@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, minInputWatermarkGaugecheckpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP| Constructor and Description |
|---|
TwoInputStreamTask(org.apache.flink.runtime.execution.Environment env) |
| Modifier and Type | Method and Description |
|---|---|
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) |
initabortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, 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, isUsingNonBlockingInput, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, processInput, restore, runMailboxLoop, runMailboxStep, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrierprotected 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 in class AbstractTwoInputStreamTask<IN1,IN2,OUT>Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.