public class GroupAlsoByWindowViaOutputBufferFn<K,InputT,W extends BoundedWindow> extends java.lang.Object implements org.apache.spark.api.java.function.FlatMapGroupsFunction<K,org.apache.beam.sdk.util.WindowedValue<KV<K,InputT>>,org.apache.beam.sdk.util.WindowedValue<KV<K,java.lang.Iterable<InputT>>>>
ReduceFnRunner.| Constructor and Description | 
|---|
| GroupAlsoByWindowViaOutputBufferFn(WindowingStrategy<?,W> windowingStrategy,
                                  org.apache.beam.runners.core.StateInternalsFactory<K> stateInternalsFactory,
                                  org.apache.beam.runners.core.SystemReduceFn<K,InputT,java.lang.Iterable<InputT>,java.lang.Iterable<InputT>,W> reduceFn,
                                  org.apache.beam.runners.core.construction.SerializablePipelineOptions options) | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.Iterator<org.apache.beam.sdk.util.WindowedValue<KV<K,java.lang.Iterable<InputT>>>> | call(K key,
    java.util.Iterator<org.apache.beam.sdk.util.WindowedValue<KV<K,InputT>>> iterator) | 
public GroupAlsoByWindowViaOutputBufferFn(WindowingStrategy<?,W> windowingStrategy, org.apache.beam.runners.core.StateInternalsFactory<K> stateInternalsFactory, org.apache.beam.runners.core.SystemReduceFn<K,InputT,java.lang.Iterable<InputT>,java.lang.Iterable<InputT>,W> reduceFn, org.apache.beam.runners.core.construction.SerializablePipelineOptions options)