public class CollectionTestEnvironment extends CollectionEnvironment
CollectionEnvironment
to be used in tests. The predominant feature of this class is that it allows setting
it as a context environment, causing it to be returned by ExecutionEnvironment.getExecutionEnvironment()
.
This also allows retrieving the JobExecutionResult
outside the actual program.jobID, lastJobExecutionResult, LOG, sessionTimeout
Constructor and Description |
---|
CollectionTestEnvironment() |
Modifier and Type | Method and Description |
---|---|
JobExecutionResult |
execute()
Triggers the program execution.
|
JobExecutionResult |
execute(String jobName)
Triggers the program execution.
|
JobExecutionResult |
getLastJobExecutionResult()
Returns the
JobExecutionResult of the last executed job. |
protected void |
setAsContext() |
protected static void |
unsetAsContext() |
getExecutionPlan, getParallelism, startNewSession
addDefaultKryoSerializer, addDefaultKryoSerializer, areExplicitEnvironmentsAllowed, createCollectionsEnvironment, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createProgramPlan, createProgramPlan, createProgramPlan, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getConfig, getDefaultLocalParallelism, getExecutionEnvironment, getId, getIdString, getNumberOfExecutionRetries, getRestartStrategy, getSessionTimeout, initializeContextEnvironment, readCsvFile, readFile, readFileOfPrimitives, readFileOfPrimitives, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerCachedFile, registerCachedFile, registerCachedFilesWithPlan, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setSessionTimeout
public JobExecutionResult getLastJobExecutionResult()
ExecutionEnvironment
JobExecutionResult
of the last executed job.getLastJobExecutionResult
in class ExecutionEnvironment
public JobExecutionResult execute() throws Exception
ExecutionEnvironment
DataSet.print()
,
writing results (e.g. DataSet.writeAsText(String)
,
DataSet.write(org.apache.flink.api.common.io.FileOutputFormat, String)
, or other generic
data sinks created with DataSet.output(org.apache.flink.api.common.io.OutputFormat)
.
The program execution will be logged and displayed with a generated default name.
execute
in class ExecutionEnvironment
Exception
- Thrown, if the program executions fails.public JobExecutionResult execute(String jobName) throws Exception
ExecutionEnvironment
DataSet.print()
,
writing results (e.g. DataSet.writeAsText(String)
,
DataSet.write(org.apache.flink.api.common.io.FileOutputFormat, String)
, or other generic
data sinks created with DataSet.output(org.apache.flink.api.common.io.OutputFormat)
.
The program execution will be logged and displayed with the given job name.
execute
in class CollectionEnvironment
Exception
- Thrown, if the program executions fails.protected void setAsContext()
protected static void unsetAsContext()
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.