Package

org.apache.spark.sql.execution

joins

Permalink

package joins

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 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 SparkPlan with BinaryExecNode with HashJoin with BatchConsumer with NonRecursivePlans 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()

Value Members

  1. object HashedObjectCache

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped