package
execution
Type Members
-
case class
Aggregate(partial: Boolean, groupingExpressions: Seq[Expression], aggregateExpressions: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
AggregateEvaluation(schema: Seq[Attribute], initialValues: Seq[Expression], update: Seq[Expression], result: Expression) extends Product with Serializable
-
case class
BatchPythonEvaluation(udf: PythonUDF, output: Seq[Attribute], child: SparkPlan) extends SparkPlan with Product with Serializable
-
case class
CacheTableCommand(tableName: String, plan: Option[LogicalPlan], isLazy: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable
-
case class
DescribeCommand(child: SparkPlan, output: Seq[Attribute], isExtended: Boolean) extends LogicalPlan with RunnableCommand with Product with Serializable
-
case class
Distinct(partial: Boolean, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
EvaluatePython(udf: PythonUDF, child: LogicalPlan, resultAttribute: AttributeReference) extends catalyst.plans.logical.UnaryNode with Product with Serializable
-
case class
Except(left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable
-
case class
Exchange(newPartitioning: Partitioning, newOrdering: Seq[SortOrder], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
Expand(projections: Seq[GroupExpression], output: Seq[Attribute], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
ExplainCommand(logicalPlan: LogicalPlan, output: Seq[Attribute] = ..., extended: Boolean = false) extends LogicalPlan with RunnableCommand with Product with Serializable
-
case class
ExternalSort(sortOrder: Seq[SortOrder], global: Boolean, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
Filter(condition: Expression, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
Generate(generator: Generator, join: Boolean, outer: Boolean, output: Seq[Attribute], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
GeneratedAggregate(partial: Boolean, groupingExpressions: Seq[Expression], aggregateExpressions: Seq[NamedExpression], unsafeEnabled: Boolean, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
Intersect(left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable
-
case class
Limit(limit: Int, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
OutputFaker(output: Seq[Attribute], child: SparkPlan) extends SparkPlan with Product with Serializable
-
case class
Project(projectList: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
-
case class
Repartition(numPartitions: Int, shuffle: Boolean, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
Sample(lowerBound: Double, upperBound: Double, withReplacement: Boolean, seed: Long, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
SetCommand(kv: Option[(String, Option[String])], output: Seq[Attribute]) extends LogicalPlan with RunnableCommand with Logging with Product with Serializable
-
case class
ShowTablesCommand(databaseName: Option[String]) extends LogicalPlan with RunnableCommand with Product with Serializable
-
case class
Sort(sortOrder: Seq[SortOrder], global: Boolean, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
abstract
class
SparkPlan extends QueryPlan[SparkPlan] with Logging with Serializable
-
case class
TakeOrdered(limit: Int, sortOrder: Seq[SortOrder], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
UncacheTableCommand(tableName: String) extends LogicalPlan with RunnableCommand with Product with Serializable
-
case class
Union(children: Seq[SparkPlan]) extends SparkPlan with Product with Serializable
-
case class
Window(projectList: Seq[Attribute], windowExpression: Seq[NamedExpression], windowSpec: WindowSpecDefinition, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
Value Members
-
object
ClearCacheCommand extends LogicalPlan with RunnableCommand with Product with Serializable
-
-
object
Exchange extends Serializable
-
-
object
SparkPlan extends Serializable
-
-
Inherited from AnyRef
Inherited from Any
:: DeveloperApi :: An execution engine for relational query plans that runs on top Spark and returns RDDs.
Note that the operators in this package are created automatically by a query planner using a SQLContext and are not intended to be used directly by end users of Spark SQL. They are documented here in order to make it easier for others to understand the performance characteristics of query plans that are generated by Spark SQL.