public class BroadcastNestedLoopJoin extends SparkPlan implements scala.Product, scala.Serializable
| Constructor and Description |
|---|
BroadcastNestedLoopJoin(SparkPlan streamed,
SparkPlan broadcast,
org.apache.spark.sql.catalyst.plans.JoinType joinType,
scala.Option<org.apache.spark.sql.catalyst.expressions.Expression> condition,
SQLContext sqlContext) |
| Modifier and Type | Method and Description |
|---|---|
scala.Function1<org.apache.spark.sql.catalyst.expressions.Row,Object> |
boundCondition() |
SparkPlan |
broadcast() |
scala.Option<org.apache.spark.sql.catalyst.expressions.Expression> |
condition() |
RDD<org.apache.spark.sql.catalyst.expressions.Row> |
execute()
Runs this query returning the result as an RDD.
|
org.apache.spark.sql.catalyst.plans.JoinType |
joinType() |
SparkPlan |
left()
The Streamed Relation
|
scala.collection.immutable.List<SQLContext> |
otherCopyArgs() |
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.
|
SparkPlan |
right()
The Broadcast relation
|
SparkPlan |
streamed() |
executeCollect, requiredChildDistributionexpressions, 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, transformExpressionsUpapply, argString, asCode, children, collect, fastEquals, flatMap, foreach, generateTreeString, getNodeNumbered, id, makeCopy, map, mapChildren, nextId, nodeName, numberedTreeString, sameInstance, simpleString, stringArgs, toString, transform, transformChildrenDown, transformChildrenUp, transformDown, transformUp, treeString, withNewChildrenpublic BroadcastNestedLoopJoin(SparkPlan streamed, SparkPlan broadcast, org.apache.spark.sql.catalyst.plans.JoinType joinType, scala.Option<org.apache.spark.sql.catalyst.expressions.Expression> condition, SQLContext sqlContext)
public SparkPlan streamed()
public SparkPlan broadcast()
public org.apache.spark.sql.catalyst.plans.JoinType joinType()
public scala.Option<org.apache.spark.sql.catalyst.expressions.Expression> condition()
public org.apache.spark.sql.catalyst.plans.physical.Partitioning outputPartitioning()
SparkPlanoutputPartitioning in class SparkPlanpublic scala.collection.immutable.List<SQLContext> otherCopyArgs()
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output()
output in class org.apache.spark.sql.catalyst.plans.QueryPlan<SparkPlan>public SparkPlan left()
public SparkPlan right()
public scala.Function1<org.apache.spark.sql.catalyst.expressions.Row,Object> boundCondition()