public abstract class SparkPipelineResult extends java.lang.Object implements PipelineResult
PipelineResult.State| Modifier and Type | Field and Description | 
|---|---|
protected org.apache.spark.api.java.JavaSparkContext | 
javaSparkContext  | 
protected java.util.concurrent.Future | 
pipelineExecution  | 
protected PipelineResult.State | 
state  | 
| Modifier and Type | Method and Description | 
|---|---|
protected abstract PipelineResult.State | 
awaitTermination(Duration duration)  | 
PipelineResult.State | 
cancel()
Cancels the pipeline execution. 
 | 
PipelineResult.State | 
getState()
Retrieves the current state of the pipeline execution. 
 | 
MetricResults | 
metrics()
Returns the object to access metrics from the pipeline. 
 | 
protected abstract void | 
stop()  | 
PipelineResult.State | 
waitUntilFinish()
Waits until the pipeline finishes and returns the final status. 
 | 
PipelineResult.State | 
waitUntilFinish(Duration duration)
Waits until the pipeline finishes and returns the final status. 
 | 
protected final java.util.concurrent.Future pipelineExecution
protected org.apache.spark.api.java.JavaSparkContext javaSparkContext
protected PipelineResult.State state
protected abstract void stop()
protected abstract PipelineResult.State awaitTermination(Duration duration) throws java.util.concurrent.TimeoutException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.util.concurrent.TimeoutExceptionjava.util.concurrent.ExecutionExceptionjava.lang.InterruptedExceptionpublic PipelineResult.State getState()
PipelineResultgetState in interface PipelineResultPipelineResult.State representing the state of this pipeline.public PipelineResult.State waitUntilFinish()
PipelineResultwaitUntilFinish in interface PipelineResultpublic PipelineResult.State waitUntilFinish(Duration duration)
PipelineResultwaitUntilFinish in interface PipelineResultduration - The time to wait for the pipeline to finish. Provide a value less than 1 ms for
     an infinite wait.public MetricResults metrics()
PipelineResultmetrics in interface PipelineResultpublic PipelineResult.State cancel() throws java.io.IOException
PipelineResultcancel in interface PipelineResultjava.io.IOException - if there is a problem executing the cancel request.