T
- Type of the elements in the DataStream created from the this source.public class DataStreamSource<T> extends SingleOutputStreamOperator<T,DataStreamSource<T>>
environment, transformation
Constructor and Description |
---|
DataStreamSource(StreamExecutionEnvironment environment,
org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo,
StreamSource<T> operator,
boolean isParallel,
String sourceName) |
Modifier and Type | Method and Description |
---|---|
DataStreamSource<T> |
setParallelism(int parallelism)
Sets the parallelism for this operator.
|
broadcast, disableChaining, forward, getName, global, isolateResources, name, rebalance, returns, returns, returns, setBufferTimeout, setConnectionType, shuffle, startNewChain, startNewResourceGroup
addSink, assignTimestamps, clean, coGroup, connect, countWindowAll, countWindowAll, filter, flatMap, getExecutionConfig, getExecutionEnvironment, getId, getParallelism, getTransformation, getType, iterate, iterate, join, keyBy, keyBy, keyBy, map, partitionByHash, partitionByHash, partitionByHash, partitionCustom, partitionCustom, partitionCustom, print, printToErr, project, split, timeWindowAll, timeWindowAll, transform, union, windowAll, write, writeAsCsv, writeAsCsv, writeAsCsv, writeAsCsv, writeAsText, writeAsText, writeAsText, writeAsText, writeToSocket
public DataStreamSource(StreamExecutionEnvironment environment, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, StreamSource<T> operator, boolean isParallel, String sourceName)
public DataStreamSource<T> setParallelism(int parallelism)
SingleOutputStreamOperator
setParallelism
in class SingleOutputStreamOperator<T,DataStreamSource<T>>
parallelism
- The parallelism for this operator.Copyright © 2014–2015 The Apache Software Foundation. All rights reserved.