public class ApexRunner extends PipelineRunner<ApexRunnerResult>
PipelineRunner
that translates the pipeline to an Apex DAG and executes it on an Apex
cluster.Modifier and Type | Class and Description |
---|---|
static class |
ApexRunner.CreateApexPCollectionView<ElemT,ViewT>
Creates a primitive
PCollectionView . |
Modifier and Type | Field and Description |
---|---|
static java.util.concurrent.atomic.AtomicReference<java.lang.AssertionError> |
ASSERTION_ERROR
TODO: this isn't thread safe and may cause issues when tests run in parallel Holds any most
resent assertion error that was raised while processing elements.
|
static java.lang.String |
CLASSPATH_SCHEME |
protected boolean |
translateOnly |
Constructor and Description |
---|
ApexRunner(ApexPipelineOptions options) |
Modifier and Type | Method and Description |
---|---|
static ApexRunner |
fromOptions(PipelineOptions options) |
protected java.util.List<org.apache.beam.sdk.runners.PTransformOverride> |
getOverrides() |
ApexRunnerResult |
run(Pipeline pipeline)
Processes the given
Pipeline , potentially asynchronously, returning a runner-specific
type of result. |
create, run, run
public static final java.lang.String CLASSPATH_SCHEME
protected boolean translateOnly
public static final java.util.concurrent.atomic.AtomicReference<java.lang.AssertionError> ASSERTION_ERROR
public ApexRunner(ApexPipelineOptions options)
public static ApexRunner fromOptions(PipelineOptions options)
protected java.util.List<org.apache.beam.sdk.runners.PTransformOverride> getOverrides()
public ApexRunnerResult run(Pipeline pipeline)
PipelineRunner
Pipeline
, potentially asynchronously, returning a runner-specific
type of result.run
in class PipelineRunner<ApexRunnerResult>