@Internal public class TwoInputSelectableStreamTask<IN1,IN2,OUT> extends AbstractTwoInputStreamTask<IN1,IN2,OUT>
StreamTask for executing a TwoInputStreamOperator and supporting
the TwoInputStreamOperator to select input for reading.StreamTask.ActionContext, StreamTask.AsyncCheckpointRunnableinput1WatermarkGauge, input2WatermarkGauge, minInputWatermarkGaugeconfiguration, headOperator, inputProcessor, mailbox, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP| Constructor and Description |
|---|
TwoInputSelectableStreamTask(org.apache.flink.runtime.execution.Environment env) |
| Modifier and Type | Method and Description |
|---|---|
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) |
initabortCheckpointOnBarrier, advanceToEndOfEventTime, cancel, cancelTask, cleanup, createCheckpointExceptionHandlerFactory, createRecordWriters, createStreamTaskStateInitializer, finalize, finishTask, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getConfiguration, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isRunning, notifyCheckpointComplete, processInput, toString, triggerCheckpoint, triggerCheckpointOnBarriergetCurrentNumberOfSubtasks, getEnvironment, getExecutingThread, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader, setShouldInterruptOnCancel, shouldInterruptOnCancelpublic TwoInputSelectableStreamTask(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 in class AbstractTwoInputStreamTask<IN1,IN2,OUT>IOExceptionCopyright © 2014–2020 The Apache Software Foundation. All rights reserved.