Package

org.apache.flink.streaming.api.scala

function

Permalink

package function

Visibility
  1. Public
  2. All

Type Members

  1. trait AllWindowFunction[IN, OUT, W <: Window] extends Function with Serializable

    Permalink

    Base interface for functions that are evaluated over non-grouped windows, i.e., windows over all stream partitions.

    Base interface for functions that are evaluated over non-grouped windows, i.e., windows over all stream partitions.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    Annotations
    @Public()
  2. abstract class ProcessAllWindowFunction[IN, OUT, W <: Window] extends AbstractRichFunction

    Permalink

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    W

    The type of the window.

    Annotations
    @PublicEvolving()
  3. abstract class ProcessWindowFunction[IN, OUT, KEY, W <: Window] extends AbstractRichFunction

    Permalink

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    KEY

    The type of the key.

    W

    The type of the window.

    Annotations
    @PublicEvolving()
  4. abstract class RichAllWindowFunction[IN, OUT, W <: Window] extends AbstractRichFunction with AllWindowFunction[IN, OUT, W]

    Permalink

    Rich variant of the org.apache.flink.streaming.api.scala.function.AllWindowFunction.

    Rich variant of the org.apache.flink.streaming.api.scala.function.AllWindowFunction.

    As a org.apache.flink.api.common.functions.RichFunction, it gives access to the org.apache.flink.api.common.functions.RuntimeContext and provides setup and tear-down methods.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    W

    The type of Window that this window function can be applied on.

  5. abstract class RichWindowFunction[IN, OUT, KEY, W <: Window] extends AbstractRichFunction with WindowFunction[IN, OUT, KEY, W]

    Permalink

    Rich variant of the org.apache.flink.streaming.api.scala.function.WindowFunction.

    Rich variant of the org.apache.flink.streaming.api.scala.function.WindowFunction.

    As a org.apache.flink.api.common.functions.RichFunction, it gives access to the org.apache.flink.api.common.functions.RuntimeContext and provides setup and tear-down methods.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    KEY

    The type of the key.

    W

    The type of Window that this window function can be applied on.

  6. trait StatefulFunction[I, O, S] extends RichFunction

    Permalink

    Trait implementing the functionality necessary to apply stateful functions in RichFunctions without exposing the OperatorStates to the user.

    Trait implementing the functionality necessary to apply stateful functions in RichFunctions without exposing the OperatorStates to the user. The user should call the applyWithState method in his own RichFunction implementation.

    Annotations
    @Public()
  7. trait WindowFunction[IN, OUT, KEY, W <: Window] extends Function with Serializable

    Permalink

    Base interface for functions that are evaluated over keyed (grouped) windows.

    Base interface for functions that are evaluated over keyed (grouped) windows.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    KEY

    The type of the key.

    Annotations
    @Public()
  8. abstract class RichProcessAllWindowFunction[IN, OUT, W <: Window] extends ProcessAllWindowFunction[IN, OUT, W]

    Permalink

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    W

    The type of the window.

    Annotations
    @Public() @deprecated
    Deprecated

    use ProcessAllWindowFunction instead

  9. abstract class RichProcessWindowFunction[IN, OUT, KEY, W <: Window] extends ProcessWindowFunction[IN, OUT, KEY, W]

    Permalink

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

    IN

    The type of the input value.

    OUT

    The type of the output value.

    KEY

    The type of the key.

    W

    The type of the window.

    Annotations
    @Public() @deprecated
    Deprecated

    use ProcessWindowFunction instead

Value Members

  1. package util

    Permalink

Ungrouped