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 BinaryNode extends LogicalPlan with trees.BinaryNode[LogicalPlan]

    A logical plan node with a left and right child.

  3. case class CacheTableCommand(tableName: String, plan: Option[LogicalPlan], isLazy: Boolean) extends Command with Product with Serializable

    Returned for the "CACHE TABLE tableName [AS SELECT ...]" command.

  4. abstract class Command extends LeafNode

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

    A logical node that represents a non-query command to be executed by the system. For example, commands can be used by parsers to represent DDL operations.

  5. case class CreateTableAsSelect[T](databaseName: Option[String], tableName: String, child: LogicalPlan, allowExisting: Boolean, desc: Option[T] = None) extends UnaryNode with Product with Serializable

  6. case class DFSCommand(kv: Option[(String, Option[String])]) extends Command with Product with Serializable

    Commands of the form "SET [key [= value] ]".

  7. case class DescribeCommand(table: LogicalPlan, isExtended: Boolean) extends Command with Product with Serializable

    Returned for the "DESCRIBE [EXTENDED] [dbName.]tableName" command.

    Returned for the "DESCRIBE [EXTENDED] [dbName.]tableName" command.

    table

    The table to be described.

    isExtended

    True if "DESCRIBE EXTENDED" is used. Otherwise, false. It is effective only when the table is a Hive table.

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

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

  10. case class ExplainCommand(plan: LogicalPlan, extended: Boolean = false) 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.

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

  12. 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.

    Applies a Generator to a stream of input rows, combining the output of each into a new stream of rows. This operation is similar to a flatMap in functional programming with one important additional feature, which allows the input rows to be joined with their output.

    join

    when true, each output row is implicitly joined with the input tuple that produced it.

    outer

    when true, each input row will be output at least once, even if the output of the given generator is empty. outer has no effect when join is false.

    alias

    when set, this string is applied to the schema of the output of the transformation as a qualifier.

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

  14. case class Intersect(left: LogicalPlan, right: LogicalPlan) extends BinaryNode with Product with Serializable

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

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

    A logical plan node with no children.

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

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

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

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

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

    Returned for commands supported by a given parser, but not catalyst. In general these are DDL commands that are passed directly to another system.

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

  22. abstract class RedistributeData extends UnaryNode

    Performs a physical redistribution of the data.

    Performs a physical redistribution of the data. Used when the consumer of the query result have expectations about the distribution and ordering of partitioned input data.

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

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

  25. 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.

    Transforms the input by forking and running the specified script.

    input

    the set of expression that should be passed to the script.

    script

    the command that should be executed.

    output

    the attributes that are produced by the script.

  26. case class SetCommand(kv: Option[(String, Option[String])]) extends Command with Product with Serializable

    Commands of the form "SET [key [= value] ]".

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

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

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

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

    A logical plan node with single child.

  31. case class UncacheTableCommand(tableName: String) extends Command with Product with Serializable

    Returned for the "UNCACHE TABLE tableName" command.

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

  33. 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