org.apache.spark.sql

execution

package execution

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. execution
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. case class CoprocessorRDD(output: Seq[Attribute], tiRdds: List[TiRDD]) extends SparkPlan with LeafExecNode with Product with Serializable

  2. case class HandleRDDExec(tiHandleRDDs: List[TiHandleRDD]) extends SparkPlan with LeafExecNode with Product with Serializable

    HandleRDDExec is used for scanning handles from TiKV as a LeafExecNode in index plan.

  3. case class RegionTaskExec(child: SparkPlan, output: Seq[Attribute], dagRequest: TiDAGRequest, tiConf: TiConfiguration, ts: TiTimestamp, session: TiSession, sparkSession: SparkSession) extends SparkPlan with UnaryExecNode with Product with Serializable

    RegionTaskExec is used for issuing requests which are generated based on handles retrieved from HandleRDDExec aggregated by a SortAggregateExec with org.apache.spark.sql.catalyst.expressions.aggregate.CollectHandles as aggregate function.

Value Members

  1. package command

Inherited from AnyRef

Inherited from Any

Ungrouped