类 InputOperator<T>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<IterationRecord<T>>
-
- org.apache.flink.iteration.operator.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 intoIterationRecord.- 另请参阅:
- 序列化表格
-
-
构造器概要
构造器 构造器 说明 InputOperator()
-
方法概要
所有方法 实例方法 具体方法 修饰符和类型 方法 说明 voidopen()voidprocessElement(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
-
从类继承的方法 java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
从接口继承的方法 org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
-
-
-
方法详细资料
-
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
-
-