public class StreamContextEnvironment extends StreamExecutionEnvironment
checkpointingMode, checkpointInterval, DEFAULT_JOB_NAME, forceCheckpointing, isChainingEnabled, transformations
Modifier | Constructor and Description |
---|---|
protected |
StreamContextEnvironment(org.apache.flink.client.program.Client client,
List<URL> jars,
List<URL> classpaths,
int parallelism,
boolean wait) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.JobExecutionResult |
execute()
Triggers the program execution.
|
org.apache.flink.api.common.JobExecutionResult |
execute(String jobName)
Triggers the program execution.
|
addDefaultKryoSerializer, addDefaultKryoSerializer, addOperator, addSource, addSource, addSource, addSource, clean, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, disableOperatorChaining, enableCheckpointing, enableCheckpointing, enableCheckpointing, enableCheckpointing, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getBufferTimeout, getCheckpointingMode, getCheckpointInterval, getConfig, getExecutionEnvironment, getExecutionPlan, getNumberOfExecutionRetries, getParallelism, getStateBackend, getStreamGraph, getStreamTimeCharacteristic, initializeContextEnvironment, isChainingEnabled, isForceCheckpointing, readFile, readFileOfPrimitives, readFileOfPrimitives, readFileStream, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setBufferTimeout, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setStateBackend, setStreamTimeCharacteristic, socketTextStream, socketTextStream, socketTextStream
public org.apache.flink.api.common.JobExecutionResult execute() throws Exception
StreamExecutionEnvironment
The program execution will be logged and displayed with a generated default name.
execute
in class StreamExecutionEnvironment
Exception
- which occurs during job execution.public org.apache.flink.api.common.JobExecutionResult execute(String jobName) throws Exception
StreamExecutionEnvironment
The program execution will be logged and displayed with the provided name
execute
in class StreamExecutionEnvironment
jobName
- Desired name of the jobException
- which occurs during job execution.Copyright © 2014–2015 The Apache Software Foundation. All rights reserved.