OutputT
- the type of main output elements of the DoFn being usedpublic static class ParDoP.Supplier<InputT,OutputT>
extends java.lang.Object
Processor
supplier that will provide instances of ParDoP
.Modifier and Type | Field and Description |
---|---|
protected java.lang.String |
ownerId |
Constructor and Description |
---|
Supplier(java.lang.String stepId,
java.lang.String ownerId,
DoFn<InputT,OutputT> doFn,
WindowingStrategy<?,?> windowingStrategy,
DoFnSchemaInformation doFnSchemaInformation,
org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions,
TupleTag<OutputT> mainOutputTag,
java.util.Set<TupleTag<OutputT>> allOutputTags,
Coder<InputT> inputCoder,
java.util.Map<PCollectionView<?>,Coder<?>> sideInputCoders,
java.util.Map<TupleTag<?>,Coder<?>> outputCoders,
Coder<InputT> inputValueCoder,
java.util.Map<TupleTag<?>,Coder<?>> outputValueCoders,
java.util.Collection<PCollectionView<?>> sideInputs,
java.util.Map<java.lang.String,PCollectionView<?>> sideInputMapping) |
Modifier and Type | Method and Description |
---|---|
com.hazelcast.jet.core.Processor |
getEx() |
void |
isInboundEdgeOfVertex(com.hazelcast.jet.core.Edge edge,
java.lang.String edgeId,
java.lang.String pCollId,
java.lang.String vertexId) |
void |
isOutboundEdgeOfVertex(com.hazelcast.jet.core.Edge edge,
java.lang.String edgeId,
java.lang.String pCollId,
java.lang.String vertexId) |
public Supplier(java.lang.String stepId, java.lang.String ownerId, DoFn<InputT,OutputT> doFn, WindowingStrategy<?,?> windowingStrategy, DoFnSchemaInformation doFnSchemaInformation, org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions, TupleTag<OutputT> mainOutputTag, java.util.Set<TupleTag<OutputT>> allOutputTags, Coder<InputT> inputCoder, java.util.Map<PCollectionView<?>,Coder<?>> sideInputCoders, java.util.Map<TupleTag<?>,Coder<?>> outputCoders, Coder<InputT> inputValueCoder, java.util.Map<TupleTag<?>,Coder<?>> outputValueCoders, java.util.Collection<PCollectionView<?>> sideInputs, java.util.Map<java.lang.String,PCollectionView<?>> sideInputMapping)
public com.hazelcast.jet.core.Processor getEx()
getEx
in interface com.hazelcast.function.SupplierEx<com.hazelcast.jet.core.Processor>
public void isOutboundEdgeOfVertex(com.hazelcast.jet.core.Edge edge, java.lang.String edgeId, java.lang.String pCollId, java.lang.String vertexId)
isOutboundEdgeOfVertex
in interface DAGBuilder.WiringListener
public void isInboundEdgeOfVertex(com.hazelcast.jet.core.Edge edge, java.lang.String edgeId, java.lang.String pCollId, java.lang.String vertexId)
isInboundEdgeOfVertex
in interface DAGBuilder.WiringListener