public final class PipelineTranslatorUtils
extends java.lang.Object
| Modifier and Type | Method and Description | 
|---|---|
static org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.BiMap<java.lang.String,java.lang.Integer> | 
createOutputMap(java.lang.Iterable<java.lang.String> localOutputs)
Creates a mapping from PCollection id to output tag integer. 
 | 
static void | 
fireEligibleTimers(org.apache.beam.runners.core.InMemoryTimerInternals timerInternals,
                  java.util.Map<KV<java.lang.String,java.lang.String>,FnDataReceiver<org.apache.beam.runners.core.construction.Timer>> timerReceivers,
                  java.lang.Object currentTimerKey)
Fires all timers which are ready to be fired. 
 | 
static java.lang.String | 
getExecutableStageIntermediateId(org.apache.beam.runners.core.construction.graph.PipelineNode.PTransformNode transformNode)  | 
static java.lang.String | 
getInputId(org.apache.beam.runners.core.construction.graph.PipelineNode.PTransformNode transformNode)  | 
static java.lang.String | 
getOutputId(org.apache.beam.runners.core.construction.graph.PipelineNode.PTransformNode transformNode)  | 
static <T> org.apache.beam.sdk.util.WindowedValue.WindowedValueCoder<T> | 
getWindowedValueCoder(java.lang.String pCollectionId,
                     org.apache.beam.model.pipeline.v1.RunnerApi.Components components)  | 
static WindowingStrategy | 
getWindowingStrategy(java.lang.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<org.apache.beam.sdk.util.WindowedValue<T>> | 
instantiateCoder(java.lang.String collectionId,
                org.apache.beam.model.pipeline.v1.RunnerApi.Components components)
Creates a coder for a given PCollection id from the Proto definition. 
 | 
public static org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.BiMap<java.lang.String,java.lang.Integer> createOutputMap(java.lang.Iterable<java.lang.String> localOutputs)
public static <T> Coder<org.apache.beam.sdk.util.WindowedValue<T>> instantiateCoder(java.lang.String collectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components)
public static WindowingStrategy getWindowingStrategy(java.lang.String pCollectionId, org.apache.beam.model.pipeline.v1.RunnerApi.Components components)
public static boolean hasUnboundedPCollections(org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipeline)
public static void fireEligibleTimers(org.apache.beam.runners.core.InMemoryTimerInternals timerInternals,
                                      java.util.Map<KV<java.lang.String,java.lang.String>,FnDataReceiver<org.apache.beam.runners.core.construction.Timer>> timerReceivers,
                                      java.lang.Object currentTimerKey)
public static <T> org.apache.beam.sdk.util.WindowedValue.WindowedValueCoder<T> getWindowedValueCoder(java.lang.String pCollectionId,
                                                                                                     org.apache.beam.model.pipeline.v1.RunnerApi.Components components)
public static java.lang.String getInputId(org.apache.beam.runners.core.construction.graph.PipelineNode.PTransformNode transformNode)
public static java.lang.String getOutputId(org.apache.beam.runners.core.construction.graph.PipelineNode.PTransformNode transformNode)
public static java.lang.String getExecutableStageIntermediateId(org.apache.beam.runners.core.construction.graph.PipelineNode.PTransformNode transformNode)