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 eachIterationHead
to 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 int
getWorkerIndex()
void
read(org.apache.flink.core.memory.DataInputView in)
void
write(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:
write
in interfaceorg.apache.flink.core.io.IOReadableWritable
- Overrides:
write
in classIterationEventWithAggregators
- Throws:
IOException
-
read
public void read(org.apache.flink.core.memory.DataInputView in) throws IOException
- Specified by:
read
in interfaceorg.apache.flink.core.io.IOReadableWritable
- Overrides:
read
in classIterationEventWithAggregators
- Throws:
IOException
-
-