Class/Object

org.apache.spark.sql.cassandra

CassandraSourceRelation

Related Docs: object CassandraSourceRelation | package cassandra

Permalink

class CassandraSourceRelation extends BaseRelation with InsertableRelation with PrunedFilteredScan with Logging

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

Linear Supertypes
Logging, PrunedFilteredScan, InsertableRelation, BaseRelation, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. CassandraSourceRelation
  2. Logging
  3. PrunedFilteredScan
  4. InsertableRelation
  5. BaseRelation
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new CassandraSourceRelation(tableRef: TableRef, userSpecifiedSchema: Option[StructType], filterPushdown: Boolean, confirmTruncate: Boolean, tableSizeInBytes: Option[Long], connector: CassandraConnector, readConf: ReadConf, writeConf: WriteConf, sparkConf: SparkConf, sqlContext: SQLContext, directJoinSetting: DirectJoinSetting = Automatic)

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. lazy val additionalRules: Seq[CassandraPredicateRules]

    Permalink
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def buildScan(requiredColumns: Array[String], filters: Array[Filter]): RDD[Row]

    Permalink
    Definition Classes
    CassandraSourceRelation → PrunedFilteredScan
  7. def buildScan(): RDD[Row]

    Permalink
  8. def canEqual(a: Any): Boolean

    Permalink
  9. implicit val cassandraConnector: CassandraConnector

    Permalink
  10. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  11. val confirmTruncate: Boolean

    Permalink
  12. val connector: CassandraConnector

    Permalink
  13. val directJoinSetting: DirectJoinSetting

    Permalink
  14. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  15. def equals(that: Any): Boolean

    Permalink
    Definition Classes
    CassandraSourceRelation → AnyRef → Any
  16. val filterPushdown: Boolean

    Permalink
  17. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  18. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  19. lazy val hashCode: Int

    Permalink
    Definition Classes
    CassandraSourceRelation → AnyRef → Any
  20. def insert(data: DataFrame, overwrite: Boolean): Unit

    Permalink
    Definition Classes
    CassandraSourceRelation → InsertableRelation
  21. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  22. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  23. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  24. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  25. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  26. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  27. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  28. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  29. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  30. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  31. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  32. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  33. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  34. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  35. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  36. def needConversion: Boolean

    Permalink
    Definition Classes
    BaseRelation
  37. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  38. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  39. val pushdownCache: TrieMap[Seq[Filter], AnalyzedPredicates]

    Permalink
  40. val readConf: ReadConf

    Permalink
  41. implicit val readconf: ReadConf

    Permalink
  42. def schema: StructType

    Permalink
    Definition Classes
    CassandraSourceRelation → BaseRelation
  43. val searchOptimization: DseSearchOptimizationSetting

    Permalink
  44. def sizeInBytes: Long

    Permalink
    Definition Classes
    CassandraSourceRelation → BaseRelation
  45. val sparkConf: SparkConf

    Permalink
  46. val sqlContext: SQLContext

    Permalink
    Definition Classes
    CassandraSourceRelation → BaseRelation
  47. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  48. val tableDef: TableDef

    Permalink
  49. val tableRef: TableRef

    Permalink
  50. val tableSizeInBytes: Option[Long]

    Permalink
  51. def toString(): String

    Permalink
    Definition Classes
    CassandraSourceRelation → AnyRef → Any
  52. def unhandledFilters(filters: Array[Filter]): Array[Filter]

    Permalink
    Definition Classes
    CassandraSourceRelation → BaseRelation
  53. val userSpecifiedSchema: Option[StructType]

    Permalink
  54. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  55. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  56. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  57. def withDirectJoin(directJoinSetting: DirectJoinSetting): CassandraSourceRelation

    Permalink
  58. val writeConf: WriteConf

    Permalink

Inherited from Logging

Inherited from PrunedFilteredScan

Inherited from InsertableRelation

Inherited from BaseRelation

Inherited from AnyRef

Inherited from Any

Ungrouped