@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.StreamTask.AsyncCheckpointRunnable
input1WatermarkGauge, input2WatermarkGauge, minInputWatermarkGauge
configuration, headOperator, inputProcessor, LOG, mailboxProcessor, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
构造器和说明 |
---|
TwoInputStreamTask(org.apache.flink.runtime.execution.Environment env) |
限定符和类型 | 方法和说明 |
---|---|
protected void |
createInputProcessor(Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates1,
Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates2,
org.apache.flink.api.common.typeutils.TypeSerializer<IN1> inputDeserializer1,
org.apache.flink.api.common.typeutils.TypeSerializer<IN2> inputDeserializer2) |
init
abortCheckpointOnBarrier, advanceToEndOfEventTime, cancel, cancelTask, cleanup, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, finalize, finishTask, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getConfiguration, getMailboxExecutorFactory, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, handleCheckpointException, invoke, isCanceled, isRunning, notifyCheckpointCompleteAsync, processInput, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
public TwoInputStreamTask(org.apache.flink.runtime.execution.Environment env)
protected void createInputProcessor(Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates1, Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates2, org.apache.flink.api.common.typeutils.TypeSerializer<IN1> inputDeserializer1, org.apache.flink.api.common.typeutils.TypeSerializer<IN2> inputDeserializer2) throws IOException
createInputProcessor
在类中 AbstractTwoInputStreamTask<IN1,IN2,OUT>
IOException
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.