public static interface TransformTranslator.TranslationContext
DataflowRunner
,
including reading and writing the values of PCollection
s and side inputs.Modifier and Type | Method and Description |
---|---|
TransformTranslator.StepTranslationContext |
addStep(PTransform<?,?> transform,
java.lang.String type)
Adds a step to the Dataflow workflow for the given transform, with the given Dataflow step
type.
|
OutputReference |
asOutputReference(PValue value,
org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> producer)
Encode a PValue reference as an output reference.
|
org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> |
getCurrentParent()
Gets the parent composite transform to the current transform, if one exists.
|
org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> |
getCurrentTransform() |
java.lang.String |
getFullName(PTransform<?,?> transform)
Returns the full name of the currently being translated transform.
|
<InputT extends PValue> |
getInput(PTransform<InputT,?> transform) |
<InputT extends PInput> |
getInputs(PTransform<InputT,?> transform)
Returns the input of the currently being translated transform.
|
<OutputT extends PValue> |
getOutput(PTransform<?,OutputT> transform) |
<OutputT extends POutput> |
getOutputs(PTransform<?,OutputT> transform)
Returns the output of the currently being translated transform.
|
DataflowPipelineOptions |
getPipelineOptions()
Returns the configured pipeline options.
|
org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> |
getProducer(PValue value)
Get the
AppliedPTransform that produced the provided PValue . |
org.apache.beam.runners.core.construction.SdkComponents |
getSdkComponents() |
default boolean |
isStreamingEngine() |
default boolean isStreamingEngine()
DataflowPipelineOptions getPipelineOptions()
<InputT extends PInput> java.util.Map<TupleTag<?>,PCollection<?>> getInputs(PTransform<InputT,?> transform)
<InputT extends PValue> InputT getInput(PTransform<InputT,?> transform)
<OutputT extends POutput> java.util.Map<TupleTag<?>,PCollection<?>> getOutputs(PTransform<?,OutputT> transform)
<OutputT extends PValue> OutputT getOutput(PTransform<?,OutputT> transform)
java.lang.String getFullName(PTransform<?,?> transform)
TransformTranslator.StepTranslationContext addStep(PTransform<?,?> transform, java.lang.String type)
OutputReference asOutputReference(PValue value, org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> producer)
org.apache.beam.runners.core.construction.SdkComponents getSdkComponents()
org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> getCurrentTransform()
org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> getProducer(PValue value)
AppliedPTransform
that produced the provided PValue
.org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> getCurrentParent()