org.apache.spark.sql

cassandra

package cassandra

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. cassandra
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. case class AnalyzedPredicates(handledByCassandra: Set[Filter], handledBySpark: Set[Filter]) extends Product with Serializable

  2. class BasicCassandraPredicatePushDown[Predicate] extends AnyRef

    Determines which filter predicates can be pushed down to Cassandra.

  3. trait CassandraPredicateRules extends AnyRef

  4. implicit final class CassandraSQLContextFunctions extends AnyVal

  5. final class CassandraSQLRow extends GettableData with Row with Serializable

  6. case class CassandraSourceOptions(pushdown: Boolean = true, confirmTruncate: Boolean = false, cassandraConfs: Map[String, String] = ...) extends Product with Serializable

    Store data source options

  7. implicit final class CassandraSparkSessionFunctions extends AnyVal

  8. implicit final class DataFrameReaderWrapper extends AnyVal

  9. implicit final class DataFrameWriterWrapper[T] extends AnyVal

  10. class DefaultSource extends RelationProvider with SchemaRelationProvider with CreatableRelationProvider with Logging

    Cassandra data source extends RelationProvider, SchemaRelationProvider and CreatableRelationProvider.

  11. trait PredicateOps[Predicate] extends AnyRef

    A unified API for predicates, used by BasicCassandraPredicatePushDown.

  12. case class TableRef(table: String, keyspace: String, cluster: Option[String] = scala.None) extends Product with Serializable

    Store table name, keyspace name and option cluster name, keyspace is equivalent to database

Value Members

  1. val CassandraFormat: String

    A data frame format used to access Cassandra through Connector

  2. object CassandraSQLContextParams

  3. object CassandraSQLRow extends Serializable

  4. object CassandraSourceRelation

  5. object DataTypeConverter extends Logging

    Convert Cassandra data type to Catalyst data type

  6. object DefaultSource

  7. object PredicateOps

    Provides PredicateOps adapters for Expression and Filter classes

  8. def cassandraOptions(table: String, keyspace: String, cluster: String = ..., pushdownEnable: Boolean = true): Map[String, String]

    Returns a map of options which configure the path to Cassandra table as well as whether pushdown is enabled or not

Inherited from AnyRef

Inherited from Any

Ungrouped