Interface TransformTranslator.TranslationContext

Enclosing interface:
TransformTranslator<TransformT extends PTransform>

public static interface TransformTranslator.TranslationContext
The interface provided to registered callbacks for interacting with the DataflowRunner, including reading and writing the values of PCollections and side inputs.
  • Method Details

    • isStreamingEngine

      default boolean isStreamingEngine()
    • getPipelineOptions

      DataflowPipelineOptions getPipelineOptions()
      Returns the configured pipeline options.
    • getInputs

      <InputT extends PInput> Map<TupleTag<?>,PCollection<?>> getInputs(PTransform<InputT,?> transform)
      Returns the input of the currently being translated transform.
    • getInput

      <InputT extends PValue> InputT getInput(PTransform<InputT,?> transform)
    • getOutputs

      <OutputT extends POutput> Map<TupleTag<?>,PCollection<?>> getOutputs(PTransform<?,OutputT> transform)
      Returns the output of the currently being translated transform.
    • getOutput

      <OutputT extends PValue> OutputT getOutput(PTransform<?,OutputT> transform)
    • getFullName

      String getFullName(PTransform<?,?> transform)
      Returns the full name of the currently being translated transform.
    • addStep

      Adds a step to the Dataflow workflow for the given transform, with the given Dataflow step type.
    • asOutputReference

      OutputReference asOutputReference(PValue value, org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> producer)
      Encode a PValue reference as an output reference.
    • getSdkComponents

      org.apache.beam.sdk.util.construction.SdkComponents getSdkComponents()
    • getCurrentTransform

      org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> getCurrentTransform()
    • getProducer

      org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> getProducer(PValue value)
      Get the AppliedPTransform that produced the provided PValue.
    • getCurrentParent

      org.apache.beam.sdk.runners.AppliedPTransform<?,?,?> getCurrentParent()
      Gets the parent composite transform to the current transform, if one exists. Otherwise returns one null.