Interface WindowFunction<IN,​OUT,​KEY,​W extends Window>

  • Type Parameters:
    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.
    All Superinterfaces:
    org.apache.flink.api.common.functions.Function, Serializable
    All Known Implementing Classes:
    AggregateApplyWindowFunction, PassThroughWindowFunction, ReduceApplyWindowFunction

    @Public
    public interface WindowFunction<IN,​OUT,​KEY,​W extends Window>
    extends org.apache.flink.api.common.functions.Function, Serializable
    Base interface for functions that are evaluated over keyed (grouped) windows.
    • Method Detail

      • apply

        void apply​(KEY key,
                   W window,
                   Iterable<IN> input,
                   org.apache.flink.util.Collector<OUT> out)
            throws Exception
        Evaluates the window and outputs none or several elements.
        Parameters:
        key - The key for which this window is evaluated.
        window - The window that is being evaluated.
        input - The elements in the window being evaluated.
        out - A collector for emitting elements.
        Throws:
        Exception - The function may throw exceptions to fail the program and trigger recovery.