Class ParDoP.Supplier<InputT,OutputT>
java.lang.Object
org.apache.beam.runners.jet.processors.ParDoP.Supplier<InputT,OutputT>
- Type Parameters:
OutputT
- the type of main output elements of the DoFn being used
- All Implemented Interfaces:
com.hazelcast.function.SupplierEx<com.hazelcast.jet.core.Processor>
,Serializable
,Supplier<com.hazelcast.jet.core.Processor>
,DAGBuilder.WiringListener
Jet
Processor
supplier that will provide instances of ParDoP
.- See Also:
-
Field Summary
Fields -
Constructor Summary
ConstructorsConstructorDescriptionSupplier
(String stepId, String ownerId, DoFn<InputT, OutputT> doFn, WindowingStrategy<?, ?> windowingStrategy, DoFnSchemaInformation doFnSchemaInformation, org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions, TupleTag<OutputT> mainOutputTag, Set<TupleTag<OutputT>> allOutputTags, Coder<InputT> inputCoder, Map<PCollectionView<?>, Coder<?>> sideInputCoders, Map<TupleTag<?>, Coder<?>> outputCoders, Coder<InputT> inputValueCoder, Map<TupleTag<?>, Coder<?>> outputValueCoders, Collection<PCollectionView<?>> sideInputs, Map<String, PCollectionView<?>> sideInputMapping) -
Method Summary
Modifier and TypeMethodDescriptioncom.hazelcast.jet.core.Processor
getEx()
void
isInboundEdgeOfVertex
(com.hazelcast.jet.core.Edge edge, String edgeId, String pCollId, String vertexId) void
isOutboundEdgeOfVertex
(com.hazelcast.jet.core.Edge edge, String edgeId, String pCollId, String vertexId) Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface com.hazelcast.function.SupplierEx
get
-
Field Details
-
ownerId
-
-
Constructor Details
-
Supplier
public Supplier(String stepId, String ownerId, DoFn<InputT, OutputT> doFn, WindowingStrategy<?, ?> windowingStrategy, DoFnSchemaInformation doFnSchemaInformation, org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions, TupleTag<OutputT> mainOutputTag, Set<TupleTag<OutputT>> allOutputTags, Coder<InputT> inputCoder, Map<PCollectionView<?>, Coder<?>> sideInputCoders, Map<TupleTag<?>, Coder<?>> outputCoders, Coder<InputT> inputValueCoder, Map<TupleTag<?>, Coder<?>> outputValueCoders, Collection<PCollectionView<?>> sideInputs, Map<String, PCollectionView<?>> sideInputMapping)
-
-
Method Details
-
getEx
public com.hazelcast.jet.core.Processor getEx()- Specified by:
getEx
in interfacecom.hazelcast.function.SupplierEx<InputT>
-
isOutboundEdgeOfVertex
public void isOutboundEdgeOfVertex(com.hazelcast.jet.core.Edge edge, String edgeId, String pCollId, String vertexId) - Specified by:
isOutboundEdgeOfVertex
in interfaceDAGBuilder.WiringListener
-
isInboundEdgeOfVertex
public void isInboundEdgeOfVertex(com.hazelcast.jet.core.Edge edge, String edgeId, String pCollId, String vertexId) - Specified by:
isInboundEdgeOfVertex
in interfaceDAGBuilder.WiringListener
-