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 of- KVvalues from the output of this primitive
- V- 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 SummaryNested classes/interfaces inherited from class com.hazelcast.jet.core.AbstractProcessorcom.hazelcast.jet.core.AbstractProcessor.FlatMapper<T,R> Nested classes/interfaces inherited from interface com.hazelcast.jet.core.Processorcom.hazelcast.jet.core.Processor.Context
- 
Method SummaryModifier and TypeMethodDescriptionbooleancomplete()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) booleanprotected booleantryProcess(int ordinal, Object item) booleantryProcessWatermark(com.hazelcast.jet.core.Watermark watermark) Methods inherited from class com.hazelcast.jet.core.AbstractProcessoremitFromTraverser, emitFromTraverser, emitFromTraverser, emitFromTraverserToSnapshot, flatMapper, flatMapper, flatMapper, getLogger, getOutbox, init, init, process, restoreFromSnapshot, restoreFromSnapshot, tryEmit, tryEmit, tryEmit, tryEmitToSnapshot, tryProcess0, tryProcess1, tryProcess2, tryProcess3, tryProcess4Methods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface com.hazelcast.jet.core.Processorclose, completeEdge, finishSnapshotRestore, isCooperative, saveToSnapshot, snapshotCommitFinish, snapshotCommitPrepare
- 
Method Details- 
supplierpublic 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) 
- 
tryProcesspublic boolean tryProcess()
- 
tryProcess- Overrides:
- tryProcessin class- com.hazelcast.jet.core.AbstractProcessor
 
- 
tryProcessWatermark- Specified by:
- tryProcessWatermarkin interface- com.hazelcast.jet.core.Processor
- Overrides:
- tryProcessWatermarkin class- com.hazelcast.jet.core.AbstractProcessor
 
- 
completepublic boolean complete()
 
-