Package

org.apache.spark.sql.execution

joins

Permalink

package joins

:: DeveloperApi :: 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
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

    Permalink

    :: DeveloperApi :: Performs an inner hash join of two child relations.

    :: DeveloperApi :: Performs an inner hash join of two child relations. When the output RDD of this operator is being constructed, a Spark job is asynchronously started to calculate the values for the broadcasted relation. This data is then placed in a Spark broadcast variable. The streamed relation is not shuffled.

    Annotations
    @DeveloperApi()
  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

    Permalink

    :: DeveloperApi :: Performs a outer hash join for two child relations.

    :: DeveloperApi :: Performs a outer hash join for two child relations. When the output RDD of this operator is being constructed, a Spark job is asynchronously started to calculate the values for the broadcasted relation. This data is then placed in a Spark broadcast variable. The streamed relation is not shuffled.

    Annotations
    @DeveloperApi()
  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

    Permalink

    :: DeveloperApi :: 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.

    :: DeveloperApi :: 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.

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

    Permalink

    :: DeveloperApi ::

    :: DeveloperApi ::

    Annotations
    @DeveloperApi()
  5. sealed abstract class BuildSide extends AnyRef

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

    Permalink

    :: DeveloperApi ::

    :: DeveloperApi ::

    Annotations
    @DeveloperApi()
  7. trait HashJoin extends AnyRef

    Permalink
  8. trait HashOuterJoin extends AnyRef

    Permalink
    Annotations
    @DeveloperApi()
  9. trait HashSemiJoin extends AnyRef

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

    Permalink

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

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

    Annotations
    @DeveloperApi()
  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

    Permalink

    :: DeveloperApi :: 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.

    :: DeveloperApi :: 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.

    Annotations
    @DeveloperApi()
  12. case class ShuffledHashJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], buildSide: BuildSide, left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with HashJoin with Product with Serializable

    Permalink

    :: DeveloperApi :: Performs an inner hash join of two child relations by first shuffling the data using the join keys.

    :: DeveloperApi :: Performs an inner hash join of two child relations by first shuffling the data using the join keys.

    Annotations
    @DeveloperApi()
  13. case class ShuffledHashOuterJoin(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

    Permalink

    :: DeveloperApi :: Performs a hash based outer join for two child relations by shuffling the data using the join keys.

    :: DeveloperApi :: Performs a hash based outer join for two child relations by shuffling the data using the join keys. This operator requires loading the associated partition in both side into memory.

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

    Permalink

    :: DeveloperApi :: Performs an sort merge join of two child relations.

    :: DeveloperApi :: Performs an sort merge join of two child relations.

    Annotations
    @DeveloperApi()
  15. 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

    Permalink

    :: DeveloperApi :: Performs an sort merge outer join of two child relations.

    :: DeveloperApi :: Performs an sort merge outer join of two child relations.

    Note: this does not support full outer join yet; see SPARK-9730 for progress on this.

    Annotations
    @DeveloperApi()

Value Members

  1. object BroadcastHashJoin extends Serializable

    Permalink
  2. object BuildLeft extends BuildSide with Product with Serializable

    Permalink
    Annotations
    @DeveloperApi()
  3. object BuildRight extends BuildSide with Product with Serializable

    Permalink
    Annotations
    @DeveloperApi()

Inherited from AnyRef

Inherited from Any

Ungrouped