package joins
Physical execution operators for join operations.
- Alphabetic
- By Inheritance
- joins
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Type Members
-
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.
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 broadcast relation. This data is then placed in a Spark broadcast variable. The streamed relation is not shuffled.
- case class BroadcastNestedLoopJoinExec(left: SparkPlan, right: SparkPlan, buildSide: BuildSide, joinType: JoinType, condition: Option[Expression]) extends SparkPlan with BinaryExecNode with Product with Serializable
- sealed abstract class BuildSide extends AnyRef
- case class CartesianProductExec(left: SparkPlan, right: SparkPlan, condition: Option[Expression]) extends SparkPlan with BinaryExecNode with Product with Serializable
- trait HashJoin extends AnyRef
-
case class
HashedRelationBroadcastMode(key: Seq[Expression]) extends BroadcastMode with Product with Serializable
The HashedRelationBroadcastMode requires that rows are broadcasted as a HashedRelation.
- class LongHashedRelation extends HashedRelation with Externalizable
-
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.
-
case class
SortMergeJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, condition: Option[Expression], left: SparkPlan, right: SparkPlan, isSkewJoin: Boolean = false) extends SparkPlan with BinaryExecNode with CodegenSupport with Product with Serializable
Performs a sort merge join of two child relations.
-
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).