@Deprecated @Public public class RemoteEnvironment extends ExecutionEnvironment
ExecutionEnvironment that sends programs to a cluster for execution. The environment
 needs to be created with the address and port of the JobManager of the Flink cluster that should
 execute the programs.
 Many programs executed via the remote environment depend on additional classes. Such classes may be the classes of functions (transformation, aggregation, ...) or libraries. Those classes must be attached to the remote environment as JAR files, to allow the environment to ship the classes into the cluster for the distributed execution.
lastJobExecutionResult, LOG| Constructor and Description | 
|---|
| RemoteEnvironment(String host,
                 int port,
                 org.apache.flink.configuration.Configuration clientConfig,
                 String[] jarFiles)Deprecated.  Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
 host name and port. | 
| RemoteEnvironment(String host,
                 int port,
                 org.apache.flink.configuration.Configuration clientConfig,
                 String[] jarFiles,
                 URL[] globalClasspaths)Deprecated.  Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
 host name and port. | 
| RemoteEnvironment(String host,
                 int port,
                 String... jarFiles)Deprecated.  Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
 host name and port. | 
| Modifier and Type | Method and Description | 
|---|---|
| String | toString()Deprecated.  | 
addDefaultKryoSerializer, addDefaultKryoSerializer, areExplicitEnvironmentsAllowed, clearJobListeners, configure, createCollectionsEnvironment, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createProgramPlan, createProgramPlan, createProgramPlan, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, execute, execute, executeAsync, 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, registerJobListener, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategypublic RemoteEnvironment(String host, int port, String... jarFiles)
Each program execution will have all the given JAR files in its classpath.
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.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.public RemoteEnvironment(String host, int port, org.apache.flink.configuration.Configuration clientConfig, String[] jarFiles)
Each program execution will have all the given JAR files in its classpath.
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.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.public RemoteEnvironment(String host, int port, org.apache.flink.configuration.Configuration clientConfig, String[] jarFiles, URL[] globalClasspaths)
Each program execution will have all the given JAR files in its classpath.
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.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.globalClasspaths - The paths of directories and JAR files that are added to each user
     code classloader on all nodes in the cluster. Note that the paths must specify a protocol
     (e.g. file://) and be accessible on all nodes (e.g. by means of a NFS share). The
     protocol must be supported by the URLClassLoader.Copyright © 2014–2025 The Apache Software Foundation. All rights reserved.