Modifier and Type | Class and Description |
---|---|
static class |
FileSinkProgram.Generator
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
static class |
StreamSQLTestProgram.Generator
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Interface and Description |
---|---|
interface |
ExternallyInducedSource<T,CD>
Deprecated.
This interface is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Method and Description |
---|---|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function)
Deprecated.
This method relies on the
SourceFunction API, which is due to be
removed. Use the StreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String) method based on
the new Source API instead. |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
String sourceName)
Deprecated.
This method relies on the
SourceFunction API, which is due to be
removed. Use the StreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String) method based on
the new Source API instead. |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
String sourceName,
TypeInformation<OUT> typeInfo)
Deprecated.
This method relies on the
SourceFunction API, which is due to be
removed. Use the StreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String, TypeInformation)
method based on the new Source API instead. |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
TypeInformation<OUT> typeInfo)
Deprecated.
This method relies on the
SourceFunction API, which is due to be
removed. Use the StreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String, TypeInformation)
method based on the new Source API instead. |
Modifier and Type | Interface and Description |
---|---|
interface |
ParallelSourceFunction<OUT>
Deprecated.
This interface is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
class |
ContinuousFileMonitoringFunction<OUT>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
FileMonitoringFunction
Deprecated.
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
class |
FromElementsFunction<T>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
FromIteratorFunction<T>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
FromSplittableIteratorFunction<T>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
InputFormatSourceFunction<OUT>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
MessageAcknowledgingSourceBase<Type,UId>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
RichParallelSourceFunction<OUT>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
RichSourceFunction<OUT>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
SocketTextStreamFunction
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
StatefulSequenceSource
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
class |
DataGeneratorSource<T>
Deprecated.
Use
org.apache.flink.connector.datagen.source.DataGeneratorSource instead. |
Modifier and Type | Class and Description |
---|---|
class |
StreamSource<OUT,SRC extends SourceFunction<OUT>>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
class |
WikipediaEditsSource
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
class |
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
static class |
PeriodicStreamingJob.PeriodicSourceGenerator
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
class |
SequenceGeneratorSource
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
class |
FiniteTestSource<T>
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Method and Description |
---|---|
SourceFunction<RowData> |
SourceFunctionProvider.createSourceFunction()
Deprecated.
Creates a
SourceFunction instance. |
Modifier and Type | Method and Description |
---|---|
static SourceFunctionProvider |
SourceFunctionProvider.of(SourceFunction<RowData> sourceFunction,
boolean isBounded)
Deprecated.
Helper method for creating a static provider.
|
static SourceFunctionProvider |
SourceFunctionProvider.of(SourceFunction<RowData> sourceFunction,
boolean isBounded,
Integer sourceParallelism)
Deprecated.
Helper method for creating a Source provider with a provided source parallelism.
|
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
CommonExecTableSourceScan.createSourceFunctionTransformation(StreamExecutionEnvironment env,
SourceFunction<RowData> function,
boolean isBounded,
String operatorName,
TypeInformation<RowData> outputTypeInfo,
int sourceParallelism,
boolean sourceParallelismConfigured)
Deprecated.
This method relies on the
SourceFunction API, which is due to be
removed. |
Modifier and Type | Class and Description |
---|---|
class |
ArrowSourceFunction
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
class |
TestSourceFunction
A source function used to test.
|
Modifier and Type | Class and Description |
---|---|
static class |
StatefulStreamingJob.MySource
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Modifier and Type | Class and Description |
---|---|
class |
TransactionSource
Deprecated.
This class is based on the
SourceFunction API, which is due to be
removed. Use the new Source API instead. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.