OUT
- Type of the produced elementsSRC
- Stoppable source functionpublic class StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & org.apache.flink.api.common.functions.StoppableFunction> extends SourceStreamTask<OUT,SRC,StoppableStreamSource<OUT,SRC>> implements org.apache.flink.runtime.jobgraph.tasks.StoppableTask
StreamTask.AsyncCheckpointRunnable
configuration, headOperator, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
StoppableSourceStreamTask(org.apache.flink.runtime.execution.Environment environment) |
Modifier and Type | Method and Description |
---|---|
protected void |
run() |
void |
stop() |
cancelTask, cleanup, init, triggerCheckpoint
abortCheckpointOnBarrier, cancel, createCheckpointExceptionHandlerFactory, createRecordWriters, createStreamTaskStateInitializer, finalize, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getConfiguration, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isRunning, notifyCheckpointComplete, toString, triggerCheckpointOnBarrier
public StoppableSourceStreamTask(org.apache.flink.runtime.execution.Environment environment)
protected void run() throws Exception
run
in class SourceStreamTask<OUT,SRC extends SourceFunction<OUT> & org.apache.flink.api.common.functions.StoppableFunction,StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & org.apache.flink.api.common.functions.StoppableFunction>>
Exception
public void stop()
stop
in interface org.apache.flink.runtime.jobgraph.tasks.StoppableTask
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.