public class SparkLogicalPlan
extends org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
implements org.apache.spark.sql.catalyst.analysis.MultiInstanceRelation, scala.Product, scala.Serializable
Note that in general it is not valid to use this class to link multiple copies of the same physical operator into the same query plan as this violates the uniqueness of expression ids. Special handling exists for ExistingRdd as these are already leaf operators and thus we can just replace the output attributes with new copies of themselves without breaking any attribute linking.
Constructor and Description |
---|
SparkLogicalPlan(SparkPlan alreadyPlanned) |
Modifier and Type | Method and Description |
---|---|
SparkPlan |
alreadyPlanned() |
scala.collection.immutable.Nil$ |
children() |
SparkLogicalPlan |
newInstance() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> |
output() |
scala.collection.immutable.Set<org.apache.spark.sql.catalyst.expressions.Attribute> |
references() |
childrenResolved, inputSet, resolve, resolved
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, 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 SparkLogicalPlan(SparkPlan alreadyPlanned)
public SparkPlan alreadyPlanned()
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output()
output
in class org.apache.spark.sql.catalyst.plans.QueryPlan<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>
public scala.collection.immutable.Set<org.apache.spark.sql.catalyst.expressions.Attribute> references()
references
in class org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
public scala.collection.immutable.Nil$ children()
public final SparkLogicalPlan newInstance()
newInstance
in interface org.apache.spark.sql.catalyst.analysis.MultiInstanceRelation