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. abstract class BaseRelation extends LeafNode

  3. abstract class BinaryNode extends LogicalPlan with trees.BinaryNode[LogicalPlan]

    A logical plan node with a left and right child.

  4. abstract class Command extends LeafNode

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

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

  6. case class ExplainCommand(plan: LogicalPlan) extends Command with Product with Serializable

    Returned by a parser when the users only wants to see what query plan would be executed, without actually performing the execution.

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

  8. case class Generate(generator: Generator, join: Boolean, outer: Boolean, alias: Option[String], 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.

  9. case class InsertIntoCreatedTable(databaseName: Option[String], tableName: String, child: LogicalPlan) extends UnaryNode with Product with Serializable

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

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

  12. abstract class LeafNode extends LogicalPlan with trees.LeafNode[LogicalPlan]

    A logical plan node with no children.

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

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

  15. abstract class LogicalPlan extends QueryPlan[LogicalPlan]

  16. case class LowerCaseSchema(child: LogicalPlan) extends UnaryNode with Product with Serializable

    Converts the schema of child to all lowercase, together with LowercaseAttributeReferences this allows for optional case insensitive attribute resolution.

  17. case class NativeCommand(cmd: String) extends Command with Product with Serializable

    Returned for commands supported by a given parser, but not catalyst.

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

  19. abstract class RedistributeData extends UnaryNode

    Performs a physical redistribution of the data.

  20. case class Repartition(partitionExpressions: Seq[Expression], child: LogicalPlan) extends RedistributeData with Product with Serializable

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

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

    Transforms the input by forking and running the specified script.

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

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

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

  26. abstract class UnaryNode extends LogicalPlan with trees.UnaryNode[LogicalPlan]

    A logical plan node with single child.

  27. case class Union(left: LogicalPlan, right: LogicalPlan) extends BinaryNode with Product with Serializable

  28. case class WriteToFile(path: String, child: LogicalPlan) extends UnaryNode with Product with Serializable

Value Members

  1. object LocalRelation extends Serializable

  2. object NoRelation extends LeafNode with Product with Serializable

Ungrouped