Class DataStreamSource<T>

  • Type Parameters:
    T - Type of the elements in the DataStream created from the this source.

    @Public
    public class DataStreamSource<T>
    extends SingleOutputStreamOperator<T>
    The DataStreamSource represents the starting point of a DataStream.
    • Constructor Detail

      • DataStreamSource

        public DataStreamSource​(StreamExecutionEnvironment environment,
                                org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo,
                                StreamSource<T,​?> operator,
                                boolean isParallel,
                                String sourceName)
      • DataStreamSource

        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)
        The constructor used to create legacy sources.
      • DataStreamSource

        public DataStreamSource​(SingleOutputStreamOperator<T> operator)
        Constructor for "deep" sources that manually set up (one or more) custom configured complex operators.
      • DataStreamSource

        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)
        Constructor for new Sources (FLIP-27).