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:
org.apache.flink.core.io.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 org.apache.flink.types.Value[]
NO_VALUES
-
Constructor Summary
Constructors Modifier Constructor Description protected
IterationEventWithAggregators()
protected
IterationEventWithAggregators(String aggregatorName, org.apache.flink.types.Value aggregate)
protected
IterationEventWithAggregators(Map<String,org.apache.flink.api.common.aggregators.Aggregator<?>> aggregators)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.flink.types.Value[]
getAggregates(ClassLoader classResolver)
String[]
getAggregatorNames()
void
read(org.apache.flink.core.memory.DataInputView in)
void
write(org.apache.flink.core.memory.DataOutputView out)
-
-
-
Field Detail
-
NO_STRINGS
protected static final String[] NO_STRINGS
-
NO_VALUES
protected static final org.apache.flink.types.Value[] NO_VALUES
-
-
Constructor Detail
-
IterationEventWithAggregators
protected IterationEventWithAggregators()
-
IterationEventWithAggregators
protected IterationEventWithAggregators(String aggregatorName, org.apache.flink.types.Value aggregate)
-
-
Method Detail
-
getAggregatorNames
public String[] getAggregatorNames()
-
getAggregates
public org.apache.flink.types.Value[] getAggregates(ClassLoader classResolver)
-
write
public void write(org.apache.flink.core.memory.DataOutputView out) throws IOException
- Throws:
IOException
-
read
public void read(org.apache.flink.core.memory.DataInputView in) throws IOException
- Throws:
IOException
-
-