public class Generate extends SparkPlan implements scala.Product, scala.Serializable
Generator to a stream of input rows, combining the
output of each into a new stream of rows. This operation is similar to a flatMap in functional
programming with one important additional feature, which allows the input rows to be joined with
their output.| Constructor and Description |
|---|
Generate(org.apache.spark.sql.catalyst.expressions.Generator generator,
boolean join,
boolean outer,
SparkPlan child) |
| Modifier and Type | Method and Description |
|---|---|
org.apache.spark.sql.catalyst.expressions.Generator |
boundGenerator() |
SparkPlan |
child() |
RDD<org.apache.spark.sql.catalyst.expressions.Row> |
execute()
Runs this query returning the result as an RDD.
|
org.apache.spark.sql.catalyst.expressions.Generator |
generator() |
boolean |
join() |
boolean |
outer() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> |
output() |
org.apache.spark.sql.catalyst.plans.physical.Partitioning |
outputPartitioning() |
codegenEnabled, executeCollect, makeCopy, outputPartitioning, requiredChildDistributionexpressions, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionDown$1, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionUp$1, outputSet, printSchema, schema, schemaString, transformAllExpressions, transformExpressions, transformExpressionsDown, transformExpressionsUpapply, argString, asCode, children, collect, fastEquals, flatMap, foreach, generateTreeString, getNodeNumbered, id, map, mapChildren, nextId, nodeName, numberedTreeString, otherCopyArgs, sameInstance, simpleString, stringArgs, toString, transform, transformChildrenDown, transformChildrenUp, transformDown, transformUp, treeString, withNewChildrenproductArity, productElement, productIterator, productPrefixinitialized, initializeIfNecessary, initializeLogging, initLock, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarningpublic Generate(org.apache.spark.sql.catalyst.expressions.Generator generator,
boolean join,
boolean outer,
SparkPlan child)
public org.apache.spark.sql.catalyst.expressions.Generator generator()
public boolean join()
public boolean outer()
public SparkPlan child()
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.Generator boundGenerator()
public RDD<org.apache.spark.sql.catalyst.expressions.Row> execute()
SparkPlanpublic org.apache.spark.sql.catalyst.plans.physical.Partitioning outputPartitioning()