Package org.apache.beam.runners.spark
Class SparkRunnerDebugger
java.lang.Object
org.apache.beam.sdk.PipelineRunner<SparkPipelineResult>
org.apache.beam.runners.spark.SparkRunnerDebugger
Pipeline runner which translates a Beam pipeline into equivalent Spark operations, without
running them. Used for debugging purposes.
Example:
SparkPipelineOptions options = PipelineOptionsFactory.as(SparkPipelineOptions.class);
options.setRunner(SparkRunnerDebugger.class);
Pipeline pipeline = Pipeline.create(options);
SparkRunnerDebugger.DebugSparkPipelineResult result =
(SparkRunnerDebugger.DebugSparkPipelineResult) pipeline.run();
String sparkPipeline = result.getDebugString();
-
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionstatic class
PipelineResult of running aPipeline
usingSparkRunnerDebugger
UseSparkRunnerDebugger.DebugSparkPipelineResult.getDebugString()
to get aString
representation of thePipeline
translated into Spark native operations. -
Method Summary
Modifier and TypeMethodDescriptionstatic SparkRunnerDebugger
fromOptions
(PipelineOptions options) Processes the givenPipeline
, potentially asynchronously, returning a runner-specific type of result.Methods inherited from class org.apache.beam.sdk.PipelineRunner
create, run, run
-
Method Details
-
fromOptions
-
run
Description copied from class:PipelineRunner
Processes the givenPipeline
, potentially asynchronously, returning a runner-specific type of result.- Specified by:
run
in classPipelineRunner<SparkPipelineResult>
-