package
execution
Type Members
-
case class
Aggregate(partial: Boolean, groupingExpressions: Seq[Expression], aggregateExpressions: Seq[NamedExpression], child: SparkPlan)(sc: SparkContext) extends SparkPlan with UnaryNode with NoBind with Product with Serializable
-
case class
BroadcastNestedLoopJoin(streamed: SparkPlan, broadcast: SparkPlan, joinType: JoinType, condition: Option[Expression])(sc: SparkContext) extends SparkPlan with BinaryNode with Product with Serializable
-
sealed abstract
class
BuildSide extends AnyRef
-
-
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
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
HashJoin(leftKeys: Seq[Expression], rightKeys: Seq[Expression], buildSide: BuildSide, left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryNode with Product with Serializable
-
case class
Limit(limit: Int, child: SparkPlan)(sc: SparkContext) extends SparkPlan with UnaryNode 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
Sort(sortOrder: Seq[SortOrder], global: Boolean, child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
SparkLogicalPlan(alreadyPlanned: SparkPlan) extends LogicalPlan with MultiInstanceRelation with Product with Serializable
-
-
case class
TakeOrdered(limit: Int, sortOrder: Seq[SortOrder], child: SparkPlan)(sc: SparkContext) extends SparkPlan with UnaryNode with Product with Serializable
-
case class
Union(children: Seq[SparkPlan])(sc: SparkContext) 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.