public class TailOperator extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void> implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IterationRecord<?>,Void>
| 构造器和说明 | 
|---|
TailOperator(IterationID iterationId,
            int feedbackIndex)  | 
| 限定符和类型 | 方法和说明 | 
|---|---|
void | 
close()  | 
void | 
notifyCheckpointAborted(long checkpointId)  | 
void | 
open()  | 
void | 
prepareSnapshotPreBarrier(long checkpointId)  | 
void | 
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<?>> streamRecord)  | 
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)  | 
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, snapshotStateclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitpublic TailOperator(IterationID iterationId, int feedbackIndex)
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)
public void open()
          throws Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<?>> streamRecord)
processElement 在接口中 org.apache.flink.streaming.api.operators.Input<IterationRecord<?>>public void prepareSnapshotPreBarrier(long checkpointId)
                               throws Exception
public void notifyCheckpointAborted(long checkpointId)
                             throws Exception
Copyright © 2019–2022 The Apache Software Foundation. All rights reserved.