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

    • Constructor Detail

      • ReduceApplyProcessAllWindowFunction

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

      • process

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