Class PipelineTranslatorUtils
java.lang.Object
org.apache.beam.runners.fnexecution.translation.PipelineTranslatorUtils
Utilities for pipeline translation.
-
Method Summary
Modifier and TypeMethodDescriptioncreateOutputMap
(Iterable<String> localOutputs) Creates a mapping from PCollection id to output tag integer.static void
fireEligibleTimers
(org.apache.beam.runners.core.InMemoryTimerInternals timerInternals, Map<KV<String, String>, FnDataReceiver<org.apache.beam.sdk.util.construction.Timer>> timerReceivers, Object currentTimerKey) Fires all timers which are ready to be fired.static String
getExecutableStageIntermediateId
(org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode transformNode) static String
getInputId
(org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode transformNode) static String
getOutputId
(org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode transformNode) static <T> WindowedValues.WindowedValueCoder
<T> getWindowedValueCoder
(String pCollectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components) static WindowingStrategy
getWindowingStrategy
(String pCollectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components) static boolean
hasUnboundedPCollections
(org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipeline) Indicates whether the given pipeline has any unbounded PCollections.static <T> Coder
<WindowedValue<T>> instantiateCoder
(String collectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components) Creates a coder for a given PCollection id from the Proto definition.
-
Method Details
-
createOutputMap
public static org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.BiMap<String,Integer> createOutputMap(Iterable<String> localOutputs) Creates a mapping from PCollection id to output tag integer. -
instantiateCoder
public static <T> Coder<WindowedValue<T>> instantiateCoder(String collectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components) Creates a coder for a given PCollection id from the Proto definition. -
getWindowingStrategy
public static WindowingStrategy getWindowingStrategy(String pCollectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components) -
hasUnboundedPCollections
public static boolean hasUnboundedPCollections(org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipeline) Indicates whether the given pipeline has any unbounded PCollections. -
fireEligibleTimers
public static void fireEligibleTimers(org.apache.beam.runners.core.InMemoryTimerInternals timerInternals, Map<KV<String, String>, FnDataReceiver<org.apache.beam.sdk.util.construction.Timer>> timerReceivers, Object currentTimerKey) Fires all timers which are ready to be fired. This is done in a loop because timers may itself schedule timers. -
getWindowedValueCoder
public static <T> WindowedValues.WindowedValueCoder<T> getWindowedValueCoder(String pCollectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components) -
getInputId
public static String getInputId(org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode transformNode) -
getOutputId
public static String getOutputId(org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode transformNode) -
getExecutableStageIntermediateId
public static String getExecutableStageIntermediateId(org.apache.beam.sdk.util.construction.graph.PipelineNode.PTransformNode transformNode)
-