Class BootstrapStreamTaskRunner<IN>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<TaggedOperatorSubtaskState>
-
- org.apache.flink.state.api.output.BootstrapStreamTaskRunner<IN>
-
- Type Parameters:
IN
- Type of the input to the partition
- All Implemented Interfaces:
Serializable
,org.apache.flink.api.common.state.CheckpointListener
,org.apache.flink.streaming.api.operators.BoundedOneInput
,org.apache.flink.streaming.api.operators.Input<IN>
,org.apache.flink.streaming.api.operators.KeyContext
,org.apache.flink.streaming.api.operators.KeyContextHandler
,org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,TaggedOperatorSubtaskState>
,org.apache.flink.streaming.api.operators.StreamOperator<TaggedOperatorSubtaskState>
,org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
,org.apache.flink.streaming.api.operators.YieldingOperator<TaggedOperatorSubtaskState>
@Internal public class BootstrapStreamTaskRunner<IN> extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<TaggedOperatorSubtaskState> implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,TaggedOperatorSubtaskState>, org.apache.flink.streaming.api.operators.BoundedOneInput
The runtime for aBootstrapStreamTask
.The task is executed processing the data in a particular partition instead of the pulling from the network stack. After all data has been processed the runner will output the
OperatorSubtaskState
from the snapshot of the bounded task.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description BootstrapStreamTaskRunner(org.apache.flink.streaming.api.graph.StreamConfig streamConfig, int maxParallelism)
Create a newBootstrapStreamTaskRunner
.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
endInput()
void
open()
void
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IN> element)
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
beforeInitializeStateHandler, close, finish, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isAsyncStateProcessingEnabled, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark, processWatermark, processWatermark1, processWatermark1, processWatermark2, processWatermark2, processWatermarkStatus, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState, useSplittableTimers
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
Methods inherited from interface org.apache.flink.streaming.api.operators.Input
processLatencyMarker, processRecordAttributes, processWatermark, processWatermark, processWatermarkStatus
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContext
getCurrentKey, setCurrentKey
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandler
hasKeyContext
-
-
-
-
Constructor Detail
-
BootstrapStreamTaskRunner
public BootstrapStreamTaskRunner(org.apache.flink.streaming.api.graph.StreamConfig streamConfig, int maxParallelism)
Create a newBootstrapStreamTaskRunner
.- Parameters:
streamConfig
- The internal configuration for the task.maxParallelism
- The max parallelism of the operator.
-
-
Method Detail
-
open
public void open() throws Exception
- Specified by:
open
in interfaceorg.apache.flink.streaming.api.operators.StreamOperator<IN>
- Overrides:
open
in classorg.apache.flink.streaming.api.operators.AbstractStreamOperator<TaggedOperatorSubtaskState>
- Throws:
Exception
-
processElement
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IN> element) throws Exception
-
-