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 BroadcastHashJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], buildSide: BuildSide, left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with HashJoin with Product with Serializable

    Performs an inner hash join of two child relations.

  2. case class BroadcastHashOuterJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, condition: Option[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with HashOuterJoin with Product with Serializable

    Performs a outer hash join for two child relations.

  3. case class BroadcastLeftSemiJoinHash(leftKeys: Seq[Expression], rightKeys: Seq[Expression], left: SparkPlan, right: SparkPlan, condition: Option[Expression]) extends SparkPlan with BinaryNode with HashSemiJoin with Product with Serializable

    Build the right table's join keys into a HashSet, and iteratively go through the left table, to find the if join keys are in the Hash set.

  4. case class BroadcastNestedLoopJoin(left: SparkPlan, right: SparkPlan, buildSide: BuildSide, joinType: JoinType, condition: Option[Expression]) extends SparkPlan with BinaryNode with Product with Serializable

  5. sealed abstract class BuildSide extends AnyRef

  6. case class CartesianProduct(left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable

  7. trait HashJoin extends AnyRef

  8. trait HashOuterJoin extends AnyRef

  9. trait HashSemiJoin extends AnyRef

  10. case class LeftSemiJoinBNL(streamed: SparkPlan, broadcast: SparkPlan, condition: Option[Expression]) extends SparkPlan with BinaryNode with Product with Serializable

    Using BroadcastNestedLoopJoin to calculate left semi join result when there's no join keys for hash join.

  11. case class LeftSemiJoinHash(leftKeys: Seq[Expression], rightKeys: Seq[Expression], left: SparkPlan, right: SparkPlan, condition: Option[Expression]) extends SparkPlan with BinaryNode with HashSemiJoin with Product with Serializable

    Build the right table's join keys into a HashSet, and iteratively go through the left table, to find the if join keys are in the Hash set.

  12. case class SortMergeJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable

    Performs an sort merge join of two child relations.

  13. case class SortMergeOuterJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, condition: Option[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable

    Performs an sort merge outer join of two child relations.

Value Members

  1. object BroadcastHashJoin extends Serializable

  2. object BuildLeft extends BuildSide with Product with Serializable

  3. object BuildRight extends BuildSide with Product with Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped