Class FlinkNonMergingReduceFunction<K,InputT>

java.lang.Object
org.apache.beam.runners.flink.translation.functions.FlinkNonMergingReduceFunction<K,InputT>
Type Parameters:
K - Key type.
InputT - Input type.
All Implemented Interfaces:
Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.GroupReduceFunction<WindowedValue<KV<K,InputT>>,WindowedValue<KV<K,Iterable<InputT>>>>

public class FlinkNonMergingReduceFunction<K,InputT> extends Object implements org.apache.flink.api.common.functions.GroupReduceFunction<WindowedValue<KV<K,InputT>>,WindowedValue<KV<K,Iterable<InputT>>>>
Reduce function for non-merging GBK implementation. Implementation tries to return non-iterable results when possible, so we do not have to materialize all values for a single key in memory.
See Also:
  • Constructor Details

    • FlinkNonMergingReduceFunction

      public FlinkNonMergingReduceFunction(WindowingStrategy<?,?> windowingStrategy, boolean reIterableResult)
  • Method Details