@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
configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, 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) |
init
abortCheckpointOnBarrier, 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, triggerCheckpointAsync, triggerCheckpointOnBarrier
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)
createInputProcessor
在类中 AbstractTwoInputStreamTask<IN1,IN2,OUT>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.