类 ReplayOperator<T>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>
-
- org.apache.flink.iteration.operator.ReplayOperator<T>
-
- 所有已实现的接口:
Serializable,org.apache.flink.api.common.state.CheckpointListener,OperatorEpochWatermarkTrackerListener,org.apache.flink.streaming.api.operators.BoundedMultiInput,org.apache.flink.streaming.api.operators.KeyContext,org.apache.flink.streaming.api.operators.SetupableStreamOperator<IterationRecord<T>>,org.apache.flink.streaming.api.operators.StreamOperator<IterationRecord<T>>,org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator,org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IterationRecord<T>,IterationRecord<Void>,IterationRecord<T>>
public class ReplayOperator<T> extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>> implements org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IterationRecord<T>,IterationRecord<Void>,IterationRecord<T>>, OperatorEpochWatermarkTrackerListener, org.apache.flink.streaming.api.operators.BoundedMultiInput
Replays the data received in the round 0 in the following round.- 另请参阅:
- 序列化表格
-
-
构造器概要
构造器 构造器 说明 ReplayOperator()
-
方法概要
所有方法 实例方法 具体方法 修饰符和类型 方法 说明 voidendInput(int i)voidinitializeState(org.apache.flink.runtime.state.StateInitializationContext context)voidonEpochWatermarkIncrement(int epochWatermark)Notifies a new round is aligned to a new epoch watermark.voidprocessElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>> element)voidprocessElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<Void>> element)voidsetup(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)voidsnapshotState(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
-
从类继承的方法 java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
从接口继承的方法 org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
-
-
-
方法详细资料
-
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
-
processElement1
public void processElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>> element) throws Exception
- 指定者:
processElement1在接口中org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IterationRecord<T>,IterationRecord<Void>,IterationRecord<T>>- 抛出:
Exception
-
processElement2
public void processElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<Void>> element) throws Exception
- 指定者:
processElement2在接口中org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IterationRecord<T>,IterationRecord<Void>,IterationRecord<T>>- 抛出:
Exception
-
endInput
public void endInput(int i) throws Exception- 指定者:
endInput在接口中org.apache.flink.streaming.api.operators.BoundedMultiInput- 抛出:
Exception
-
onEpochWatermarkIncrement
public void onEpochWatermarkIncrement(int epochWatermark) throws IOException从接口复制的说明:OperatorEpochWatermarkTrackerListenerNotifies a new round is aligned to a new epoch watermark.- 指定者:
onEpochWatermarkIncrement在接口中OperatorEpochWatermarkTrackerListener- 参数:
epochWatermark- The new epoch watermark.- 抛出:
IOException
-
-