类 ReplayOperator<T>

    • 字段概要

      • 从类继承的字段 org.apache.flink.streaming.api.operators.AbstractStreamOperator

        chainingStrategy, config, latencyStats, LOG, metrics, output, processingTimeService
    • 方法概要

      所有方法 实例方法 具体方法 
      修饰符和类型 方法 说明
      void endInput​(int i)  
      void initializeState​(org.apache.flink.runtime.state.StateInitializationContext context)  
      void onEpochWatermarkIncrement​(int epochWatermark)
      Notifies a new round is aligned to a new epoch watermark.
      void processElement1​(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>> element)  
      void processElement2​(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<Void>> element)  
      void setup​(org.apache.flink.streaming.runtime.tasks.StreamTask<?,​?> containingTask, org.apache.flink.streaming.api.graph.StreamConfig config, org.apache.flink.streaming.api.operators.Output<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>>> output)  
      void snapshotState​(org.apache.flink.runtime.state.StateSnapshotContext context)  
      • 从类继承的方法 org.apache.flink.streaming.api.operators.AbstractStreamOperator

        close, finish, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, open, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, snapshotState
      • 从接口继承的方法 org.apache.flink.api.common.state.CheckpointListener

        notifyCheckpointAborted, notifyCheckpointComplete
      • 从接口继承的方法 org.apache.flink.streaming.api.operators.KeyContext

        getCurrentKey, setCurrentKey
      • 从接口继承的方法 org.apache.flink.streaming.api.operators.StreamOperator

        close, finish, getMetricGroup, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
      • 从接口继承的方法 org.apache.flink.streaming.api.operators.TwoInputStreamOperator

        processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2
    • 构造器详细资料

      • ReplayOperator

        public ReplayOperator()
    • 方法详细资料

      • setup

        public void setup​(org.apache.flink.streaming.runtime.tasks.StreamTask<?,​?> containingTask,
                          org.apache.flink.streaming.api.graph.StreamConfig config,
                          org.apache.flink.streaming.api.operators.Output<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>>> output)
        指定者:
        setup 在接口中 org.apache.flink.streaming.api.operators.SetupableStreamOperator<T>
        覆盖:
        setup 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>
      • initializeState

        public void initializeState​(org.apache.flink.runtime.state.StateInitializationContext context)
                             throws Exception
        指定者:
        initializeState 在接口中 org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
        覆盖:
        initializeState 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>
        抛出:
        Exception
      • snapshotState

        public void snapshotState​(org.apache.flink.runtime.state.StateSnapshotContext context)
                           throws Exception
        指定者:
        snapshotState 在接口中 org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
        覆盖:
        snapshotState 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>
        抛出:
        Exception
      • endInput

        public void endInput​(int i)
                      throws Exception
        指定者:
        endInput 在接口中 org.apache.flink.streaming.api.operators.BoundedMultiInput
        抛出:
        Exception