@Internal public class SourceOperatorStreamTask<T> extends StreamTask<T,SourceOperator<T,?>>
StreamTask
for executing the SourceOperator
.Modifier and Type | Class and Description |
---|---|
static class |
SourceOperatorStreamTask.AsyncDataOutputToOutput<T>
Implementation of
PushingAsyncDataInput.DataOutput that wraps a specific Output . |
StreamTask.CanEmitBatchOfRecordsChecker
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, recordWriter, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
SourceOperatorStreamTask(org.apache.flink.runtime.execution.Environment env) |
Modifier and Type | Method and Description |
---|---|
protected void |
advanceToEndOfEventTime()
Emits the
MAX_WATERMARK so that all registered timers are fired. |
protected void |
declineCheckpoint(long checkpointId) |
void |
init() |
Future<Void> |
notifyCheckpointAbortAsync(long checkpointId,
long latestCompletedCheckpointId) |
Future<Void> |
notifyCheckpointSubsumedAsync(long checkpointId) |
CompletableFuture<Boolean> |
triggerCheckpointAsync(org.apache.flink.runtime.checkpoint.CheckpointMetaData checkpointMetaData,
org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions) |
abortCheckpointOnBarrier, afterInvoke, cancel, cancelTask, cleanUp, cleanUpInternal, createRecordWriterDelegate, createStreamTaskStateInitializer, dispatchOperatorEvent, endData, finalize, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCanEmitBatchOfRecords, getCheckpointBarrierHandler, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointCompleteAsync, processInput, restore, runMailboxLoop, runMailboxStep, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointOnBarrier
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
public void init() throws Exception
init
in class StreamTask<T,SourceOperator<T,?>>
Exception
public CompletableFuture<Boolean> triggerCheckpointAsync(org.apache.flink.runtime.checkpoint.CheckpointMetaData checkpointMetaData, org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions)
triggerCheckpointAsync
in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
triggerCheckpointAsync
in class StreamTask<T,SourceOperator<T,?>>
protected void advanceToEndOfEventTime()
StreamTask
MAX_WATERMARK
so that all registered timers are fired.
This is used by the source task when the job is TERMINATED
. In the case, we want
all the timers registered throughout the pipeline to fire and the related state (e.g.
windows) to be flushed.
For tasks other than the source task, this method does nothing.
advanceToEndOfEventTime
in class StreamTask<T,SourceOperator<T,?>>
protected void declineCheckpoint(long checkpointId)
declineCheckpoint
in class StreamTask<T,SourceOperator<T,?>>
public Future<Void> notifyCheckpointAbortAsync(long checkpointId, long latestCompletedCheckpointId)
notifyCheckpointAbortAsync
in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
notifyCheckpointAbortAsync
in class StreamTask<T,SourceOperator<T,?>>
public Future<Void> notifyCheckpointSubsumedAsync(long checkpointId)
notifyCheckpointSubsumedAsync
in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
notifyCheckpointSubsumedAsync
in class StreamTask<T,SourceOperator<T,?>>
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.