Package

org.apache.spark.sql

cassandra

Permalink

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
Visibility
  1. Public
  2. All

Type Members

  1. class CassandraXDSourceRelation extends BaseRelation with InsertableRelation with PrunedFilteredScan with NativeFunctionExecutor with NativeScan with SparkLoggerComponent

    Permalink

    Implements org.apache.spark.sql.sources.BaseRelation]], org.apache.spark.sql.sources.InsertableRelation]] and org.apache.spark.sql.sources.PrunedFilteredScan]] It inserts data to and scans Cassandra table.

    Implements org.apache.spark.sql.sources.BaseRelation]], org.apache.spark.sql.sources.InsertableRelation]] and org.apache.spark.sql.sources.PrunedFilteredScan]] It inserts data to and scans Cassandra table. If filterPushdown is true, it pushs down some filters to CQL

Value Members

  1. val CassandraFormat: String

    Permalink
  2. object CassandraXDSourceRelation

    Permalink
  3. def cassandraOptions(table: String, keyspace: String, cluster: String, pushdownEnable: Boolean): Map[String, String]

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped