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
| 构造器和说明 | 
|---|
ReplayOperator()  | 
| 限定符和类型 | 方法和说明 | 
|---|---|
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)  | 
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, snapshotStateclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitprocessLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2close, finish, getMetricGroup, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotStatepublic 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<IterationRecord<T>>setup 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>public void initializeState(org.apache.flink.runtime.state.StateInitializationContext context)
                     throws Exception
initializeState 在接口中 org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperatorinitializeState 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>Exceptionpublic void snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context)
                   throws Exception
snapshotState 在接口中 org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperatorsnapshotState 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>Exceptionpublic 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>>Exceptionpublic 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>>Exceptionpublic void endInput(int i)
              throws Exception
endInput 在接口中 org.apache.flink.streaming.api.operators.BoundedMultiInputExceptionpublic void onEpochWatermarkIncrement(int epochWatermark)
                               throws IOException
OperatorEpochWatermarkTrackerListeneronEpochWatermarkIncrement 在接口中 OperatorEpochWatermarkTrackerListenerepochWatermark - The new epoch watermark.IOExceptionCopyright © 2019–2022 The Apache Software Foundation. All rights reserved.