Modifier and Type | Class and Description |
---|---|
class |
NumberSequenceSource
A data source that produces a sequence of numbers (longs).
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractFileSource<T,SplitT extends FileSourceSplit>
The base class for File Sources.
|
class |
FileSource<T>
A unified data source that reads files - both in batch and in streaming mode.
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaSource<OUT>
The Source implementation of Kafka.
|
Modifier and Type | Class and Description |
---|---|
class |
HiveSource
A unified data source that reads a hive table.
|
Constructor and Description |
---|
SourceCoordinator(String operatorName,
ExecutorService coordinatorExecutor,
Source<?,SplitT,EnumChkT> source,
SourceCoordinatorContext<SplitT> context) |
SourceCoordinatorProvider(String operatorName,
OperatorID operatorID,
Source<?,SplitT,?> source,
int numWorkerThreads)
Construct the
SourceCoordinatorProvider . |
Constructor and Description |
---|
DataStreamSource(StreamExecutionEnvironment environment,
Source<T,?,?> source,
WatermarkStrategy<T> watermarkStrategy,
TypeInformation<T> outTypeInfo,
String sourceName)
Constructor for new Sources (FLIP-27).
|
Modifier and Type | Method and Description |
---|---|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(Source<OUT,?,?> source,
WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName)
Adds a data
Source to the environment to get a DataStream . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.fromSource(Source<OUT,?,?> source,
WatermarkStrategy<OUT> timestampsAndWatermarks,
String sourceName,
TypeInformation<OUT> typeInfo)
Adds a data
Source to the environment to get a DataStream . |
Constructor and Description |
---|
SourceOperatorFactory(Source<OUT,?,?> source,
WatermarkStrategy<OUT> watermarkStrategy) |
SourceOperatorFactory(Source<OUT,?,?> source,
WatermarkStrategy<OUT> watermarkStrategy,
boolean emitProgressiveWatermarks) |
SourceOperatorFactory(Source<OUT,?,?> source,
WatermarkStrategy<OUT> watermarkStrategy,
boolean emitProgressiveWatermarks,
int numCoordinatorWorkerThread) |
Modifier and Type | Method and Description |
---|---|
Source<OUT,SplitT,EnumChkT> |
SourceTransformation.getSource() |
Constructor and Description |
---|
SourceTransformation(String name,
Source<OUT,SplitT,EnumChkT> source,
WatermarkStrategy<OUT> watermarkStrategy,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
Transformation with the given name, output type and parallelism. |
Modifier and Type | Method and Description |
---|---|
Source<RowData,?,?> |
SourceProvider.createSource()
Creates a
Source instance. |
Modifier and Type | Method and Description |
---|---|
static SourceProvider |
SourceProvider.of(Source<RowData,?,?> source)
Helper method for creating a static provider.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.