Class AggregateApplyWindowFunction<K,​W extends Window,​T,​ACC,​V,​R>

  • Type Parameters:
    K - The key type
    W - The window type
    T - The type of the input to the AggregateFunction
    ACC - The type of the AggregateFunction's accumulator
    V - The type of the AggregateFunction's result, and the input to the WindowFunction
    R - The result type of the WindowFunction
    All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.RichFunction, WindowFunction<T,​R,​K,​W>

    @Internal
    public class AggregateApplyWindowFunction<K,​W extends Window,​T,​ACC,​V,​R>
    extends org.apache.flink.api.common.functions.WrappingFunction<WindowFunction<V,​R,​K,​W>>
    implements WindowFunction<T,​R,​K,​W>
    A WindowFunction that composes an AggregateFunction and WindowFunction. Upon invocation, this first applies AggregateFunction to the input, and then finally the WindowFunction to the single result element.
    See Also:
    Serialized Form
    • Field Summary

      • Fields inherited from class org.apache.flink.api.common.functions.WrappingFunction

        wrappedFunction
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      void apply​(K key, W window, Iterable<T> values, org.apache.flink.util.Collector<R> out)
      Evaluates the window and outputs none or several elements.
      • Methods inherited from class org.apache.flink.api.common.functions.WrappingFunction

        close, getWrappedFunction, open, setRuntimeContext
      • Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction

        getIterationRuntimeContext, getRuntimeContext
    • Constructor Detail

      • AggregateApplyWindowFunction

        public AggregateApplyWindowFunction​(org.apache.flink.api.common.functions.AggregateFunction<T,​ACC,​V> aggFunction,
                                            WindowFunction<V,​R,​K,​W> windowFunction)
    • Method Detail

      • apply

        public void apply​(K key,
                          W window,
                          Iterable<T> values,
                          org.apache.flink.util.Collector<R> out)
                   throws Exception
        Description copied from interface: WindowFunction
        Evaluates the window and outputs none or several elements.
        Specified by:
        apply in interface WindowFunction<K,​W extends Window,​T,​ACC>
        Parameters:
        key - The key for which this window is evaluated.
        window - The window that is being evaluated.
        values - 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.