Package

org.apache.spark.sql.execution

aggregate

Permalink

package aggregate

Visibility
  1. Public
  2. All

Type Members

  1. case class CollectAggregateExec(basePlan: SnappyHashAggregateExec, child: SparkPlan) extends SparkPlan with UnaryExecNode with Product with Serializable

    Permalink

    Special plan to collect top-level aggregation on driver itself and avoid an exchange for simple aggregates.

  2. trait GroupAggregate extends AnyRef

    Permalink
  3. case class SnappyHashAggregateExec(requiredChildDistributionExpressions: Option[Seq[Expression]], groupingExpressions: Seq[NamedExpression], aggregateExpressions: Seq[AggregateExpression], aggregateAttributes: Seq[Attribute], __resultExpressions: Seq[NamedExpression], child: SparkPlan, hasDistinct: Boolean) extends SparkPlan with UnaryExecNode with BatchConsumer with NonRecursivePlans with Product with Serializable

    Permalink

    Hash-based aggregate operator that can also fallback to sorting when data exceeds memory size.

    Hash-based aggregate operator that can also fallback to sorting when data exceeds memory size.

    Parts of this class have been adapted from Spark's HashAggregateExec. That class is not extended because it forces that the limitations HashAggregateExec.supportsAggregate of that implementation in the constructor itself while this implementation has no such restriction.

Ungrouped