Package

org.apache.spark.sql.execution

joins

Permalink

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

    Permalink

    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.

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

    Permalink
  3. sealed abstract class BuildSide extends AnyRef

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

    Permalink
  5. trait HashJoin extends AnyRef

    Permalink
  6. case class HashJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], buildSide: BuildSide, condition: Option[Expression], joinType: JoinType, left: SparkPlan, right: SparkPlan, leftSizeInBytes: BigInt, rightSizeInBytes: BigInt, replicatedTableJoin: Boolean) extends NonRecursivePlans with BinaryExecNode with HashJoin with SnappyJoinLike with BatchConsumer with Product with Serializable

    Permalink

    :: DeveloperApi :: Performs a local hash join of two child relations.

    :: DeveloperApi :: Performs a local hash join of two child relations. If a relation (out of a datasource) is already replicated across all nodes then rather than doing a Broadcast join which can be expensive, this join just scans through the single partition of the replicated relation while streaming through the other relation.

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

    Permalink

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

  8. trait SnappyJoinLike extends SparkPlan

    Permalink

    Base trait for joins used in SnappyData.

    Base trait for joins used in SnappyData. Currently this allows children to have subsets of join keys as partitioning columns without introducing a shuffle.

  9. class SnappySortMergeJoinExec extends SortMergeJoinExec with SnappyJoinLike

    Permalink

    Extension to Spark's SortMergeJoinExec to avoid exchange for cases when join keys are a subset of child plan partitioning.

  10. 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

    Permalink

    Performs a sort merge join of two child relations.

  11. class UnsafeCartesianRDD extends CartesianRDD[UnsafeRow, UnsafeRow]

    Permalink

    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

    Permalink
  2. object BuildRight extends BuildSide with Product with Serializable

    Permalink
  3. object HashJoin

    Permalink
  4. object HashedObjectCache

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped