org.apache.spark.sql.execution

aggregate

package aggregate

Visibility
  1. Public
  2. All

Type Members

  1. abstract class AggregationIterator extends Iterator[InternalRow] with Logging

    The base class of SortBasedAggregationIterator and UnsafeHybridAggregationIterator.

  2. sealed trait BufferSetterGetterUtils extends AnyRef

    A helper trait used to create specialized setter and getter for types supported by org.apache.spark.sql.execution.UnsafeFixedWidthAggregationMap's buffer.

  3. case class SortBasedAggregate(requiredChildDistributionExpressions: Option[Seq[Expression]], groupingExpressions: Seq[NamedExpression], nonCompleteAggregateExpressions: Seq[AggregateExpression2], nonCompleteAggregateAttributes: Seq[Attribute], completeAggregateExpressions: Seq[AggregateExpression2], completeAggregateAttributes: Seq[Attribute], initialInputBufferOffset: Int, resultExpressions: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable

  4. class SortBasedAggregationIterator extends AggregationIterator

    An iterator used to evaluate AggregateFunction2.

  5. case class TungstenAggregate(requiredChildDistributionExpressions: Option[Seq[Expression]], groupingExpressions: Seq[NamedExpression], nonCompleteAggregateExpressions: Seq[AggregateExpression2], completeAggregateExpressions: Seq[AggregateExpression2], initialInputBufferOffset: Int, resultExpressions: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryNode with Product with Serializable

  6. class TungstenAggregationIterator extends Iterator[UnsafeRow] with Logging

    An iterator used to evaluate aggregate functions.

Value Members

  1. object AggregationIterator

  2. object SortBasedAggregationIterator

  3. object Utils

    Utility functions used by the query planner to convert our plan to new aggregation code path.

Ungrouped