Package

org.apache.spark.sql.cassandra

execution

Permalink

package execution

Visibility
  1. Public
  2. All

Type Members

  1. case class CassandraDirectJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, cassandraSide: BuildSide, condition: Option[Expression], child: SparkPlan, aliasMap: Map[String, Attribute], cassandraScan: CassandraTableScanRDD[_], cassandraPlan: DataSourceScanExec) extends SparkPlan with UnaryExecNode with Product with Serializable

    Permalink

    A physical plan for performing a join against a CassandraTable given a set of keys.

  2. case class CassandraDirectJoinStrategy(spark: SparkSession) extends Strategy with Serializable with Product

    Permalink

    Direct Join Strategy Converts logical plans where the join target is a Cassandra derived branch with joinWithCassandraTable style Join

Value Members

  1. object CassandraDirectJoinStrategy extends Logging with Serializable

    Permalink
  2. package unsafe

    Permalink

Ungrouped