类 InputOperator<T>

  • 所有已实现的接口:
    Serializable, org.apache.flink.api.common.state.CheckpointListener, org.apache.flink.streaming.api.operators.Input<T>, org.apache.flink.streaming.api.operators.KeyContext, org.apache.flink.streaming.api.operators.OneInputStreamOperator<T,​IterationRecord<T>>, 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

    public class InputOperator<T>
    extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>
    implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<T,​IterationRecord<T>>
    Input operator that wraps the user record into IterationRecord.
    另请参阅:
    序列化表格
    • 字段概要

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

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

      所有方法 实例方法 具体方法 
      修饰符和类型 方法 说明
      void open()  
      void processElement​(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<T> streamRecord)  
      • 从类继承的方法 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, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState, snapshotState
      • 从接口继承的方法 org.apache.flink.api.common.state.CheckpointListener

        notifyCheckpointAborted, 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

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

      • InputOperator

        public InputOperator()
    • 方法详细资料

      • open

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

        public void processElement​(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<T> streamRecord)
                            throws Exception
        指定者:
        processElement 在接口中 org.apache.flink.streaming.api.operators.Input<T>
        抛出:
        Exception