@Internal public class TwoInputStreamTask<IN1,IN2,OUT> extends AbstractTwoInputStreamTask<IN1,IN2,OUT>
StreamTask
for executing a TwoInputStreamOperator
and supporting the TwoInputStreamOperator
to select input for reading.input1WatermarkGauge, input2WatermarkGauge, minInputWatermarkGauge
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
构造器和说明 |
---|
TwoInputStreamTask(org.apache.flink.runtime.execution.Environment env) |
限定符和类型 | 方法和说明 |
---|---|
protected void |
createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates1,
List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates2,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
protected Optional<CheckpointBarrierHandler> |
getCheckpointBarrierHandler()
Acquires the optional
CheckpointBarrierHandler associated with this stream task. |
init
abortCheckpointOnBarrier, advanceToEndOfEventTime, 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, triggerCheckpointAsync, triggerCheckpointOnBarrier
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
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.protected void createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates1, List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates2, java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners)
createInputProcessor
在类中 AbstractTwoInputStreamTask<IN1,IN2,OUT>
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.