org.apache.spark.sql.execution

joins

package joins

Physical execution operators for join operations.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. joins
  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 BroadcastHashJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, buildSide: BuildSide, condition: Option[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryExecNode with HashJoin with CodegenSupport with Product with Serializable

    Performs an inner hash join of two child relations.

  2. case class BroadcastNestedLoopJoinExec(left: SparkPlan, right: SparkPlan, buildSide: BuildSide, joinType: JoinType, condition: Option[Expression]) extends SparkPlan with BinaryExecNode with Product with Serializable

  3. sealed abstract class BuildSide extends AnyRef

  4. case class CartesianProductExec(left: SparkPlan, right: SparkPlan, condition: Option[Expression]) extends SparkPlan with BinaryExecNode with Product with Serializable

  5. trait HashJoin extends AnyRef

  6. case class ShuffledHashJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, buildSide: BuildSide, condition: Option[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryExecNode with HashJoin with Product with Serializable

    Performs a hash join of two child relations by first shuffling the data using the join keys.

  7. case class SortMergeJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, condition: Option[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryExecNode with CodegenSupport with Product with Serializable

    Performs a sort merge join of two child relations.

  8. class UnsafeCartesianRDD extends CartesianRDD[UnsafeRow, UnsafeRow]

    An optimized CartesianRDD for UnsafeRow, which will cache the rows from second child RDD, will be much faster than building the right partition for every row in left RDD, it also materialize the right RDD (in case of the right RDD is nondeterministic).

Value Members

  1. object BuildLeft extends BuildSide with Product with Serializable

  2. object BuildRight extends BuildSide with Product with Serializable

  3. object HashJoin

Inherited from AnyRef

Inherited from Any

Ungrouped