Class RichAllWindowFunction<IN,​OUT,​W extends org.apache.flink.streaming.api.windowing.windows.Window>

  • All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.RichFunction, org.apache.flink.streaming.api.functions.windowing.AllWindowFunction<IN,​OUT,​W>

    @Public
    public abstract class RichAllWindowFunction<IN,​OUT,​W extends org.apache.flink.streaming.api.windowing.windows.Window>
    extends org.apache.flink.api.common.functions.AbstractRichFunction
    implements org.apache.flink.streaming.api.functions.windowing.AllWindowFunction<IN,​OUT,​W>
    A RichFunction version of AllWindowFunction.
    See Also:
    Serialized Form
    • Method Summary

      • Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction

        close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
      • Methods inherited from interface org.apache.flink.streaming.api.functions.windowing.AllWindowFunction

        apply
    • Constructor Detail

      • RichAllWindowFunction

        public RichAllWindowFunction()