类 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.
    另请参阅:
    序列化表格
    • 字段概要

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

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

      所有方法 实例方法 具体方法 
      修饰符和类型 方法 说明
      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)  
      • 从类继承的方法 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
      • 从接口继承的方法 org.apache.flink.api.common.state.CheckpointListener

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

        processLatencyMarker, processWatermark, processWatermarkStatus
      • 从接口继承的方法 org.apache.flink.streaming.api.operators.KeyContext

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

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

        finish, getMetricGroup, getOperatorID, initializeState, setKeyContextElement1, setKeyContextElement2, snapshotState
    • 构造器详细资料

      • 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)
        指定者:
        setup 在接口中 org.apache.flink.streaming.api.operators.SetupableStreamOperator<Void>
        覆盖:
        setup 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void>
      • open

        public void open()
                  throws Exception
        指定者:
        open 在接口中 org.apache.flink.streaming.api.operators.StreamOperator<Void>
        覆盖:
        open 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void>
        抛出:
        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
        指定者:
        prepareSnapshotPreBarrier 在接口中 org.apache.flink.streaming.api.operators.StreamOperator<Void>
        覆盖:
        prepareSnapshotPreBarrier 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void>
        抛出:
        Exception
      • notifyCheckpointAborted

        public void notifyCheckpointAborted​(long checkpointId)
                                     throws Exception
        指定者:
        notifyCheckpointAborted 在接口中 org.apache.flink.api.common.state.CheckpointListener
        覆盖:
        notifyCheckpointAborted 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void>
        抛出:
        Exception
      • close

        public void close()
                   throws Exception
        指定者:
        close 在接口中 org.apache.flink.streaming.api.operators.StreamOperator<Void>
        覆盖:
        close 在类中 org.apache.flink.streaming.api.operators.AbstractStreamOperator<Void>
        抛出:
        Exception