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.

  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.

  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.

  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.

  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.

  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