Class DataSinkTask<IT>
- java.lang.Object
-
- org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
- org.apache.flink.runtime.operators.DataSinkTask<IT>
-
- All Implemented Interfaces:
CheckpointableTask,CoordinatedTask,TaskInvokable
public class DataSinkTask<IT> extends AbstractInvokable
DataSinkTask which is executed by a task manager. The task hands the data to an output format.- See Also:
OutputFormat
-
-
Constructor Summary
Constructors Constructor Description DataSinkTask(Environment environment)Create an Invokable task and set its environment.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidcancel()This method is called when a task is canceled either as a result of a user abort or an execution failure.DistributedRuntimeUDFContextcreateRuntimeContext()voidinvoke()Starts the execution.-
Methods inherited from class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
abortCheckpointOnBarrier, cleanUp, dispatchOperatorEvent, getCurrentNumberOfSubtasks, getEnvironment, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, notifyCheckpointSubsumedAsync, restore, triggerCheckpointAsync, triggerCheckpointOnBarrier
-
-
-
-
Constructor Detail
-
DataSinkTask
public DataSinkTask(Environment environment)
Create an Invokable task and set its environment.- Parameters:
environment- The environment assigned to this invokable.
-
-
Method Detail
-
invoke
public void invoke() throws ExceptionDescription copied from interface:TaskInvokableStarts the execution.This method is called by the task manager when the actual execution of the task starts.
All resources should be cleaned up by calling
TaskInvokable.cleanUp(Throwable)after the method returns.- Throws:
Exception
-
cancel
public void cancel() throws ExceptionDescription copied from interface:TaskInvokableThis method is called when a task is canceled either as a result of a user abort or an execution failure. It can be overwritten to respond to shut down the user code properly.- Specified by:
cancelin interfaceTaskInvokable- Overrides:
cancelin classAbstractInvokable- Throws:
Exception
-
createRuntimeContext
public DistributedRuntimeUDFContext createRuntimeContext()
-
-