Class ReduceApplyProcessWindowFunction<K,​W extends Window,​T,​R>

  • All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.RichFunction

    @Internal
    public class ReduceApplyProcessWindowFunction<K,​W extends Window,​T,​R>
    extends ProcessWindowFunction<T,​R,​K,​W>
    Internal ProcessWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
    See Also:
    Serialized Form
    • Constructor Detail

      • ReduceApplyProcessWindowFunction

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

      • process

        public void process​(K k,
                            ProcessWindowFunction.Context context,
                            Iterable<T> input,
                            org.apache.flink.util.Collector<R> out)
                     throws Exception
        Description copied from class: ProcessWindowFunction
        Evaluates the window and outputs none or several elements.
        Specified by:
        process in class ProcessWindowFunction<T,​R,​K,​W extends Window>
        Parameters:
        k - The key for which this window is evaluated.
        context - The context in which the window 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.
      • open

        public void open​(org.apache.flink.api.common.functions.OpenContext openContext)
                  throws Exception
        Specified by:
        open in interface org.apache.flink.api.common.functions.RichFunction
        Overrides:
        open in class org.apache.flink.api.common.functions.AbstractRichFunction
        Throws:
        Exception
      • close

        public void close()
                   throws Exception
        Specified by:
        close in interface org.apache.flink.api.common.functions.RichFunction
        Overrides:
        close in class org.apache.flink.api.common.functions.AbstractRichFunction
        Throws:
        Exception
      • setRuntimeContext

        public void setRuntimeContext​(org.apache.flink.api.common.functions.RuntimeContext t)
        Specified by:
        setRuntimeContext in interface org.apache.flink.api.common.functions.RichFunction
        Overrides:
        setRuntimeContext in class org.apache.flink.api.common.functions.AbstractRichFunction