org.apache.spark.sql.catalyst.plans

physical

package physical

Visibility
  1. Public
  2. All

Type Members

  1. case class ClusteredDistribution(clustering: Seq[Expression]) extends Distribution with Product with Serializable

    Represents data where tuples that share the same values for the clustering Expressions will be co-located.

    Represents data where tuples that share the same values for the clustering Expressions will be co-located. Based on the context, this can mean such tuples are either co-located in the same partition or they will be contiguous within a single partition.

  2. sealed trait Distribution extends AnyRef

    Specifies how tuples that share common expressions will be distributed when a query is executed in parallel on many machines.

    Specifies how tuples that share common expressions will be distributed when a query is executed in parallel on many machines. Distribution can be used to refer to two distinct physical properties:

    • Inter-node partitioning of data: In this case the distribution describes how tuples are partitioned across physical machines in a cluster. Knowing this property allows some operators (e.g., Aggregate) to perform partition local operations instead of global ones.
    • Intra-partition ordering of data: In this case the distribution describes guarantees made about how tuples are distributed within a single partition.
  3. case class HashPartitioning(expressions: Seq[Expression], numPartitions: Int) extends Expression with Partitioning with Product with Serializable

    Represents a partitioning where rows are split up across partitions based on the hash of expressions.

    Represents a partitioning where rows are split up across partitions based on the hash of expressions. All rows where expressions evaluate to the same values are guaranteed to be in the same partition.

  4. case class OrderedDistribution(ordering: Seq[SortOrder]) extends Distribution with Product with Serializable

    Represents data where tuples have been ordered according to the ordering Expressions.

    Represents data where tuples have been ordered according to the ordering Expressions. This is a strictly stronger guarantee than ClusteredDistribution as an ordering will ensure that tuples that share the same value for the ordering expressions are contiguous and will never be split across partitions.

  5. sealed trait Partitioning extends AnyRef

  6. case class RangePartitioning(ordering: Seq[SortOrder], numPartitions: Int) extends Expression with Partitioning with Product with Serializable

    Represents a partitioning where rows are split across partitions based on some total ordering of the expressions specified in ordering.

    Represents a partitioning where rows are split across partitions based on some total ordering of the expressions specified in ordering. When data is partitioned in this manner the following two conditions are guaranteed to hold:

    • All row where the expressions in ordering evaluate to the same values will be in the same partition.
    • Each partition will have a min and max row, relative to the given ordering. All rows that are in between min and max in this ordering will reside in this partition.

    This class extends expression primarily so that transformations over expression will descend into its child.

  7. case class UnknownPartitioning(numPartitions: Int) extends Partitioning with Product with Serializable

Value Members

  1. object AllTuples extends Distribution with Product with Serializable

    Represents a distribution that only has a single partition and all tuples of the dataset are co-located.

  2. object BroadcastPartitioning extends Partitioning with Product with Serializable

  3. object SinglePartition extends Partitioning with Product with Serializable

  4. object UnspecifiedDistribution extends Distribution with Product with Serializable

    Represents a distribution where no promises are made about co-location of data.

Ungrouped