Class DataflowPipelineTranslator.JobSpecification

java.lang.Object
org.apache.beam.runners.dataflow.DataflowPipelineTranslator.JobSpecification
Enclosing class:
DataflowPipelineTranslator

public static class DataflowPipelineTranslator.JobSpecification extends Object
The result of a job translation.

Used to pass the result Job and any state that was used to construct the job that may be of use to other classes (eg the PTransform to StepName mapping).

  • Constructor Details

    • JobSpecification

      public JobSpecification(Job job, org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline pipelineProto, Map<org.apache.beam.sdk.runners.AppliedPTransform<?,?,?>,String> stepNames)
  • Method Details

    • getJob

      public Job getJob()
    • getPipelineProto

      public org.apache.beam.model.pipeline.v1.RunnerApi.Pipeline getPipelineProto()
    • getStepNames

      public Map<org.apache.beam.sdk.runners.AppliedPTransform<?,?,?>,String> getStepNames()
      Returns the mapping of AppliedPTransforms to the internal step name for that AppliedPTransform.