Class StatefulParDoP<OutputT>
java.lang.Object
org.apache.beam.runners.jet.processors.StatefulParDoP<OutputT>
- All Implemented Interfaces:
com.hazelcast.jet.core.Processor
Jet
Processor
implementation for Beam's stateful ParDo primitive.-
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionstatic class
JetProcessor
supplier that will provide instances ofStatefulParDoP
.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()
boolean
completeEdge
(int ordinal) protected void
finishRunnerBundle
(org.apache.beam.runners.core.DoFnRunner<KV<?, ?>, OutputT> runner) getDoFnRunner
(PipelineOptions pipelineOptions, DoFn<KV<?, ?>, OutputT> doFn, org.apache.beam.runners.core.SideInputReader sideInputReader, org.apache.beam.runners.jet.processors.AbstractParDoP.JetOutputManager outputManager, TupleTag<OutputT> mainOutputTag, List<TupleTag<?>> additionalOutputTags, Coder<KV<?, ?>> inputValueCoder, Map<TupleTag<?>, Coder<?>> outputValueCoders, WindowingStrategy<?, ?> windowingStrategy, DoFnSchemaInformation doFnSchemaInformation, Map<String, PCollectionView<?>> sideInputMapping) void
init
(com.hazelcast.jet.core.Outbox outbox, com.hazelcast.jet.core.Processor.Context context) boolean
void
process
(int ordinal, com.hazelcast.jet.core.Inbox inbox) protected void
processElementWithRunner
(org.apache.beam.runners.core.DoFnRunner<KV<?, ?>, OutputT> runner, WindowedValue<KV<?, ?>> windowedValue) protected void
startRunnerBundle
(org.apache.beam.runners.core.DoFnRunner<KV<?, ?>, OutputT> runner) boolean
boolean
tryProcessWatermark
(com.hazelcast.jet.core.Watermark watermark) 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
finishSnapshotRestore, restoreFromSnapshot, saveToSnapshot, snapshotCommitFinish, snapshotCommitPrepare
-
Method Details
-
getDoFnRunner
protected org.apache.beam.runners.core.DoFnRunner<KV<?,?>, getDoFnRunnerOutputT> (PipelineOptions pipelineOptions, DoFn<KV<?, ?>, OutputT> doFn, org.apache.beam.runners.core.SideInputReader sideInputReader, org.apache.beam.runners.jet.processors.AbstractParDoP.JetOutputManager outputManager, TupleTag<OutputT> mainOutputTag, List<TupleTag<?>> additionalOutputTags, Coder<KV<?, ?>> inputValueCoder, Map<TupleTag<?>, Coder<?>> outputValueCoders, WindowingStrategy<?, ?> windowingStrategy, DoFnSchemaInformation doFnSchemaInformation, Map<String, PCollectionView<?>> sideInputMapping) -
startRunnerBundle
-
processElementWithRunner
protected void processElementWithRunner(org.apache.beam.runners.core.DoFnRunner<KV<?, ?>, OutputT> runner, WindowedValue<KV<?, ?>> windowedValue) -
tryProcessWatermark
- Specified by:
tryProcessWatermark
in interfacecom.hazelcast.jet.core.Processor
-
complete
public boolean complete()- Specified by:
complete
in interfacecom.hazelcast.jet.core.Processor
-
init
public void init(@Nonnull com.hazelcast.jet.core.Outbox outbox, @Nonnull com.hazelcast.jet.core.Processor.Context context) - Specified by:
init
in interfacecom.hazelcast.jet.core.Processor
-
isCooperative
public boolean isCooperative()- Specified by:
isCooperative
in interfacecom.hazelcast.jet.core.Processor
-
close
public void close()- Specified by:
close
in interfacecom.hazelcast.jet.core.Processor
-
process
- Specified by:
process
in interfacecom.hazelcast.jet.core.Processor
-
finishRunnerBundle
-
tryProcess
public boolean tryProcess()- Specified by:
tryProcess
in interfacecom.hazelcast.jet.core.Processor
-
completeEdge
public boolean completeEdge(int ordinal) - Specified by:
completeEdge
in interfacecom.hazelcast.jet.core.Processor
-