类 EpochAwareAllRoundProcessFunction<I,​O>

  • 所有已实现的接口:
    Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.RichFunction, EpochAware

    @Internal
    public abstract class EpochAwareAllRoundProcessFunction<I,​O>
    extends org.apache.flink.streaming.api.functions.ProcessFunction<I,​O>
    implements EpochAware
    A specialized ProcessFunction that also provide the attach epoch with each record. It is executed as all-round inside the iteration.
    另请参阅:
    序列化表格
    • 嵌套类概要

      • 从类继承的嵌套类/接口 org.apache.flink.streaming.api.functions.ProcessFunction

        org.apache.flink.streaming.api.functions.ProcessFunction.Context, org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
    • 方法概要

      所有方法 实例方法 抽象方法 具体方法 
      修饰符和类型 方法 说明
      abstract void processElement​(I input, int epoch, org.apache.flink.streaming.api.functions.ProcessFunction.Context context, org.apache.flink.util.Collector<O> collector)  
      void processElement​(I input, org.apache.flink.streaming.api.functions.ProcessFunction.Context context, org.apache.flink.util.Collector<O> collector)  
      void setEpochSupplier​(java.util.function.Supplier<Integer> epochSupplier)  
      • 从类继承的方法 org.apache.flink.streaming.api.functions.ProcessFunction

        onTimer
      • 从类继承的方法 org.apache.flink.api.common.functions.AbstractRichFunction

        close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
    • 构造器详细资料

      • EpochAwareAllRoundProcessFunction

        public EpochAwareAllRoundProcessFunction()
    • 方法详细资料

      • processElement

        public final void processElement​(I input,
                                         org.apache.flink.streaming.api.functions.ProcessFunction.Context context,
                                         org.apache.flink.util.Collector<O> collector)
                                  throws Exception
        指定者:
        processElement 在类中 org.apache.flink.streaming.api.functions.ProcessFunction<I,​O>
        抛出:
        Exception
      • processElement

        public abstract void processElement​(I input,
                                            int epoch,
                                            org.apache.flink.streaming.api.functions.ProcessFunction.Context context,
                                            org.apache.flink.util.Collector<O> collector)
                                     throws Exception
        抛出:
        Exception