public class ScalaShellRemoteEnvironment
extends org.apache.flink.api.java.RemoteEnvironment
RemoteEnvironment 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.| Constructor and Description |
|---|
ScalaShellRemoteEnvironment(String host,
int port,
org.apache.flink.api.scala.FlinkILoop flinkILoop,
org.apache.flink.configuration.Configuration clientConfig,
String... jarFiles)
Creates new ScalaShellRemoteEnvironment that has a reference to the FlinkILoop.
|
| Modifier and Type | Method and Description |
|---|---|
static void |
disableAllContextAndOtherEnvironments() |
protected org.apache.flink.api.common.PlanExecutor |
getExecutor() |
static void |
resetContextEnvironments() |
dispose, execute, getExecutionPlan, startNewSession, toStringaddDefaultKryoSerializer, 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, setSessionTimeoutpublic ScalaShellRemoteEnvironment(String host, int port, org.apache.flink.api.scala.FlinkILoop flinkILoop, org.apache.flink.configuration.Configuration clientConfig, String... jarFiles) throws Exception
host - The host name or address of the master (JobManager), where the program should be executed.port - The port of the master (JobManager), where the program should be executed.flinkILoop - The flink Iloop instance from which the ScalaShellRemoteEnvironment is called.clientConfig - The configuration used by the client that connects to the cluster.jarFiles - The JAR files with code that needs to be shipped to the cluster. If the program uses
user-defined functions, user-defined input formats, or any libraries, those must be
provided in the JAR files.Exceptionprotected org.apache.flink.api.common.PlanExecutor getExecutor()
throws Exception
getExecutor in class org.apache.flink.api.java.RemoteEnvironmentExceptionpublic static void disableAllContextAndOtherEnvironments()
public static void resetContextEnvironments()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.