Class TwoInputStreamTask<IN1,IN2,OUT>
- java.lang.Object
-
- org.apache.flink.streaming.runtime.tasks.StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
-
- org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask<IN1,IN2,OUT>
-
- org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask<IN1,IN2,OUT>
-
- All Implemented Interfaces:
CheckpointableTask
,CoordinatedTask
,TaskInvokable
,AsyncExceptionHandler
,ContainingTaskDetails
@Internal public class TwoInputStreamTask<IN1,IN2,OUT> extends AbstractTwoInputStreamTask<IN1,IN2,OUT>
AStreamTask
for executing aTwoInputStreamOperator
and supporting theTwoInputStreamOperator
to select input for reading.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.streaming.runtime.tasks.StreamTask
StreamTask.CanEmitBatchOfRecordsChecker
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
input1WatermarkGauge, input2WatermarkGauge, minInputWatermarkGauge
-
Fields inherited from class org.apache.flink.streaming.runtime.tasks.StreamTask
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, recordWriter, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
-
-
Constructor Summary
Constructors Constructor Description TwoInputStreamTask(Environment env)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected void
createInputProcessor(List<IndexedInputGate> inputGates1, List<IndexedInputGate> inputGates2, Function<Integer,StreamPartitioner<?>> gatePartitioners)
StreamTask.CanEmitBatchOfRecordsChecker
getCanEmitBatchOfRecords()
protected Optional<CheckpointBarrierHandler>
getCheckpointBarrierHandler()
Acquires the optionalCheckpointBarrierHandler
associated with this stream task.-
Methods inherited from class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
init
-
Methods inherited from class org.apache.flink.streaming.runtime.tasks.StreamTask
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, cancel, cancelTask, cleanUp, cleanUpInternal, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, hasMail, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, notifyCheckpointSubsumedAsync, notifyEndOfData, processInput, restore, runMailboxLoop, runMailboxStep, runSingleMailboxLoop, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
-
Methods inherited from class java.lang.Object
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
-
Methods inherited from interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
-
-
-
-
Constructor Detail
-
TwoInputStreamTask
public TwoInputStreamTask(Environment env) throws Exception
- Throws:
Exception
-
-
Method Detail
-
getCheckpointBarrierHandler
protected Optional<CheckpointBarrierHandler> getCheckpointBarrierHandler()
Description copied from class:StreamTask
Acquires the optionalCheckpointBarrierHandler
associated with this stream task. TheCheckpointBarrierHandler
should exist if the task has data inputs and requires to align the barriers.- Overrides:
getCheckpointBarrierHandler
in classStreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
-
createInputProcessor
protected void createInputProcessor(List<IndexedInputGate> inputGates1, List<IndexedInputGate> inputGates2, Function<Integer,StreamPartitioner<?>> gatePartitioners)
- Specified by:
createInputProcessor
in classAbstractTwoInputStreamTask<IN1,IN2,OUT>
-
getCanEmitBatchOfRecords
public StreamTask.CanEmitBatchOfRecordsChecker getCanEmitBatchOfRecords()
- Overrides:
getCanEmitBatchOfRecords
in classStreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
-
-