T - Type of the elements in the DataStream created from the this source.@Public public class DataStreamSource<T> extends SingleOutputStreamOperator<T>
nonParallelenvironment, transformation| 构造器和说明 |
|---|
DataStreamSource(SingleOutputStreamOperator<T> operator)
Constructor for "deep" sources that manually set up (one or more) custom configured complex
operators.
|
DataStreamSource(StreamExecutionEnvironment environment,
org.apache.flink.api.connector.source.Source<T,?,?> source,
org.apache.flink.api.common.eventtime.WatermarkStrategy<T> watermarkStrategy,
org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo,
String sourceName)
Constructor for new Sources (FLIP-27).
|
DataStreamSource(StreamExecutionEnvironment environment,
org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo,
StreamSource<T,?> operator,
boolean isParallel,
String sourceName) |
DataStreamSource(StreamExecutionEnvironment environment,
org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo,
StreamSource<T,?> operator,
boolean isParallel,
String sourceName,
org.apache.flink.api.connector.source.Boundedness boundedness)
The constructor used to create legacy sources.
|
| 限定符和类型 | 方法和说明 |
|---|---|
DataStreamSource<T> |
setParallelism(int parallelism)
Sets the parallelism for this operator.
|
disableChaining, forceNonParallel, getName, getSideOutput, name, returns, returns, returns, setBufferTimeout, setMaxParallelism, setUidHash, slotSharingGroup, slotSharingGroup, startNewChain, uidaddSink, assignTimestampsAndWatermarks, assignTimestampsAndWatermarks, assignTimestampsAndWatermarks, broadcast, broadcast, clean, coGroup, connect, connect, countWindowAll, countWindowAll, doTransform, executeAndCollect, executeAndCollect, executeAndCollect, executeAndCollect, filter, flatMap, flatMap, forward, getExecutionConfig, getExecutionEnvironment, getId, getMinResources, getParallelism, getPreferredResources, getTransformation, getType, global, iterate, iterate, join, keyBy, keyBy, keyBy, keyBy, map, map, partitionCustom, partitionCustom, partitionCustom, print, print, printToErr, printToErr, process, process, project, rebalance, rescale, setConnectionType, shuffle, sinkTo, timeWindowAll, timeWindowAll, transform, transform, union, windowAll, writeAsCsv, writeAsCsv, writeAsCsv, writeAsText, writeAsText, writeToSocket, writeUsingOutputFormatpublic DataStreamSource(StreamExecutionEnvironment environment, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, StreamSource<T,?> operator, boolean isParallel, String sourceName)
public DataStreamSource(StreamExecutionEnvironment environment, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, StreamSource<T,?> operator, boolean isParallel, String sourceName, org.apache.flink.api.connector.source.Boundedness boundedness)
public DataStreamSource(SingleOutputStreamOperator<T> operator)
public DataStreamSource(StreamExecutionEnvironment environment, org.apache.flink.api.connector.source.Source<T,?,?> source, org.apache.flink.api.common.eventtime.WatermarkStrategy<T> watermarkStrategy, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, String sourceName)
public DataStreamSource<T> setParallelism(int parallelism)
SingleOutputStreamOperatorsetParallelism 在类中 SingleOutputStreamOperator<T>parallelism - The parallelism for this operator.Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.