@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
构造器和说明 |
---|
MultipleInputStreamTask(org.apache.flink.runtime.execution.Environment env) |
限定符和类型 | 方法和说明 |
---|---|
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, toString
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
public void init() throws Exception
init
在类中 StreamTask<OUT,MultipleInputStreamOperator<OUT>>
Exception
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()
StreamTask
CheckpointBarrierHandler
associated with this stream task. The
CheckpointBarrierHandler
should exist if the task has data inputs and requires to
align the barriers.public CompletableFuture<Boolean> triggerCheckpointAsync(org.apache.flink.runtime.checkpoint.CheckpointMetaData metadata, org.apache.flink.runtime.checkpoint.CheckpointOptions options)
triggerCheckpointAsync
在接口中 org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
triggerCheckpointAsync
在类中 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
在接口中 org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
triggerCheckpointOnBarrier
在类中 StreamTask<OUT,MultipleInputStreamOperator<OUT>>
IOException
public void abortCheckpointOnBarrier(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointException cause) throws IOException
abortCheckpointOnBarrier
在接口中 org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
abortCheckpointOnBarrier
在类中 StreamTask<OUT,MultipleInputStreamOperator<OUT>>
IOException
protected void advanceToEndOfEventTime() throws Exception
StreamTask
MAX_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
在类中 StreamTask<OUT,MultipleInputStreamOperator<OUT>>
Exception
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.