Packages

package joins

Ordering
  1. Alphabetic
Visibility
  1. Public
  2. Protected

Type Members

  1. trait BaseJoinExec extends SparkPlan with BinaryExecNode

    Holds common logic for join operators

  2. case class BroadcastHashJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, buildSide: BuildSide, condition: Option[Expression], left: SparkPlan, right: SparkPlan, isNullAwareAntiJoin: Boolean = false) extends SparkPlan with HashJoin 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.

  3. case class BroadcastNestedLoopJoinExec(left: SparkPlan, right: SparkPlan, buildSide: BuildSide, joinType: JoinType, condition: Option[Expression]) extends SparkPlan with JoinCodegenSupport with Product with Serializable
  4. case class CartesianProductExec(left: SparkPlan, right: SparkPlan, condition: Option[Expression]) extends SparkPlan with BaseJoinExec with Product with Serializable
  5. trait HashJoin extends SparkPlan with JoinCodegenSupport
  6. case class HashedRelationBroadcastMode(key: Seq[Expression], isNullAware: Boolean = false) extends BroadcastMode with Product with Serializable

    The HashedRelationBroadcastMode requires that rows are broadcasted as a HashedRelation.

  7. trait JoinCodegenSupport extends SparkPlan with CodegenSupport with BaseJoinExec

    An interface for those join physical operators that support codegen.

  8. class LongHashedRelation extends HashedRelation with Externalizable
  9. case class ShuffledHashJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, buildSide: BuildSide, condition: Option[Expression], left: SparkPlan, right: SparkPlan, isSkewJoin: Boolean = false) extends SparkPlan with HashJoin with ShuffledJoin with Product with Serializable

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

  10. trait ShuffledJoin extends SparkPlan with JoinCodegenSupport

    Holds common logic for join operators by shuffling two child relations using the join keys.

  11. case class SortMergeJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, condition: Option[Expression], left: SparkPlan, right: SparkPlan, isSkewJoin: Boolean = false) extends SparkPlan with ShuffledJoin with Product with Serializable

    Performs a sort merge join of two child relations.

  12. 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. case object EmptyHashedRelation extends HashedRelation with Product with Serializable

    A special HashedRelation indicating that it's built from a empty input:Iterator[InternalRow].

    A special HashedRelation indicating that it's built from a empty input:Iterator[InternalRow]. get & getValue will return null just like empty LongHashedRelation or empty UnsafeHashedRelation does.

  2. object HashJoin extends CastSupport with SQLConfHelper with Serializable
  3. case object HashedRelationWithAllNullKeys extends HashedRelation with Product with Serializable

    A special HashedRelation indicating that it's built from a non-empty input:Iterator[InternalRow] with all the keys to be null.

Ungrouped