@Internal public class FinishedOperatorChain<OUT,OP extends StreamOperator<OUT>> extends OperatorChain<OUT,OP>
OperatorChain
that is used for restoring tasks that are TaskStateManager.isTaskDeployedAsFinished()
.OperatorChain.ChainedSource
chainedSources, closer, finishedOnRestoreInput, firstOperatorWrapper, isClosed, mainOperatorOutput, mainOperatorWrapper, numOperators, operatorEventDispatcher, streamOutputs, tailOperatorWrapper
Constructor and Description |
---|
FinishedOperatorChain(StreamTask<OUT,OP> containingTask,
RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate) |
abortCheckpoint, alignedBarrierTimeout, broadcastEvent, broadcastEvent, close, closeAllOperators, flushOutputs, getAllOperators, getAllOperators, getChainedSource, getChainedSourceOutputs, getFinishedOnRestoreInputOrDefault, getMainOperator, getNumberOfOperators, getOperatorEventDispatcher, getSourceTaskInput, getSourceTaskInputs, getStreamOutputs, getTailOperator, sendAcknowledgeCheckpointEvent, snapshotChannelStates
public FinishedOperatorChain(StreamTask<OUT,OP> containingTask, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate)
public boolean isTaskDeployedAsFinished()
isTaskDeployedAsFinished
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
public WatermarkGaugeExposingOutput<StreamRecord<OUT>> getMainOperatorOutput()
getMainOperatorOutput
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
public void dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event)
dispatchOperatorEvent
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
public void prepareSnapshotPreBarrier(long checkpointId)
prepareSnapshotPreBarrier
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
public void endInput(int inputId) throws Exception
OperatorChain
inputId
).endInput
in interface BoundedMultiInput
endInput
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
inputId
- the input ID starts from 1 which indicates the first input.Exception
public void initializeStateAndOpenOperators(StreamTaskStateInitializer streamTaskStateInitializer)
OperatorChain
StreamOperator.close()
which happens heads to tail (see OperatorChain.finishOperators(StreamTaskActionExecutor, StopMode)
).initializeStateAndOpenOperators
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
public void finishOperators(StreamTaskActionExecutor actionExecutor, StopMode stopMode) throws Exception
OperatorChain
StreamOperator.open()
which happens tail to
heads (see OperatorChain.initializeStateAndOpenOperators(StreamTaskStateInitializer)
).finishOperators
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
public void notifyCheckpointComplete(long checkpointId) throws Exception
notifyCheckpointComplete
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
public void notifyCheckpointAborted(long checkpointId) throws Exception
notifyCheckpointAborted
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
public void notifyCheckpointSubsumed(long checkpointId) throws Exception
notifyCheckpointSubsumed
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
public boolean isClosed()
isClosed
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
public void snapshotState(Map<OperatorID,OperatorSnapshotFutures> operatorSnapshotsInProgress, CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, java.util.function.Supplier<Boolean> isRunning, ChannelStateWriter.ChannelStateWriteResult channelStateWriteResult, CheckpointStreamFactory storage) throws Exception
snapshotState
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.