public class DetachedEnvironment extends ContextEnvironment
Modifier and Type | Class and Description |
---|---|
static class |
DetachedEnvironment.DetachedJobExecutionResult
The
JobExecutionResult returned by a DetachedEnvironment . |
classpathsToAttach, client, jarFilesToAttach, savepointSettings, userCodeClassLoader
jobID, lastJobExecutionResult, sessionTimeout
Constructor and Description |
---|
DetachedEnvironment(ClusterClient remoteConnection,
List<URL> jarFiles,
List<URL> classpaths,
ClassLoader userCodeClassLoader,
SavepointRestoreSettings savepointSettings) |
Modifier and Type | Method and Description |
---|---|
JobExecutionResult |
execute(String jobName)
Triggers the program execution.
|
void |
setDetachedPlan(FlinkPlan plan) |
getClasspaths, getClient, getExecutionPlan, getJars, getSavepointRestoreSettings, getUserCodeClassLoader, startNewSession, toString
addDefaultKryoSerializer, addDefaultKryoSerializer, areExplicitEnvironmentsAllowed, createCollectionsEnvironment, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createProgramPlan, createProgramPlan, createProgramPlan, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, execute, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getConfig, getDefaultLocalParallelism, getExecutionEnvironment, getId, getIdString, getLastJobExecutionResult, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getSessionTimeout, initializeContextEnvironment, readCsvFile, readFile, readFileOfPrimitives, readFileOfPrimitives, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerCachedFile, registerCachedFile, registerCachedFilesWithPlan, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setSessionTimeout
public DetachedEnvironment(ClusterClient remoteConnection, List<URL> jarFiles, List<URL> classpaths, ClassLoader userCodeClassLoader, SavepointRestoreSettings savepointSettings)
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 ContextEnvironment
Exception
- Thrown, if the program executions fails.public void setDetachedPlan(FlinkPlan plan)
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.