Class IterationEventWithAggregators

  • All Implemented Interfaces:
    org.apache.flink.core.io.IOReadableWritable
    Direct Known Subclasses:
    AllWorkersDoneEvent, WorkerDoneEvent

    public abstract class IterationEventWithAggregators
    extends TaskEvent
    Base class for iteration TaskEvent transmitting operator aggregators.
    • 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)
      • IterationEventWithAggregators

        protected IterationEventWithAggregators​(Map<String,​org.apache.flink.api.common.aggregators.Aggregator<?>> aggregators)
    • 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