OUT
- Type of the produced elementsSRC
- Stoppable source functionpublic class StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> extends SourceStreamTask<OUT,SRC,StoppableStreamSource<OUT,SRC>> implements StoppableTask
StreamTask.AsyncCheckpointRunnable
configuration, headOperator, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
StoppableSourceStreamTask(Environment environment) |
Modifier and Type | Method and Description |
---|---|
protected void |
run() |
void |
stop()
Called on STOP signal.
|
cancelTask, cleanup, init, triggerCheckpoint
abortCheckpointOnBarrier, cancel, createCheckpointExceptionHandlerFactory, createStreamRecordWriters, createStreamTaskStateInitializer, finalize, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getConfiguration, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isRunning, notifyCheckpointComplete, toString, triggerCheckpointOnBarrier
getCurrentNumberOfSubtasks, getEnvironment, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader
public StoppableSourceStreamTask(Environment environment)
protected void run() throws Exception
run
in class SourceStreamTask<OUT,SRC extends SourceFunction<OUT> & StoppableFunction,StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction>>
Exception
public void stop()
StoppableTask
stop
in interface StoppableTask
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.