public class ParDoP<InputT,OutputT>
extends java.lang.Object
Processor
implementation for Beam's ParDo primitive (when no
user-state is being used).Modifier and Type | Class and Description |
---|---|
static class |
ParDoP.Supplier<InputT,OutputT>
Jet
Processor supplier that will provide instances of ParDoP . |
Modifier and Type | Method and Description |
---|---|
void |
close() |
boolean |
complete() |
boolean |
completeEdge(int ordinal) |
protected void |
finishRunnerBundle(org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> runner) |
protected org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> |
getDoFnRunner(PipelineOptions pipelineOptions,
DoFn<InputT,OutputT> doFn,
org.apache.beam.runners.core.SideInputReader sideInputReader,
org.apache.beam.runners.jet.processors.AbstractParDoP.JetOutputManager outputManager,
TupleTag<OutputT> mainOutputTag,
java.util.List<TupleTag<?>> additionalOutputTags,
Coder<InputT> inputValueCoder,
java.util.Map<TupleTag<?>,Coder<?>> outputValueCoders,
WindowingStrategy<?,?> windowingStrategy,
DoFnSchemaInformation doFnSchemaInformation,
java.util.Map<java.lang.String,PCollectionView<?>> sideInputMapping) |
void |
init(com.hazelcast.jet.core.Outbox outbox,
com.hazelcast.jet.core.Processor.Context context) |
boolean |
isCooperative() |
void |
process(int ordinal,
com.hazelcast.jet.core.Inbox inbox) |
protected void |
processElementWithRunner(org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> runner,
org.apache.beam.sdk.util.WindowedValue<InputT> windowedValue) |
protected void |
startRunnerBundle(org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> runner) |
boolean |
tryProcess() |
boolean |
tryProcessWatermark(com.hazelcast.jet.core.Watermark watermark) |
protected org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> getDoFnRunner(PipelineOptions pipelineOptions, DoFn<InputT,OutputT> doFn, org.apache.beam.runners.core.SideInputReader sideInputReader, org.apache.beam.runners.jet.processors.AbstractParDoP.JetOutputManager outputManager, TupleTag<OutputT> mainOutputTag, java.util.List<TupleTag<?>> additionalOutputTags, Coder<InputT> inputValueCoder, java.util.Map<TupleTag<?>,Coder<?>> outputValueCoders, WindowingStrategy<?,?> windowingStrategy, DoFnSchemaInformation doFnSchemaInformation, java.util.Map<java.lang.String,PCollectionView<?>> sideInputMapping)
public void init(@Nonnull com.hazelcast.jet.core.Outbox outbox, @Nonnull com.hazelcast.jet.core.Processor.Context context)
init
in interface com.hazelcast.jet.core.Processor
public boolean isCooperative()
isCooperative
in interface com.hazelcast.jet.core.Processor
public void close()
close
in interface com.hazelcast.jet.core.Processor
public void process(int ordinal, @Nonnull com.hazelcast.jet.core.Inbox inbox)
process
in interface com.hazelcast.jet.core.Processor
protected void startRunnerBundle(org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> runner)
protected void processElementWithRunner(org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> runner, org.apache.beam.sdk.util.WindowedValue<InputT> windowedValue)
protected void finishRunnerBundle(org.apache.beam.runners.core.DoFnRunner<InputT,OutputT> runner)
public boolean tryProcess()
tryProcess
in interface com.hazelcast.jet.core.Processor
public boolean tryProcessWatermark(@Nonnull com.hazelcast.jet.core.Watermark watermark)
tryProcessWatermark
in interface com.hazelcast.jet.core.Processor
public boolean completeEdge(int ordinal)
completeEdge
in interface com.hazelcast.jet.core.Processor
public boolean complete()
complete
in interface com.hazelcast.jet.core.Processor