org.apache.spark.sql

expressions

package expressions

Visibility
  1. Public
  2. All

Type Members

  1. abstract class Aggregator[-IN, BUF, OUT] extends Serializable

    :: Experimental :: A base class for user-defined aggregations, which can be used in Dataset operations to take all of the elements of a group and reduce them to a single value.

  2. abstract class MutableAggregationBuffer extends Row

    A Row representing a mutable aggregation buffer.

  3. abstract class UserDefinedAggregateFunction extends Serializable

    The base class for implementing user-defined aggregate functions (UDAF).

  4. case class UserDefinedFunction(f: AnyRef, dataType: DataType, inputTypes: Option[Seq[DataType]]) extends Product with Serializable

    A user-defined function.

  5. class Window extends AnyRef

    Utility functions for defining window in DataFrames.

  6. class WindowSpec extends AnyRef

    A window specification that defines the partitioning, ordering, and frame boundaries.

Value Members

  1. object Window

    Utility functions for defining window in DataFrames.

  2. package javalang

  3. package scalalang

Ungrouped