Class StatefulParDoP<OutputT>

java.lang.Object
org.apache.beam.runners.jet.processors.StatefulParDoP<OutputT>
All Implemented Interfaces:
com.hazelcast.jet.core.Processor

public class StatefulParDoP<OutputT> extends Object
Jet Processor implementation for Beam's stateful ParDo primitive.
  • Method Details

    • getDoFnRunner

      protected org.apache.beam.runners.core.DoFnRunner<KV<?,?>,OutputT> 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)
    • startRunnerBundle

      protected void startRunnerBundle(org.apache.beam.runners.core.DoFnRunner<KV<?,?>,OutputT> runner)
    • processElementWithRunner

      protected void processElementWithRunner(org.apache.beam.runners.core.DoFnRunner<KV<?,?>,OutputT> runner, WindowedValue<KV<?,?>> windowedValue)
    • tryProcessWatermark

      public boolean tryProcessWatermark(@Nonnull com.hazelcast.jet.core.Watermark watermark)
      Specified by:
      tryProcessWatermark in interface com.hazelcast.jet.core.Processor
    • complete

      public boolean complete()
      Specified by:
      complete in interface com.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 interface com.hazelcast.jet.core.Processor
    • isCooperative

      public boolean isCooperative()
      Specified by:
      isCooperative in interface com.hazelcast.jet.core.Processor
    • close

      public void close()
      Specified by:
      close in interface com.hazelcast.jet.core.Processor
    • process

      public void process(int ordinal, @Nonnull com.hazelcast.jet.core.Inbox inbox)
      Specified by:
      process in interface com.hazelcast.jet.core.Processor
    • finishRunnerBundle

      protected void finishRunnerBundle(org.apache.beam.runners.core.DoFnRunner<KV<?,?>,OutputT> runner)
    • tryProcess

      public boolean tryProcess()
      Specified by:
      tryProcess in interface com.hazelcast.jet.core.Processor
    • completeEdge

      public boolean completeEdge(int ordinal)
      Specified by:
      completeEdge in interface com.hazelcast.jet.core.Processor