类 TailOperator
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void>
-
- org.apache.flink.iteration.operator.TailOperator
-
- 所有已实现的接口:
Serializable,org.apache.flink.api.common.state.CheckpointListener,org.apache.flink.streaming.api.operators.Input<IterationRecord<?>>,org.apache.flink.streaming.api.operators.KeyContext,org.apache.flink.streaming.api.operators.OneInputStreamOperator<IterationRecord<?>,Void>,org.apache.flink.streaming.api.operators.SetupableStreamOperator<Void>,org.apache.flink.streaming.api.operators.StreamOperator<Void>,org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
public class TailOperator extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void> implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IterationRecord<?>,Void>
The tail operators is attached after each feedback operator to increment the round of each record.- 另请参阅:
- 序列化表格
-
-
构造器概要
构造器 构造器 说明 TailOperator(IterationID iterationId, int feedbackIndex)
-
方法概要
所有方法 实例方法 具体方法 修饰符和类型 方法 说明 voidclose()voidnotifyCheckpointAborted(long checkpointId)voidopen()voidprepareSnapshotPreBarrier(long checkpointId)voidprocessElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<?>> streamRecord)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<Void>> output)-
从类继承的方法 org.apache.flink.streaming.api.operators.AbstractStreamOperator
finish, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointComplete, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, snapshotState, snapshotState
-
从类继承的方法 java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
-
-
-
构造器详细资料
-
TailOperator
public TailOperator(IterationID iterationId, int feedbackIndex)
-
-
方法详细资料
-
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<Void>> output)
-
open
public void open() throws Exception
-
processElement
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<?>> streamRecord)
- 指定者:
processElement在接口中org.apache.flink.streaming.api.operators.Input<IterationRecord<?>>
-
prepareSnapshotPreBarrier
public void prepareSnapshotPreBarrier(long checkpointId) throws Exception
-
notifyCheckpointAborted
public void notifyCheckpointAborted(long checkpointId) throws Exception
-
-