Class WindowGroupP<K,V>
java.lang.Object
com.hazelcast.jet.core.AbstractProcessor
org.apache.beam.runners.jet.processors.WindowGroupP<K,V>
- Type Parameters:
K
- key type ofKV
values from the output of this primitiveV
- type of elements being windowed
- All Implemented Interfaces:
com.hazelcast.jet.core.Processor
public class WindowGroupP<K,V>
extends com.hazelcast.jet.core.AbstractProcessor
Jet
Processor
implementation for Beam's GroupByKeyOnly +
GroupAlsoByWindow primitives.-
Nested Class Summary
Nested classes/interfaces inherited from class com.hazelcast.jet.core.AbstractProcessor
com.hazelcast.jet.core.AbstractProcessor.FlatMapper<T,
R> Nested classes/interfaces inherited from interface com.hazelcast.jet.core.Processor
com.hazelcast.jet.core.Processor.Context
-
Method Summary
Modifier and TypeMethodDescriptionboolean
complete()
static <K,
V> com.hazelcast.function.SupplierEx <com.hazelcast.jet.core.Processor> supplier
(org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions, WindowedValues.WindowedValueCoder<KV<K, V>> inputCoder, Coder outputCoder, WindowingStrategy windowingStrategy, String ownerId) boolean
protected boolean
tryProcess
(int ordinal, Object item) boolean
tryProcessWatermark
(com.hazelcast.jet.core.Watermark watermark) Methods inherited from class com.hazelcast.jet.core.AbstractProcessor
emitFromTraverser, emitFromTraverser, emitFromTraverser, emitFromTraverserToSnapshot, flatMapper, flatMapper, flatMapper, getLogger, getOutbox, init, init, process, restoreFromSnapshot, restoreFromSnapshot, tryEmit, tryEmit, tryEmit, tryEmitToSnapshot, tryProcess0, tryProcess1, tryProcess2, tryProcess3, tryProcess4
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface com.hazelcast.jet.core.Processor
close, completeEdge, finishSnapshotRestore, isCooperative, saveToSnapshot, snapshotCommitFinish, snapshotCommitPrepare
-
Method Details
-
supplier
public static <K,V> com.hazelcast.function.SupplierEx<com.hazelcast.jet.core.Processor> supplier(org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions, WindowedValues.WindowedValueCoder<KV<K, V>> inputCoder, Coder outputCoder, WindowingStrategy windowingStrategy, String ownerId) -
tryProcess
public boolean tryProcess() -
tryProcess
- Overrides:
tryProcess
in classcom.hazelcast.jet.core.AbstractProcessor
-
tryProcessWatermark
- Specified by:
tryProcessWatermark
in interfacecom.hazelcast.jet.core.Processor
- Overrides:
tryProcessWatermark
in classcom.hazelcast.jet.core.AbstractProcessor
-
complete
public boolean complete()
-