Package

org.apache.spark.sql.datafu

types

Permalink

package types

Visibility
  1. Public
  2. All

Type Members

  1. case class CollectLimitedList(child: Expression, mutableAggBufferOffset: Int = 0, inputAggBufferOffset: Int = 0, howMuchToTake: Int = 10) extends LimitedCollect[ArrayBuffer[Any]] with Product with Serializable

    Permalink

    *

    *

    This code is copied from CollectList, just modified the method it extends Copied originally from https://github.com/apache/spark/blob/branch-2.3/sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/aggregate/collect.scala

  2. abstract class ExtramumValueByKey extends DeclarativeAggregate with ExpectsInputTypes

    Permalink
  3. abstract class LimitedCollect[T <: Growable[Any] with Iterable[Any]] extends Collect[T] with Serializable

    Permalink

    *

    *

    This modifies the collect list / set to keep only howMuchToTake random elements

  4. case class MaxValueByKey(child1: Expression, child2: Expression) extends ExtramumValueByKey with Product with Serializable

    Permalink
  5. case class MinValueByKey(child1: Expression, child2: Expression) extends ExtramumValueByKey with Product with Serializable

    Permalink

Value Members

  1. object SparkOverwriteUDAFs

    Permalink

Ungrouped