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.

  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[AggregateExpression], nonCompleteAggregateAttributes: Seq[Attribute], completeAggregateExpressions: Seq[AggregateExpression], 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 AggregateFunction.

  5. case class TungstenAggregate(requiredChildDistributionExpressions: Option[Seq[Expression]], groupingExpressions: Seq[NamedExpression], nonCompleteAggregateExpressions: Seq[AggregateExpression], nonCompleteAggregateAttributes: Seq[Attribute], completeAggregateExpressions: Seq[AggregateExpression], completeAggregateAttributes: Seq[Attribute], 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.

  7. case class TypedAggregateExpression(aggregator: expressions.Aggregator[Any, Any, Any], aEncoder: Option[ExpressionEncoder[Any]], unresolvedBEncoder: ExpressionEncoder[Any], cEncoder: ExpressionEncoder[Any], children: Seq[Attribute], mutableAggBufferOffset: Int, inputAggBufferOffset: Int) extends ImperativeAggregate with Logging with Product with Serializable

    This class is a rough sketch of how to hook Aggregator into the Aggregation system.

Value Members

  1. object TungstenAggregate extends Serializable

  2. object TypedAggregateExpression extends Serializable

  3. object Utils

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

Ungrouped