Class/Object

org.apache.spark.sql.cassandra

CassandraSourceRelation

Related Docs: object CassandraSourceRelation | package cassandra

Permalink

case class 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) extends BaseRelation with InsertableRelation with PrunedFilteredScan with CassandraTableDefProvider with Logging with Product with Serializable

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
Serializable, Serializable, Product, Equals, Logging, CassandraTableDefProvider, PrunedFilteredScan, InsertableRelation, BaseRelation, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. CassandraSourceRelation
  2. Serializable
  3. Serializable
  4. Product
  5. Equals
  6. Logging
  7. CassandraTableDefProvider
  8. PrunedFilteredScan
  9. InsertableRelation
  10. BaseRelation
  11. AnyRef
  12. 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
    Definition Classes
    CassandraSourceRelation → Equals
  9. implicit val cassandraConnector: CassandraConnector

    Permalink
  10. def checkMetadataColumn(columnName: String, function: String): Boolean

    Permalink
  11. def clone(): AnyRef

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

    Permalink
  13. val connector: CassandraConnector

    Permalink
  14. val directJoinSetting: DirectJoinSetting

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

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

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

    Permalink
  18. def finalize(): Unit

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

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

    Permalink
    Definition Classes
    CassandraSourceRelation → AnyRef → Any
  21. val ignoreMissingMetadataColumns: Boolean

    Permalink
  22. def insert(data: DataFrame, overwrite: Boolean): Unit

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
  38. def needConversion: Boolean

    Permalink
    Definition Classes
    BaseRelation
  39. val nonRegularColumnNames: Seq[String]

    Permalink
  40. final def notify(): Unit

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

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

    Permalink
  43. val readConf: ReadConf

    Permalink
  44. implicit val readconf: ReadConf

    Permalink
  45. val regularColumnNames: Seq[String]

    Permalink
  46. def schema: StructType

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

    Permalink
  48. def sizeInBytes: Long

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

    Permalink
  50. val sqlContext: SQLContext

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

    Permalink
    Definition Classes
    AnyRef
  52. val tableDef: TableDef

    Permalink
  53. val tableRef: TableRef

    Permalink
  54. val tableSizeInBytes: Option[Long]

    Permalink
  55. def toString(): String

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

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

    Permalink
  58. final def wait(): Unit

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

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

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

    Permalink
  62. def withSparkConfOption(key: String, value: String): CassandraSourceRelation

    Permalink
  63. val writeConf: WriteConf

    Permalink

Inherited from Serializable

Inherited from Serializable

Inherited from Product

Inherited from Equals

Inherited from Logging

Inherited from CassandraTableDefProvider

Inherited from PrunedFilteredScan

Inherited from InsertableRelation

Inherited from BaseRelation

Inherited from AnyRef

Inherited from Any

Ungrouped