<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
String sourceName) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
String sourceName,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.createInput(org.apache.flink.api.common.io.InputFormat<OUT,?> inputFormat) |
Generic method to create an input data stream with InputFormat .
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.createInput(org.apache.flink.api.common.io.InputFormat<OUT,?> inputFormat,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Generic method to create an input data stream with InputFormat .
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromCollection(Collection<OUT> data) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromCollection(Collection<OUT> data,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromCollection(Iterator<OUT> data,
Class<OUT> type) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromCollection(Iterator<OUT> data,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromData(Class<OUT> type,
OUT... data) |
Creates a new data stream that contains the given elements.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromData(Collection<OUT> data) |
Creates a new data stream that contains the given elements.The type of the data stream is
that of the elements in the collection.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromData(Collection<OUT> data,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Creates a new data stream that contains the given elements.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromData(org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo,
OUT... data) |
Creates a new data stream that contains the given elements.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromData(OUT... data) |
Creates a new data stream that contains the given elements.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromElements(Class<OUT> type,
OUT... data) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromElements(OUT... data) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromParallelCollection(org.apache.flink.util.SplittableIterator<OUT> iterator,
Class<OUT> type) |
Creates a new data stream that contains elements in the iterator.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromParallelCollection(org.apache.flink.util.SplittableIterator<OUT> iterator,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Creates a new data stream that contains elements in the iterator.
|
DataStreamSource<Long> |
StreamExecutionEnvironment.fromSequence(long from,
long to) |
Creates a new data stream that contains a sequence of numbers (longs) and is useful for
testing and for cases that just need a stream of N events of any kind.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(org.apache.flink.api.connector.source.Source<OUT,?,?> source,
org.apache.flink.api.common.eventtime.WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName) |
Adds a data Source to the environment to get a DataStream .
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(org.apache.flink.api.connector.source.Source<OUT,?,?> source,
org.apache.flink.api.common.eventtime.WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo) |
Adds a data Source to the environment to get a DataStream .
|
DataStreamSource<Long> |
StreamExecutionEnvironment.generateSequence(long from,
long to) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(org.apache.flink.api.common.io.FileInputFormat<OUT> inputFormat,
String filePath) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(org.apache.flink.api.common.io.FileInputFormat<OUT> inputFormat,
String filePath,
FileProcessingMode watchType,
long interval) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(org.apache.flink.api.common.io.FileInputFormat<OUT> inputFormat,
String filePath,
FileProcessingMode watchType,
long interval,
org.apache.flink.api.common.io.FilePathFilter filter) |
Deprecated.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.readFile(org.apache.flink.api.common.io.FileInputFormat<OUT> inputFormat,
String filePath,
FileProcessingMode watchType,
long interval,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInformation) |
Deprecated.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port) |
Creates a new data stream that contains the strings received infinitely from a socket.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port,
char delimiter) |
Deprecated.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port,
char delimiter,
long maxRetry) |
Deprecated.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port,
String delimiter) |
Creates a new data stream that contains the strings received infinitely from a socket.
|
DataStreamSource<String> |
StreamExecutionEnvironment.socketTextStream(String hostname,
int port,
String delimiter,
long maxRetry) |
Creates a new data stream that contains the strings received infinitely from a socket.
|