@Internal public class ScalaShellEnvironment extends ExecutionEnvironment
ExecutionEnvironment
that has a reference
to a FlinkILoop
. When execute is called this will
use the reference of the ILoop to write the compiled classes of the current session to
a Jar file and submit these with the program.lastJobExecutionResult, LOG
Constructor and Description |
---|
ScalaShellEnvironment(Configuration configuration,
org.apache.flink.api.scala.FlinkILoop flinkILoop,
String... jarFiles) |
Modifier and Type | Method and Description |
---|---|
static void |
disableAllContextAndOtherEnvironments() |
JobClient |
executeAsync(String jobName)
Triggers the program execution asynchronously.
|
static void |
resetContextEnvironments() |
addDefaultKryoSerializer, addDefaultKryoSerializer, areExplicitEnvironmentsAllowed, clearJobListeners, configure, createCollectionsEnvironment, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createProgramPlan, createProgramPlan, createProgramPlan, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, execute, execute, executeAsync, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getConfig, getConfiguration, getDefaultLocalParallelism, getExecutionEnvironment, getExecutionPlan, getExecutorServiceLoader, getJobListeners, getLastJobExecutionResult, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getUserCodeClassLoader, initializeContextEnvironment, readCsvFile, readFile, readFileOfPrimitives, readFileOfPrimitives, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerCachedFile, registerCachedFile, registerCachedFilesWithPlan, registerJobListener, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy
public ScalaShellEnvironment(Configuration configuration, org.apache.flink.api.scala.FlinkILoop flinkILoop, String... jarFiles)
public JobClient executeAsync(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.
executeAsync
in class ExecutionEnvironment
JobClient
that can be used to communicate with the submitted job, completed on submission succeeded.Exception
- Thrown, if the program submission fails.public static void disableAllContextAndOtherEnvironments()
public static void resetContextEnvironments()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.