org.apache.spark.sql.catalyst.plans

logical

package logical

Visibility
  1. Public
  2. All

Type Members

  1. case class Aggregate(groupingExpressions: Seq[Expression], aggregateExpressions: Seq[NamedExpression], child: LogicalPlan) extends UnaryNode with Product with Serializable

  2. case class AppendColumns[T, U](func: (T) ⇒ U, tEncoder: ExpressionEncoder[T], uEncoder: ExpressionEncoder[U], newColumns: Seq[Attribute], child: LogicalPlan) extends UnaryNode with Product with Serializable

    A relation produced by applying func to each partition of the child, concatenating the resulting columns at the end of the input row.

  3. abstract class BinaryNode extends LogicalPlan

    A logical plan node with a left and right child.

  4. case class BroadcastHint(child: LogicalPlan) extends UnaryNode with Product with Serializable

    A hint for the optimizer that we should broadcast the child if used in a join operator.

  5. case class CoGroup[Key, Left, Right, Result](func: (Key, Iterator[Left], Iterator[Right]) ⇒ TraversableOnce[Result], keyEnc: ExpressionEncoder[Key], leftEnc: ExpressionEncoder[Left], rightEnc: ExpressionEncoder[Right], resultEnc: ExpressionEncoder[Result], output: Seq[Attribute], leftGroup: Seq[Attribute], rightGroup: Seq[Attribute], left: LogicalPlan, right: LogicalPlan) extends BinaryNode with Product with Serializable

    A relation produced by applying func to each grouping key and associated values from left and right children.

  6. trait Command extends AnyRef

    A logical node that represents a non-query command to be executed by the system.

  7. case class Cube(groupByExprs: Seq[Expression], child: LogicalPlan, aggregations: Seq[NamedExpression]) extends UnaryNode with GroupingAnalytics with Product with Serializable

    Cube is a syntactic sugar for GROUPING SETS, and will be transformed to GroupingSets, and eventually will be transformed to Aggregate(.

  8. case class Distinct(child: LogicalPlan) extends UnaryNode with Product with Serializable

    Returns a new logical plan that dedups input rows.

  9. case class Except(left: LogicalPlan, right: LogicalPlan) extends SetOperation with Product with Serializable

  10. case class Expand(projections: Seq[Seq[Expression]], output: Seq[Attribute], child: LogicalPlan) extends UnaryNode with Product with Serializable

    Apply a number of projections to every input row, hence we will get multiple output rows for a input row.

  11. case class Filter(condition: Expression, child: LogicalPlan) extends UnaryNode with Product with Serializable

  12. case class Generate(generator: Generator, join: Boolean, outer: Boolean, qualifier: Option[String], generatorOutput: Seq[Attribute], child: LogicalPlan) extends UnaryNode with Product with Serializable

    Applies a Generator to a stream of input rows, combining the output of each into a new stream of rows.

  13. trait GroupingAnalytics extends UnaryNode

  14. case class GroupingSets(bitmasks: Seq[Int], groupByExprs: Seq[Expression], child: LogicalPlan, aggregations: Seq[NamedExpression]) extends UnaryNode with GroupingAnalytics with Product with Serializable

    A GROUP BY clause with GROUPING SETS can generate a result set equivalent to generated by a UNION ALL of multiple simple GROUP BY clauses.

  15. case class InsertIntoTable(table: LogicalPlan, partition: Map[String, Option[String]], child: LogicalPlan, overwrite: Boolean, ifNotExists: Boolean) extends LogicalPlan with Product with Serializable

  16. case class Intersect(left: LogicalPlan, right: LogicalPlan) extends SetOperation with Product with Serializable

  17. case class Join(left: LogicalPlan, right: LogicalPlan, joinType: JoinType, condition: Option[Expression]) extends BinaryNode with Product with Serializable

  18. abstract class LeafNode extends LogicalPlan

    A logical plan node with no children.

  19. case class Limit(limitExpr: Expression, child: LogicalPlan) extends UnaryNode with Product with Serializable

  20. case class LocalRelation(output: Seq[Attribute], data: Seq[InternalRow] = immutable.this.Nil) extends LeafNode with MultiInstanceRelation with Product with Serializable

  21. abstract class LogicalPlan extends QueryPlan[LogicalPlan] with Logging

  22. case class MapGroups[K, T, U](func: (K, Iterator[T]) ⇒ TraversableOnce[U], kEncoder: ExpressionEncoder[K], tEncoder: ExpressionEncoder[T], uEncoder: ExpressionEncoder[U], groupingAttributes: Seq[Attribute], output: Seq[Attribute], child: LogicalPlan) extends UnaryNode with Product with Serializable

    Applies func to each unique group in child, based on the evaluation of groupingAttributes.

  23. case class MapPartitions[T, U](func: (Iterator[T]) ⇒ Iterator[U], tEncoder: ExpressionEncoder[T], uEncoder: ExpressionEncoder[U], output: Seq[Attribute], child: LogicalPlan) extends UnaryNode with Product with Serializable

    A relation produced by applying func to each partition of the child.

  24. case class Pivot(groupByExprs: Seq[NamedExpression], pivotColumn: Expression, pivotValues: Seq[Literal], aggregates: Seq[Expression], child: LogicalPlan) extends UnaryNode with Product with Serializable

  25. case class Project(projectList: Seq[NamedExpression], child: LogicalPlan) extends UnaryNode with Product with Serializable

  26. abstract class RedistributeData extends UnaryNode

    Performs a physical redistribution of the data.

  27. case class Repartition(numPartitions: Int, shuffle: Boolean, child: LogicalPlan) extends UnaryNode with Product with Serializable

    Returns a new RDD that has exactly numPartitions partitions.

  28. case class RepartitionByExpression(partitionExpressions: Seq[Expression], child: LogicalPlan, numPartitions: Option[Int] = scala.None) extends RedistributeData with Product with Serializable

    This method repartitions data using Expressions into numPartitions, and receives information about the number of partitions during execution.

  29. case class Rollup(groupByExprs: Seq[Expression], child: LogicalPlan, aggregations: Seq[NamedExpression]) extends UnaryNode with GroupingAnalytics with Product with Serializable

    Rollup is a syntactic sugar for GROUPING SETS, and will be transformed to GroupingSets, and eventually will be transformed to Aggregate(.

  30. case class Sample(lowerBound: Double, upperBound: Double, withReplacement: Boolean, seed: Long, child: LogicalPlan) extends UnaryNode with Product with Serializable

    Sample the dataset.

  31. trait ScriptInputOutputSchema extends AnyRef

    A placeholder for implementation specific input and output properties when passing data to a script.

  32. case class ScriptTransformation(input: Seq[Expression], script: String, output: Seq[Attribute], child: LogicalPlan, ioschema: ScriptInputOutputSchema) extends UnaryNode with Product with Serializable

    Transforms the input by forking and running the specified script.

  33. abstract class SetOperation extends BinaryNode

  34. case class Sort(order: Seq[SortOrder], global: Boolean, child: LogicalPlan) extends UnaryNode with Product with Serializable

  35. case class SortPartitions(sortExpressions: Seq[SortOrder], child: LogicalPlan) extends RedistributeData with Product with Serializable

  36. case class Subquery(alias: String, child: LogicalPlan) extends UnaryNode with Product with Serializable

  37. abstract class UnaryNode extends LogicalPlan

    A logical plan node with single child.

  38. case class Union(left: LogicalPlan, right: LogicalPlan) extends SetOperation with Product with Serializable

  39. case class Window(projectList: Seq[Attribute], windowExpressions: Seq[NamedExpression], partitionSpec: Seq[Expression], orderSpec: Seq[SortOrder], child: LogicalPlan) extends UnaryNode with Product with Serializable

  40. case class With(child: LogicalPlan, cteRelations: Map[String, Subquery]) extends UnaryNode with Product with Serializable

    A container for holding named common table expressions (CTEs) and a query plan.

  41. case class WithWindowDefinition(windowDefinitions: Map[String, WindowSpecDefinition], child: LogicalPlan) extends UnaryNode with Product with Serializable

Value Members

  1. object AppendColumns extends Serializable

    Factory for constructing new AppendColumn nodes.

  2. object CoGroup extends Serializable

    Factory for constructing new CoGroup nodes.

  3. object LocalRelation extends Serializable

  4. object MapGroups extends Serializable

    Factory for constructing new MapGroups nodes.

  5. object OneRowRelation extends LeafNode with Product with Serializable

    A relation with one row.

Ungrouped