Package

org.apache.spark.sql

expressions

Permalink

package expressions

Visibility
  1. Public
  2. All

Type Members

  1. abstract class MutableAggregationBuffer extends Row

    Permalink

    :: Experimental :: A Row representing an mutable aggregation buffer.

    :: Experimental :: A Row representing an mutable aggregation buffer.

    This is not meant to be extended outside of Spark.

    Annotations
    @Experimental()
  2. abstract class UserDefinedAggregateFunction extends Serializable

    Permalink

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

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

    Annotations
    @Experimental()
  3. class Window extends AnyRef

    Permalink

    :: Experimental :: Utility functions for defining window in DataFrames.

    :: Experimental :: Utility functions for defining window in DataFrames.

    // PARTITION BY country ORDER BY date ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW
    Window.partitionBy("country").orderBy("date").rowsBetween(Long.MinValue, 0)
    
    // PARTITION BY country ORDER BY date ROWS BETWEEN 3 PRECEDING AND 3 FOLLOWING
    Window.partitionBy("country").orderBy("date").rowsBetween(-3, 3)
    Annotations
    @Experimental()
    Since

    1.4.0

  4. class WindowSpec extends AnyRef

    Permalink

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

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

    Use the static methods in Window to create a WindowSpec.

    Annotations
    @Experimental()
    Since

    1.4.0

Value Members

  1. object Window

    Permalink

    :: Experimental :: Utility functions for defining window in DataFrames.

    :: Experimental :: Utility functions for defining window in DataFrames.

    // PARTITION BY country ORDER BY date ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW
    Window.partitionBy("country").orderBy("date").rowsBetween(Long.MinValue, 0)
    
    // PARTITION BY country ORDER BY date ROWS BETWEEN 3 PRECEDING AND 3 FOLLOWING
    Window.partitionBy("country").orderBy("date").rowsBetween(-3, 3)
    Annotations
    @Experimental()
    Since

    1.4.0

Ungrouped