public class ScalaShellRemoteStreamEnvironment
extends org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
RemoteStreamEnvironment for the Scala shell.| Constructor and Description |
|---|
ScalaShellRemoteStreamEnvironment(String host,
int port,
org.apache.flink.api.scala.FlinkILoop flinkILoop,
org.apache.flink.configuration.Configuration configuration,
String... jarFiles)
Creates a new RemoteStreamEnvironment that points to the master
(JobManager) described by the given host name and port.
|
| Modifier and Type | Method and Description |
|---|---|
static void |
disableAllContextAndOtherEnvironments() |
protected org.apache.flink.api.common.JobExecutionResult |
executeRemotely(org.apache.flink.streaming.api.graph.StreamGraph streamGraph,
List<URL> jarFiles)
Executes the remote job.
|
static void |
resetContextEnvironments() |
void |
setAsContext() |
execute, executeRemotely, getClientConfiguration, getHost, getPort, toStringaddDefaultKryoSerializer, addDefaultKryoSerializer, addOperator, addSource, addSource, addSource, addSource, clean, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, disableOperatorChaining, enableCheckpointing, enableCheckpointing, enableCheckpointing, enableCheckpointing, execute, execute, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getBufferTimeout, getCachedFiles, getCheckpointConfig, getCheckpointingMode, getCheckpointInterval, getConfig, getDefaultLocalParallelism, getExecutionEnvironment, getExecutionPlan, getMaxParallelism, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getStateBackend, getStreamGraph, getStreamGraph, getStreamTimeCharacteristic, initializeContextEnvironment, isChainingEnabled, isForceCheckpointing, readFile, readFile, readFile, readFile, readFileStream, readTextFile, readTextFile, registerCachedFile, registerCachedFile, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setBufferTimeout, setDefaultLocalParallelism, setMaxParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setStateBackend, setStateBackend, setStreamTimeCharacteristic, socketTextStream, socketTextStream, socketTextStream, socketTextStream, socketTextStreampublic ScalaShellRemoteStreamEnvironment(String host, int port, org.apache.flink.api.scala.FlinkILoop flinkILoop, org.apache.flink.configuration.Configuration configuration, String... jarFiles)
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.configuration - The configuration to be used for the environmentjarFiles - 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 beprotected org.apache.flink.api.common.JobExecutionResult executeRemotely(org.apache.flink.streaming.api.graph.StreamGraph streamGraph,
List<URL> jarFiles)
throws org.apache.flink.client.program.ProgramInvocationException
executeRemotely in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironmentstreamGraph - Stream Graph to executejarFiles - List of jar file URLs to ship to the clusterorg.apache.flink.client.program.ProgramInvocationExceptionpublic void setAsContext()
public static void disableAllContextAndOtherEnvironments()
public static void resetContextEnvironments()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.