Class ReduceApplyAllWindowFunction<W extends Window,​T,​R>

    • 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​(W window, Iterable<T> input, 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

      • ReduceApplyAllWindowFunction

        public ReduceApplyAllWindowFunction​(org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction,
                                            AllWindowFunction<T,​R,​W> windowFunction)
    • Method Detail

      • apply

        public void apply​(W window,
                          Iterable<T> input,
                          org.apache.flink.util.Collector<R> out)
                   throws Exception
        Description copied from interface: AllWindowFunction
        Evaluates the window and outputs none or several elements.
        Specified by:
        apply in interface AllWindowFunction<W extends Window,​T,​R>
        Parameters:
        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.