org.apache.spark.sql.execution

aggregate

package aggregate

Visibility
  1. Public
  2. All

Type Members

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

    The base class of SortBasedAggregationIterator and TungstenAggregationIterator.

  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 SortBasedAggregateExec(requiredChildDistributionExpressions: Option[Seq[Expression]], groupingExpressions: Seq[NamedExpression], aggregateExpressions: Seq[AggregateExpression], aggregateAttributes: Seq[Attribute], initialInputBufferOffset: Int, resultExpressions: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryExecNode 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], aggregateExpressions: Seq[AggregateExpression], aggregateAttributes: Seq[Attribute], initialInputBufferOffset: Int, resultExpressions: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

  6. class TungstenAggregationIterator extends AggregationIterator with Logging

    An iterator used to evaluate aggregate functions.

  7. case class TypedAggregateExpression(aggregator: expressions.Aggregator[Any, Any, Any], inputDeserializer: Option[Expression], bufferSerializer: Seq[NamedExpression], bufferDeserializer: Expression, outputSerializer: Seq[Expression], outputExternalType: DataType, dataType: DataType) extends DeclarativeAggregate with NonSQLExpression with Product with Serializable

    A helper class to hook Aggregator into the aggregation system.

  8. class TypedAverage[IN] extends expressions.Aggregator[IN, (Double, Long), Double]

  9. class TypedCount[IN] extends expressions.Aggregator[IN, Long, Long]

  10. class TypedSumDouble[IN] extends expressions.Aggregator[IN, Double, Double]

  11. class TypedSumLong[IN] extends expressions.Aggregator[IN, Long, Long]

  12. class VectorizedHashMapGenerator extends AnyRef

    This is a helper class to generate an append-only vectorized hash map that can act as a 'cache' for extremely fast key-value lookups while evaluating aggregates (and fall back to the BytesToBytesMap if a given key isn't found).

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