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
BroadcastHashJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], buildSide: BuildSide, left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with HashJoin with Product with Serializable
-
case class
BroadcastNestedLoopJoin(left: SparkPlan, right: SparkPlan, buildSide: BuildSide, joinType: JoinType, condition: Option[Expression]) extends SparkPlan with BinaryNode with Product with Serializable
-
sealed abstract
class
BuildSide extends AnyRef
-
case class
CacheCommand(tableName: String, doCache: Boolean)(context: SQLContext) extends SparkPlan with LeafNode with Command with Product with Serializable
-
-
trait
Command extends AnyRef
-
case class
DescribeCommand(child: SparkPlan, output: Seq[Attribute])(context: SQLContext) extends SparkPlan with LeafNode with Command 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) 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, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
ExistingRdd(output: Seq[Attribute], rdd: RDD[catalyst.expressions.Row]) extends SparkPlan with LeafNode with Product with Serializable
-
case class
ExplainCommand(logicalPlan: LogicalPlan, output: Seq[Attribute], extended: Boolean)(context: SQLContext) extends SparkPlan with LeafNode with Command 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, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
GeneratedAggregate(partial: Boolean, groupingExpressions: Seq[Expression], aggregateExpressions: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
trait
HashJoin extends AnyRef
-
case class
HashOuterJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, condition: Option[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable
-
case class
Intersect(left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable
-
case class
LeftSemiJoinBNL(streamed: SparkPlan, broadcast: SparkPlan, condition: Option[Expression]) extends SparkPlan with BinaryNode with Product with Serializable
-
case class
LeftSemiJoinHash(leftKeys: Seq[Expression], rightKeys: Seq[Expression], left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with HashJoin 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
Sample(fraction: Double, withReplacement: Boolean, seed: Long, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
SetCommand(key: Option[String], value: Option[String], output: Seq[Attribute])(context: SQLContext) extends SparkPlan with LeafNode with Command with Logging with Product with Serializable
-
case class
ShuffledHashJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], buildSide: BuildSide, left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with HashJoin with Product with Serializable
-
case class
Sort(sortOrder: Seq[SortOrder], global: Boolean, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
SparkLogicalPlan(alreadyPlanned: SparkPlan)(sqlContext: SQLContext) extends LogicalPlan with MultiInstanceRelation 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
Union(children: Seq[SparkPlan]) extends SparkPlan with Product with 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.