Class GroupAlsoByWindowViaOutputBufferFn<K,InputT,W extends BoundedWindow>
java.lang.Object
org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.GroupAlsoByWindowViaOutputBufferFn<K,InputT,W>
- All Implemented Interfaces:
Serializable
,org.apache.spark.api.java.function.FlatMapGroupsFunction<K,
WindowedValue<KV<K, InputT>>, WindowedValue<KV<K, Iterable<InputT>>>>
public class GroupAlsoByWindowViaOutputBufferFn<K,InputT,W extends BoundedWindow>
extends Object
implements org.apache.spark.api.java.function.FlatMapGroupsFunction<K,WindowedValue<KV<K,InputT>>,WindowedValue<KV<K,Iterable<InputT>>>>
A FlatMap function that groups by windows in batch mode using
ReduceFnRunner
.- See Also:
-
Constructor Summary
ConstructorsConstructorDescriptionGroupAlsoByWindowViaOutputBufferFn
(WindowingStrategy<?, W> windowingStrategy, org.apache.beam.runners.core.StateInternalsFactory<K> stateInternalsFactory, org.apache.beam.runners.core.SystemReduceFn<K, InputT, Iterable<InputT>, Iterable<InputT>, W> reduceFn, Supplier<PipelineOptions> options) -
Method Summary
-
Constructor Details
-
GroupAlsoByWindowViaOutputBufferFn
-
-
Method Details