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. class CassandraSQLContext extends SQLContext

    Allows to execute SQL queries against Cassandra and access results as SchemaRDD collections.

  2. final class CassandraSQLRow extends GettableData with Row with Serializable

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

    Store data source options

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

    Cassandra data source extends RelationProvider, SchemaRelationProvider and CreatableRelationProvider.

  5. trait PredicateOps[Predicate] extends AnyRef

    A unified API for predicates, used by PredicatePushDown.

  6. class PredicatePushDown[Predicate] extends AnyRef

    Determines which filter predicates can be pushed down to Cassandra.

  7. 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. object CassandraSQLContext extends Serializable

  2. object CassandraSQLRow extends Serializable

  3. object CassandraSourceRelation

  4. object DataTypeConverter extends Logging

    Convert Cassandra data type to Catalyst data type

  5. object DefaultSource

  6. object PredicateOps

    Provides PredicateOps adapters for Expression and Filter classes

Inherited from AnyRef

Inherited from Any

Ungrouped