All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.spark.sql.cassandra.TableRef.scala Maven / Gradle / Ivy

There is a newer version: 3.0.0-alpha2
Show newest version
package org.apache.spark.sql.cassandra


/** Store table name, keyspace name and option cluster name, keyspace is equivalent to database */
case class TableRef(table: String, keyspace: String, cluster: Option[String] = None)





© 2015 - 2024 Weber Informatics LLC | Privacy Policy