org.apache.spark.sql.catalyst.expressions

aggregate

package aggregate

Visibility
  1. Public
  2. All

Type Members

  1. sealed abstract class AggregateFunction extends Expression with ImplicitCastInputTypes

    AggregateFunction2 is the superclass of two aggregation function interfaces:

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

  3. abstract class CentralMomentAgg extends ImperativeAggregate with Serializable

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

  4. case class Corr(left: Expression, right: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends ImperativeAggregate with Product with Serializable

    Compute Pearson correlation between two expressions.

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

  6. abstract class DeclarativeAggregate extends AggregateFunction with Serializable with Unevaluable

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

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

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

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

  9. abstract class ImperativeAggregate extends AggregateFunction

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

  10. case class Kurtosis(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends CentralMomentAgg with Product with Serializable

  11. case class Last(child: Expression, ignoreNullsExpr: Expression) extends DeclarativeAggregate with Product with Serializable

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

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

  13. case class Min(child: Expression) extends DeclarativeAggregate with Product with Serializable

  14. case class Skewness(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends CentralMomentAgg with Product with Serializable

  15. case class StddevPop(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends CentralMomentAgg with Product with Serializable

  16. case class StddevSamp(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends CentralMomentAgg with Product with Serializable

  17. case class Sum(child: Expression) extends DeclarativeAggregate with Product with Serializable

  18. case class VariancePop(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends CentralMomentAgg with Product with Serializable

  19. case class VarianceSamp(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0) extends CentralMomentAgg with Product with Serializable

Value Members

  1. object Count extends Serializable

  2. object HyperLogLogPlusPlus extends Serializable

    Constants used in the implementation of the HyperLogLogPlusPlus aggregate function.

Ungrouped