Class UnboundedSourceP<T,CmT extends UnboundedSource.CheckpointMark>
java.lang.Object
com.hazelcast.jet.core.AbstractProcessor
org.apache.beam.runners.jet.processors.UnboundedSourceP<T,CmT>
- All Implemented Interfaces:
com.hazelcast.jet.core.Processor
public class UnboundedSourceP<T,CmT extends UnboundedSource.CheckpointMark>
extends com.hazelcast.jet.core.AbstractProcessor
Jet
Processor
implementation for reading from an unbounded Beam
source.-
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 TypeMethodDescriptionvoid
close()
boolean
complete()
protected void
init
(com.hazelcast.jet.core.Processor.Context context) boolean
static <T,
CmT extends UnboundedSource.CheckpointMark>
com.hazelcast.jet.core.ProcessorMetaSuppliersupplier
(UnboundedSource<T, CmT> unboundedSource, org.apache.beam.runners.core.construction.SerializablePipelineOptions options, Coder outputCoder, String ownerId) Methods inherited from class com.hazelcast.jet.core.AbstractProcessor
emitFromTraverser, emitFromTraverser, emitFromTraverser, emitFromTraverserToSnapshot, flatMapper, flatMapper, flatMapper, getLogger, getOutbox, init, process, restoreFromSnapshot, restoreFromSnapshot, tryEmit, tryEmit, tryEmit, tryEmitToSnapshot, tryProcess, tryProcess0, tryProcess1, tryProcess2, tryProcess3, tryProcess4, tryProcessWatermark
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
completeEdge, finishSnapshotRestore, saveToSnapshot, snapshotCommitFinish, snapshotCommitPrepare, tryProcess
-
Method Details
-
init
- Overrides:
init
in classcom.hazelcast.jet.core.AbstractProcessor
- Throws:
IOException
-
complete
public boolean complete() -
isCooperative
public boolean isCooperative() -
close
public void close() -
supplier
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, String ownerId)
-