Class IterationEventWithAggregators
- java.lang.Object
-
- org.apache.flink.runtime.event.AbstractEvent
-
- org.apache.flink.runtime.event.TaskEvent
-
- org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- All Implemented Interfaces:
IOReadableWritable
- Direct Known Subclasses:
AllWorkersDoneEvent
,WorkerDoneEvent
public abstract class IterationEventWithAggregators extends TaskEvent
Base class for iterationTaskEvent
transmitting operator aggregators.
-
-
Field Summary
Fields Modifier and Type Field Description protected static String[]
NO_STRINGS
protected static Value[]
NO_VALUES
-
Constructor Summary
Constructors Modifier Constructor Description protected
IterationEventWithAggregators()
protected
IterationEventWithAggregators(String aggregatorName, Value aggregate)
protected
IterationEventWithAggregators(Map<String,Aggregator<?>> aggregators)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description Value[]
getAggregates(ClassLoader classResolver)
String[]
getAggregatorNames()
void
read(DataInputView in)
Reads the object's internal data from the given data input view.void
write(DataOutputView out)
Writes the object's internal data to the given data output view.
-
-
-
Constructor Detail
-
IterationEventWithAggregators
protected IterationEventWithAggregators()
-
IterationEventWithAggregators
protected IterationEventWithAggregators(String aggregatorName, Value aggregate)
-
IterationEventWithAggregators
protected IterationEventWithAggregators(Map<String,Aggregator<?>> aggregators)
-
-
Method Detail
-
getAggregatorNames
public String[] getAggregatorNames()
-
getAggregates
public Value[] getAggregates(ClassLoader classResolver)
-
write
public void write(DataOutputView out) throws IOException
Description copied from interface:IOReadableWritable
Writes the object's internal data to the given data output view.- Parameters:
out
- the output view to receive the data.- Throws:
IOException
- thrown if any error occurs while writing to the output stream
-
read
public void read(DataInputView in) throws IOException
Description copied from interface:IOReadableWritable
Reads the object's internal data from the given data input view.- Parameters:
in
- the input view to read the data from- Throws:
IOException
- thrown if any error occurs while reading from the input stream
-
-