@Internal public class RegularOperatorChain<OUT,OP extends StreamOperator<OUT>> extends OperatorChain<OUT,OP>
OperatorChain
.OperatorChain.ChainedSource
chainedSources, closer, finishedOnRestoreInput, firstOperatorWrapper, isClosed, mainOperatorOutput, mainOperatorWrapper, numOperators, operatorEventDispatcher, streamOutputs, tailOperatorWrapper
Constructor and Description |
---|
RegularOperatorChain(StreamTask<OUT,OP> containingTask,
RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate) |
Modifier and Type | Method and Description |
---|---|
void |
close()
This method releases all resources of the record writer output.
|
void |
closeAllOperators()
Execute
StreamOperator.close() of each operator in the chain of this StreamTask . |
void |
dispatchOperatorEvent(OperatorID operator,
SerializedValue<OperatorEvent> event) |
void |
endInput(int inputId)
Ends the main operator input specified by
inputId ). |
void |
finishOperators(StreamTaskActionExecutor actionExecutor,
StopMode stopMode)
Closes all operators in a chain effect way.
|
void |
initializeStateAndOpenOperators(StreamTaskStateInitializer streamTaskStateInitializer)
Initialize state and open all operators in the chain from tail to heads, contrary to
StreamOperator.close() which happens heads to tail (see OperatorChain.finishOperators(StreamTaskActionExecutor, StopMode) ). |
boolean |
isTaskDeployedAsFinished() |
void |
notifyCheckpointAborted(long checkpointId) |
void |
notifyCheckpointComplete(long checkpointId) |
void |
notifyCheckpointSubsumed(long checkpointId) |
void |
prepareSnapshotPreBarrier(long checkpointId) |
void |
snapshotState(Map<OperatorID,OperatorSnapshotFutures> operatorSnapshotsInProgress,
CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions,
Supplier<Boolean> isRunning,
ChannelStateWriter.ChannelStateWriteResult channelStateWriteResult,
CheckpointStreamFactory storage) |
abortCheckpoint, alignedBarrierTimeout, broadcastEvent, broadcastEvent, flushOutputs, getAllOperators, getAllOperators, getChainedSource, getChainedSourceOutputs, getFinishedOnRestoreInputOrDefault, getMainOperator, getMainOperatorOutput, getNumberOfOperators, getOperatorEventDispatcher, getSourceTaskInput, getSourceTaskInputs, getStreamOutputs, getTailOperator, isClosed, sendAcknowledgeCheckpointEvent, snapshotChannelStates
public RegularOperatorChain(StreamTask<OUT,OP> containingTask, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate)
public boolean isTaskDeployedAsFinished()
isTaskDeployedAsFinished
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
public void dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event) throws FlinkException
dispatchOperatorEvent
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
FlinkException
public void prepareSnapshotPreBarrier(long checkpointId) throws Exception
prepareSnapshotPreBarrier
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
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) throws Exception
OperatorChain
StreamOperator.close()
which happens heads to tail (see OperatorChain.finishOperators(StreamTaskActionExecutor, StopMode)
).initializeStateAndOpenOperators
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
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 closeAllOperators() throws Exception
OperatorChain
StreamOperator.close()
of each operator in the chain of this StreamTask
. Closing happens from tail to head operator in the chain.closeAllOperators
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
public void close() throws IOException
OperatorChain
This method should never fail.
close
in interface Closeable
close
in interface AutoCloseable
close
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
IOException
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 void snapshotState(Map<OperatorID,OperatorSnapshotFutures> operatorSnapshotsInProgress, CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, Supplier<Boolean> isRunning, ChannelStateWriter.ChannelStateWriteResult channelStateWriteResult, CheckpointStreamFactory storage) throws Exception
snapshotState
in class OperatorChain<OUT,OP extends StreamOperator<OUT>>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.