public class UnboundedSourceP<T,CmT extends UnboundedSource.CheckpointMark>
extends com.hazelcast.jet.core.AbstractProcessor
Processor
implementation for reading from an unbounded Beam
source.Modifier and Type | Method and Description |
---|---|
void |
close() |
boolean |
complete() |
protected void |
init(com.hazelcast.jet.core.Processor.Context context) |
boolean |
isCooperative() |
static <T,CmT extends UnboundedSource.CheckpointMark> |
supplier(UnboundedSource<T,CmT> unboundedSource,
org.apache.beam.runners.core.construction.SerializablePipelineOptions options,
Coder outputCoder,
java.lang.String ownerId) |
emitFromTraverser, emitFromTraverser, emitFromTraverser, emitFromTraverserToSnapshot, flatMapper, flatMapper, flatMapper, getLogger, getOutbox, init, process, restoreFromSnapshot, restoreFromSnapshot, tryEmit, tryEmit, tryEmit, tryEmitToSnapshot, tryProcess, tryProcess0, tryProcess1, tryProcess2, tryProcess3, tryProcess4, tryProcessWatermark
protected void init(@Nonnull com.hazelcast.jet.core.Processor.Context context) throws java.io.IOException
init
in class com.hazelcast.jet.core.AbstractProcessor
java.io.IOException
public boolean complete()
public boolean isCooperative()
public void close()
public static <T,CmT extends UnboundedSource.CheckpointMark> com.hazelcast.jet.core.ProcessorMetaSupplier supplier(UnboundedSource<T,CmT> unboundedSource, org.apache.beam.runners.core.construction.SerializablePipelineOptions options, Coder outputCoder, java.lang.String ownerId)