@Internal public class MultipleInputStreamTask<OUT> extends StreamTask<OUT,MultipleInputStreamOperator<OUT>>
StreamTask for executing a MultipleInputStreamOperator and supporting the
MultipleInputStreamOperator to select input for reading.checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP| Constructor and Description |
|---|
MultipleInputStreamTask(org.apache.flink.runtime.execution.Environment env) |
| Modifier and Type | Method and Description |
|---|---|
void |
abortCheckpointOnBarrier(long checkpointId,
org.apache.flink.runtime.checkpoint.CheckpointException cause) |
protected void |
advanceToEndOfEventTime()
Emits the
MAX_WATERMARK so that all registered timers are fired. |
protected void |
createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate>[] inputGates,
StreamConfig.InputConfig[] inputs,
WatermarkGauge[] inputWatermarkGauges,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
protected Optional<CheckpointBarrierHandler> |
getCheckpointBarrierHandler()
Acquires the optional
CheckpointBarrierHandler associated with this stream task. |
void |
init() |
CompletableFuture<Boolean> |
triggerCheckpointAsync(org.apache.flink.runtime.checkpoint.CheckpointMetaData metadata,
org.apache.flink.runtime.checkpoint.CheckpointOptions options) |
void |
triggerCheckpointOnBarrier(org.apache.flink.runtime.checkpoint.CheckpointMetaData checkpointMetaData,
org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions,
org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder checkpointMetrics) |
afterInvoke, assertTriggeringCheckpointExceptions, cancel, cancelTask, cleanUp, cleanUpInternal, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, finishTask, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, processInput, restore, runMailboxLoop, runMailboxStep, setSynchronousSavepoint, setupNumRecordsInCounter, toStringclone, equals, getClass, hashCode, notify, notifyAll, wait, wait, waitgetExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoaderpublic void init()
throws Exception
init in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>Exceptionprotected void createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate>[] inputGates, StreamConfig.InputConfig[] inputs, WatermarkGauge[] inputWatermarkGauges, java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners)
protected Optional<CheckpointBarrierHandler> getCheckpointBarrierHandler()
StreamTaskCheckpointBarrierHandler associated with this stream task. The
CheckpointBarrierHandler should exist if the task has data inputs and requires to
align the barriers.getCheckpointBarrierHandler in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>public CompletableFuture<Boolean> triggerCheckpointAsync(org.apache.flink.runtime.checkpoint.CheckpointMetaData metadata, org.apache.flink.runtime.checkpoint.CheckpointOptions options)
triggerCheckpointAsync in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTasktriggerCheckpointAsync in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>public void triggerCheckpointOnBarrier(org.apache.flink.runtime.checkpoint.CheckpointMetaData checkpointMetaData,
org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions,
org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder checkpointMetrics)
throws IOException
triggerCheckpointOnBarrier in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTasktriggerCheckpointOnBarrier in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>IOExceptionpublic void abortCheckpointOnBarrier(long checkpointId,
org.apache.flink.runtime.checkpoint.CheckpointException cause)
throws IOException
abortCheckpointOnBarrier in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTaskabortCheckpointOnBarrier in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>IOExceptionprotected void advanceToEndOfEventTime()
throws Exception
StreamTaskMAX_WATERMARK so that all registered timers are fired.
This is used by the source task when the job is TERMINATED. In the case, we want
all the timers registered throughout the pipeline to fire and the related state (e.g.
windows) to be flushed.
For tasks other than the source task, this method does nothing.
advanceToEndOfEventTime in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>ExceptionCopyright © 2014–2021 The Apache Software Foundation. All rights reserved.