public class LeftSemiJoinHash extends SparkPlan implements scala.Product, scala.Serializable
Constructor and Description |
---|
LeftSemiJoinHash(scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> leftKeys,
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> rightKeys,
SparkPlan left,
SparkPlan right) |
Modifier and Type | Method and Description |
---|---|
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> |
buildKeys() |
SparkPlan |
buildPlan() |
org.apache.spark.sql.catalyst.expressions.Projection |
buildSideKeyGenerator() |
RDD<org.apache.spark.sql.catalyst.expressions.Row> |
execute()
Runs this query returning the result as an RDD.
|
SparkPlan |
left() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> |
leftKeys() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> |
output() |
org.apache.spark.sql.catalyst.plans.physical.Partitioning |
outputPartitioning()
Specifies how data is partitioned across different nodes in the cluster.
|
scala.collection.immutable.List<org.apache.spark.sql.catalyst.plans.physical.ClusteredDistribution> |
requiredChildDistribution() |
SparkPlan |
right() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> |
rightKeys() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> |
streamedKeys() |
SparkPlan |
streamedPlan() |
scala.Function0<org.apache.spark.sql.catalyst.expressions.MutableProjection> |
streamSideKeyGenerator() |
executeCollect
expressions, generateSchemaString, generateSchemaString, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionDown$1, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionUp$1, outputSet, printSchema, schemaString, transformAllExpressions, transformExpressions, transformExpressionsDown, transformExpressionsUp
apply, argString, asCode, children, collect, fastEquals, flatMap, foreach, generateTreeString, getNodeNumbered, id, makeCopy, map, mapChildren, nextId, nodeName, numberedTreeString, otherCopyArgs, sameInstance, simpleString, stringArgs, toString, transform, transformChildrenDown, transformChildrenUp, transformDown, transformUp, treeString, withNewChildren
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> leftKeys()
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> rightKeys()
public SparkPlan left()
public SparkPlan right()
public org.apache.spark.sql.catalyst.plans.physical.Partitioning outputPartitioning()
SparkPlan
outputPartitioning
in class SparkPlan
public scala.collection.immutable.List<org.apache.spark.sql.catalyst.plans.physical.ClusteredDistribution> requiredChildDistribution()
public SparkPlan buildPlan()
public SparkPlan streamedPlan()
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> buildKeys()
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> streamedKeys()
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output()
output
in class org.apache.spark.sql.catalyst.plans.QueryPlan<SparkPlan>
public org.apache.spark.sql.catalyst.expressions.Projection buildSideKeyGenerator()
public scala.Function0<org.apache.spark.sql.catalyst.expressions.MutableProjection> streamSideKeyGenerator()