org.apache.spark.sql.catalyst.expressions

aggregate

package aggregate

Visibility
  1. Public
  2. All

Type Members

  1. case class AggregateExpression(aggregateFunction: AggregateFunction, mode: AggregateMode, isDistinct: Boolean, resultId: ExprId) extends Expression with Unevaluable with Product with Serializable

    A container for an AggregateFunction with its AggregateMode and a field (isDistinct) indicating if DISTINCT keyword is specified for this function.

  2. sealed abstract class AggregateFunction extends Expression with ImplicitCastInputTypes

    AggregateFunction is the superclass of two aggregation function interfaces:

  3. sealed trait AggregateMode extends AnyRef

    The mode of an AggregateFunction.

  4. case class Average(child: Expression) extends DeclarativeAggregate with Product with Serializable

    Annotations
    @ExpressionDescription()
  5. abstract class CentralMomentAgg extends DeclarativeAggregate

    A central moment is the expected value of a specified power of the deviation of a random variable from the mean.

  6. abstract class Collect extends ImperativeAggregate

    The Collect aggregate function collects all seen expression values into a list of values.

  7. case class CollectList(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends Collect with Product with Serializable

    Collect a list of elements.

  8. case class CollectSet(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends Collect with Product with Serializable

    Collect a list of unique elements.

  9. case class Corr(x: Expression, y: Expression) extends DeclarativeAggregate with Product with Serializable

    Compute Pearson correlation between two expressions.

  10. case class Count(children: Seq[Expression]) extends DeclarativeAggregate with Product with Serializable

    Annotations
    @ExpressionDescription()
  11. case class CovPopulation(left: Expression, right: Expression) extends Covariance with Product with Serializable

    Annotations
    @ExpressionDescription()
  12. case class CovSample(left: Expression, right: Expression) extends Covariance with Product with Serializable

    Annotations
    @ExpressionDescription()
  13. abstract class Covariance extends DeclarativeAggregate

    Compute the covariance between two expressions.

  14. abstract class DeclarativeAggregate extends AggregateFunction with Serializable with Unevaluable

    API for aggregation functions that are expressed in terms of Catalyst expressions.

  15. case class First(child: Expression, ignoreNullsExpr: Expression) extends DeclarativeAggregate with Product with Serializable

    Returns the first value of child for a group of rows.

  16. case class HyperLogLogPlusPlus(child: Expression, relativeSD: Double = 0.05, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends ImperativeAggregate with Product with Serializable

    HyperLogLog++ (HLL++) is a state of the art cardinality estimation algorithm.

  17. abstract class ImperativeAggregate extends AggregateFunction with CodegenFallback

    API for aggregation functions that are expressed in terms of imperative initialize(), update(), and merge() functions which operate on Row-based aggregation buffers.

  18. case class Kurtosis(child: Expression) extends CentralMomentAgg with Product with Serializable

    Annotations
    @ExpressionDescription()
  19. case class Last(child: Expression, ignoreNullsExpr: Expression) extends DeclarativeAggregate with Product with Serializable

    Returns the last value of child for a group of rows.

  20. case class Max(child: Expression) extends DeclarativeAggregate with Product with Serializable

    Annotations
    @ExpressionDescription()
  21. case class Min(child: Expression) extends DeclarativeAggregate with Product with Serializable

    Annotations
    @ExpressionDescription()
  22. case class PivotFirst(pivotColumn: Expression, valueColumn: Expression, pivotColumnValues: Seq[Any], mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends ImperativeAggregate with Product with Serializable

    PivotFirst is an aggregate function used in the second phase of a two phase pivot to do the required rearrangement of values into pivoted form.

  23. case class Skewness(child: Expression) extends CentralMomentAgg with Product with Serializable

    Annotations
    @ExpressionDescription()
  24. case class StddevPop(child: Expression) extends CentralMomentAgg with Product with Serializable

    Annotations
    @ExpressionDescription()
  25. case class StddevSamp(child: Expression) extends CentralMomentAgg with Product with Serializable

    Annotations
    @ExpressionDescription()
  26. case class Sum(child: Expression) extends DeclarativeAggregate with Product with Serializable

    Annotations
    @ExpressionDescription()
  27. case class VariancePop(child: Expression) extends CentralMomentAgg with Product with Serializable

    Annotations
    @ExpressionDescription()
  28. case class VarianceSamp(child: Expression) extends CentralMomentAgg with Product with Serializable

    Annotations
    @ExpressionDescription()

Value Members

  1. object AggregateExpression extends Serializable

  2. object Complete extends AggregateMode with Product with Serializable

    An AggregateFunction with Complete mode is used to evaluate this function directly from original input rows without any partial aggregation.

  3. object Count extends Serializable

  4. object Final extends AggregateMode with Product with Serializable

    An AggregateFunction with Final mode is used to merge aggregation buffers containing intermediate results for this function and then generate final result.

  5. object HyperLogLogPlusPlus extends Serializable

    Constants used in the implementation of the HyperLogLogPlusPlus aggregate function.

  6. object NoOp extends Expression with Unevaluable with Product with Serializable

    A place holder expressions used in code-gen, it does not change the corresponding value in the row.

  7. object Partial extends AggregateMode with Product with Serializable

    An AggregateFunction with Partial mode is used for partial aggregation.

  8. object PartialMerge extends AggregateMode with Product with Serializable

    An AggregateFunction with PartialMerge mode is used to merge aggregation buffers containing intermediate results for this function.

  9. object PivotFirst extends Serializable

Ungrouped