Class WorkerDoneEvent
- java.lang.Object
-
- org.apache.flink.runtime.event.AbstractEvent
-
- org.apache.flink.runtime.event.TaskEvent
-
- org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- All Implemented Interfaces:
org.apache.flink.core.io.IOReadableWritable
public class WorkerDoneEvent extends IterationEventWithAggregators
Completion event sent from eachIterationHeadto theIterationSynchronizationSinkTask.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
NO_STRINGS, NO_VALUES
-
-
Constructor Summary
Constructors Constructor Description WorkerDoneEvent()WorkerDoneEvent(int workerIndex, String aggregatorName, org.apache.flink.types.Value aggregate)WorkerDoneEvent(int workerIndex, Map<String,org.apache.flink.api.common.aggregators.Aggregator<?>> aggregators)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description intgetWorkerIndex()voidread(org.apache.flink.core.memory.DataInputView in)voidwrite(org.apache.flink.core.memory.DataOutputView out)-
Methods inherited from class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
getAggregates, getAggregatorNames
-
-
-
-
Constructor Detail
-
WorkerDoneEvent
public WorkerDoneEvent()
-
WorkerDoneEvent
public WorkerDoneEvent(int workerIndex, String aggregatorName, org.apache.flink.types.Value aggregate)
-
-
Method Detail
-
getWorkerIndex
public int getWorkerIndex()
-
write
public void write(org.apache.flink.core.memory.DataOutputView out) throws IOException- Specified by:
writein interfaceorg.apache.flink.core.io.IOReadableWritable- Overrides:
writein classIterationEventWithAggregators- Throws:
IOException
-
read
public void read(org.apache.flink.core.memory.DataInputView in) throws IOException- Specified by:
readin interfaceorg.apache.flink.core.io.IOReadableWritable- Overrides:
readin classIterationEventWithAggregators- Throws:
IOException
-
-