@Internal public class MultipleInputStreamTask<OUT> extends StreamTask<OUT,MultipleInputStreamOperator<OUT>>
StreamTask
for executing a MultipleInputStreamOperator
and supporting the
MultipleInputStreamOperator
to select input for reading.configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, 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,
Throwable cause) |
protected void |
createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate>[] inputGates,
StreamConfig.InputConfig[] inputs,
WatermarkGauge[] inputWatermarkGauges) |
void |
init() |
Future<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) |
advanceToEndOfEventTime, afterInvoke, beforeInvoke, cancel, cancelTask, cleanup, cleanUpInvoke, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, finalize, finishTask, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getCompletionFuture, getConfiguration, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, processInput, runMailboxLoop, runMailboxStep, setupNumRecordsInCounter, toString
public void init() throws Exception
init
in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>
Exception
protected void createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate>[] inputGates, StreamConfig.InputConfig[] inputs, WatermarkGauge[] inputWatermarkGauges)
public Future<Boolean> triggerCheckpointAsync(org.apache.flink.runtime.checkpoint.CheckpointMetaData metadata, org.apache.flink.runtime.checkpoint.CheckpointOptions options)
triggerCheckpointAsync
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 class StreamTask<OUT,MultipleInputStreamOperator<OUT>>
IOException
public void abortCheckpointOnBarrier(long checkpointId, Throwable cause) throws IOException
abortCheckpointOnBarrier
in class StreamTask<OUT,MultipleInputStreamOperator<OUT>>
IOException
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.