public class BatchPythonEvaluation extends SparkPlan implements scala.Product, scala.Serializable
PythonUDF
, one partition of tuples at a time. The input
data is cached and zipped with the result of the udf evaluation.Constructor and Description |
---|
BatchPythonEvaluation(PythonUDF udf,
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output,
SparkPlan child) |
Modifier and Type | Method and Description |
---|---|
SparkPlan |
child() |
scala.collection.immutable.List<SparkPlan> |
children() |
RDD<org.apache.spark.sql.catalyst.expressions.Row> |
execute()
Runs this query returning the result as an RDD.
|
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> |
output() |
PythonUDF |
udf() |
codegenEnabled, executeCollect, makeCopy, outputPartitioning, requiredChildDistribution
expressions, inputSet, missingInput, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionDown$1, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionUp$1, outputSet, printSchema, references, schema, schemaString, simpleString, statePrefix, transformAllExpressions, transformExpressions, transformExpressionsDown, transformExpressionsUp
apply, argString, asCode, collect, fastEquals, flatMap, foreach, generateTreeString, getNodeNumbered, map, mapChildren, nodeName, numberedTreeString, otherCopyArgs, stringArgs, toString, transform, transformChildrenDown, transformChildrenUp, transformDown, transformUp, treeString, withNewChildren
productArity, productElement, productIterator, productPrefix
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
public PythonUDF udf()
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 child()
public scala.collection.immutable.List<SparkPlan> children()
children
in class org.apache.spark.sql.catalyst.trees.TreeNode<SparkPlan>