类 EpochAwareCoProcessFunction<I1,​I2,​O>

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

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

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

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

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

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

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

      • EpochAwareCoProcessFunction

        public EpochAwareCoProcessFunction()
    • 方法详细资料

      • processElement1

        public final void processElement1​(I1 input,
                                          org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context context,
                                          org.apache.flink.util.Collector<O> collector)
                                   throws Exception
        指定者:
        processElement1 在类中 org.apache.flink.streaming.api.functions.co.CoProcessFunction<I1,​I2,​O>
        抛出:
        Exception
      • processElement2

        public final void processElement2​(I2 input,
                                          org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context context,
                                          org.apache.flink.util.Collector<O> collector)
                                   throws Exception
        指定者:
        processElement2 在类中 org.apache.flink.streaming.api.functions.co.CoProcessFunction<I1,​I2,​O>
        抛出:
        Exception
      • processElement1

        public abstract void processElement1​(I1 input,
                                             int epoch,
                                             org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context context,
                                             org.apache.flink.util.Collector<O> collector)
                                      throws Exception
        抛出:
        Exception
      • processElement2

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