K
- key type of KV
values from the output of this primitiveV
- type of elements being windowedpublic class WindowGroupP<K,V>
extends com.hazelcast.jet.core.AbstractProcessor
Processor
implementation for Beam's GroupByKeyOnly +
GroupAlsoByWindow primitives.Modifier and Type | Method and Description |
---|---|
boolean |
complete() |
static <K,V> com.hazelcast.function.SupplierEx<com.hazelcast.jet.core.Processor> |
supplier(org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions,
org.apache.beam.sdk.util.WindowedValue.WindowedValueCoder<KV<K,V>> inputCoder,
Coder outputCoder,
WindowingStrategy windowingStrategy,
java.lang.String ownerId) |
boolean |
tryProcess() |
protected boolean |
tryProcess(int ordinal,
java.lang.Object item) |
boolean |
tryProcessWatermark(com.hazelcast.jet.core.Watermark watermark) |
emitFromTraverser, emitFromTraverser, emitFromTraverser, emitFromTraverserToSnapshot, flatMapper, flatMapper, flatMapper, getLogger, getOutbox, init, init, process, restoreFromSnapshot, restoreFromSnapshot, tryEmit, tryEmit, tryEmit, tryEmitToSnapshot, tryProcess0, tryProcess1, tryProcess2, tryProcess3, tryProcess4
public static <K,V> com.hazelcast.function.SupplierEx<com.hazelcast.jet.core.Processor> supplier(org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions, org.apache.beam.sdk.util.WindowedValue.WindowedValueCoder<KV<K,V>> inputCoder, Coder outputCoder, WindowingStrategy windowingStrategy, java.lang.String ownerId)
public boolean tryProcess()
protected boolean tryProcess(int ordinal, @Nonnull java.lang.Object item)
tryProcess
in class com.hazelcast.jet.core.AbstractProcessor
public boolean tryProcessWatermark(@Nonnull com.hazelcast.jet.core.Watermark watermark)
tryProcessWatermark
in interface com.hazelcast.jet.core.Processor
tryProcessWatermark
in class com.hazelcast.jet.core.AbstractProcessor
public boolean complete()