org.apache.spark.sql.execution

aggregate

package aggregate

Visibility
  1. Public
  2. All

Type Members

  1. class AggregationBufferEntry extends AnyRef

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

    The base class of SortBasedAggregationIterator and TungstenAggregationIterator.

  3. 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.

  4. case class ComplexTypedAggregateExpression(aggregator: expressions.Aggregator[Any, Any, Any], inputDeserializer: Option[Expression], inputClass: Option[Class[_]], inputSchema: Option[StructType], bufferSerializer: Seq[NamedExpression], bufferDeserializer: Expression, outputSerializer: Seq[Expression], dataType: DataType, nullable: Boolean, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends TypedImperativeAggregate[Any] with TypedAggregateExpression with NonSQLExpression with Product with Serializable

  5. case class HashAggregateExec(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

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

  6. abstract class HashMapGenerator extends AnyRef

    This is a helper class to generate an append-only row-based 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).

  7. class ObjectAggregationIterator extends AggregationIterator with Logging

  8. class ObjectAggregationMap extends AnyRef

    An aggregation map that supports using safe SpecificInternalRows aggregation buffers, so that we can support storing arbitrary Java objects as aggregate function states in the aggregation buffers.

  9. case class ObjectHashAggregateExec(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

    A hash-based aggregate operator that supports TypedImperativeAggregate functions that may use arbitrary JVM objects as aggregation states.

  10. class RowBasedHashMapGenerator extends HashMapGenerator

    This is a helper class to generate an append-only row-based 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).

  11. case class ScalaUDAF(children: Seq[Expression], udaf: UserDefinedAggregateFunction, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends ImperativeAggregate with NonSQLExpression with Logging with ImplicitCastInputTypes with Product with Serializable

    The internal wrapper used to hook a UserDefinedAggregateFunction udaf in the internal aggregation code path.

  12. case class SimpleTypedAggregateExpression(aggregator: expressions.Aggregator[Any, Any, Any], inputDeserializer: Option[Expression], inputClass: Option[Class[_]], inputSchema: Option[StructType], bufferSerializer: Seq[NamedExpression], bufferDeserializer: Expression, outputSerializer: Seq[Expression], outputExternalType: DataType, dataType: DataType, nullable: Boolean) extends DeclarativeAggregate with TypedAggregateExpression with NonSQLExpression with Product with Serializable

  13. case class SortAggregateExec(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

    Sort-based aggregate operator.

  14. class SortBasedAggregationIterator extends AggregationIterator

    An iterator used to evaluate AggregateFunction.

  15. class SortBasedAggregator extends AnyRef

    A class used to handle sort-based aggregation, used together with ObjectHashAggregateExec.

  16. class TungstenAggregationIterator extends AggregationIterator with Logging

    An iterator used to evaluate aggregate functions.

  17. trait TypedAggregateExpression extends AggregateFunction

    A helper class to hook Aggregator into the aggregation system.

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

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

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

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

  22. class VectorizedHashMapGenerator extends HashMapGenerator

    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 AggUtils

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

  2. object HashAggregateExec extends Serializable

  3. object ObjectHashAggregateExec extends Serializable

  4. object TypedAggregateExpression

Ungrouped