AbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT> |
The abstract base class for all tasks able to participate in an iteration.
|
IterationHeadTask<X,Y,S extends org.apache.flink.api.common.functions.Function,OT> |
The head is responsible for coordinating an iteration and can run a Driver inside.
|
IterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT> |
An intermediate iteration task, which runs a Driver
inside.
|
IterationSynchronizationSinkTask |
The task responsible for synchronizing all iteration heads, implemented as an output task.
|
IterationTailTask<S extends org.apache.flink.api.common.functions.Function,OT> |
An iteration tail, which runs a driver inside.
|
RuntimeAggregatorRegistry |
|
SyncEventHandler |
Listener for WorkerDoneEvent which also aggregates all aggregators from iteration tasks
and signals the end of the superstep.
|