public class ScalaShellRemoteStreamEnvironment extends RemoteStreamEnvironment
RemoteStreamEnvironment
for the Scala shell.cacheFile, DEFAULT_JOB_NAME, isChainingEnabled, transformations
Constructor and Description |
---|
ScalaShellRemoteStreamEnvironment(String host,
int port,
org.apache.flink.api.scala.FlinkILoop flinkILoop,
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 JobExecutionResult |
executeRemotely(StreamGraph streamGraph,
List<URL> jarFiles)
Executes the remote job.
|
static void |
resetContextEnvironments() |
void |
setAsContext() |
execute, getClientConfiguration, getHost, getPort, toString
addDefaultKryoSerializer, addDefaultKryoSerializer, addOperator, addSource, addSource, addSource, addSource, clean, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, disableOperatorChaining, enableCheckpointing, enableCheckpointing, enableCheckpointing, enableCheckpointing, 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, 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, socketTextStream
public ScalaShellRemoteStreamEnvironment(String host, int port, org.apache.flink.api.scala.FlinkILoop flinkILoop, 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 JobExecutionResult executeRemotely(StreamGraph streamGraph, List<URL> jarFiles) throws ProgramInvocationException
executeRemotely
in class RemoteStreamEnvironment
streamGraph
- Stream Graph to executejarFiles
- List of jar file URLs to ship to the clusterProgramInvocationException
public void setAsContext()
public static void disableAllContextAndOtherEnvironments()
public static void resetContextEnvironments()
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.