Class SolutionSetObjectsUpdateOutputCollector<T>

  • All Implemented Interfaces:
    org.apache.flink.util.Collector<T>

    public class SolutionSetObjectsUpdateOutputCollector<T>
    extends Object
    implements org.apache.flink.util.Collector<T>
    A Collector to update the solution set of a workset iteration.

    The records are written to a HashTable hash table to allow in-memory point updates.

    Records will only be collected, if there is a match after probing the hash table. If the build side iterator is already positioned for the update, use SolutionSetFastUpdateOutputCollector to the save re-probing.

    See Also:
    SolutionSetFastUpdateOutputCollector
    • Constructor Detail

      • SolutionSetObjectsUpdateOutputCollector

        public SolutionSetObjectsUpdateOutputCollector​(org.apache.flink.api.common.operators.util.JoinHashMap<T> hashMap)
      • SolutionSetObjectsUpdateOutputCollector

        public SolutionSetObjectsUpdateOutputCollector​(org.apache.flink.api.common.operators.util.JoinHashMap<T> hashMap,
                                                       org.apache.flink.util.Collector<T> delegate)
    • Method Detail

      • collect

        public void collect​(T record)
        Specified by:
        collect in interface org.apache.flink.util.Collector<T>
      • close

        public void close()
        Specified by:
        close in interface org.apache.flink.util.Collector<T>