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 AbstractGettableData with catalyst.expressions.Row with Serializable

  3. case class CassandraTableScan(attributes: Seq[Attribute], relation: CassandraRelation, pushdownPred: Seq[Expression])(context: CassandraSQLContext) extends SparkPlan with LeafNode with Logging with Product with Serializable

    Annotations
    @DeveloperApi()
  4. case class InsertIntoCassandraTable(cassandraRelation: CassandraRelation, childPlan: SparkPlan, overwrite: Boolean)(cc: CassandraSQLContext) extends SparkPlan with UnaryNode with Product with Serializable

    Annotations
    @DeveloperApi()

Value Members

  1. object CassandraSQLContext extends Serializable

  2. object CassandraSQLRow extends Serializable

  3. object ColumnDataType

  4. package api

Inherited from AnyRef

Inherited from Any

Ungrouped