Interface DataStreamScanProvider
-
- All Superinterfaces:
ParallelismProvider
,ScanTableSource.ScanRuntimeProvider
@PublicEvolving public interface DataStreamScanProvider extends ScanTableSource.ScanRuntimeProvider, ParallelismProvider
Provider that produces a JavaDataStream
as a runtime implementation forScanTableSource
.Note: This provider is only meant for advanced connector developers. Usually, a source should consist of a single entity expressed via
SourceProvider
,SourceFunctionProvider
, orInputFormatProvider
.
-
-
Method Summary
All Methods Instance Methods Default Methods Deprecated Methods Modifier and Type Method Description default DataStream<RowData>
produceDataStream(StreamExecutionEnvironment execEnv)
Deprecated.default DataStream<RowData>
produceDataStream(ProviderContext providerContext, StreamExecutionEnvironment execEnv)
Creates a scan JavaDataStream
from aStreamExecutionEnvironment
.-
Methods inherited from interface org.apache.flink.table.connector.ParallelismProvider
getParallelism
-
Methods inherited from interface org.apache.flink.table.connector.source.ScanTableSource.ScanRuntimeProvider
isBounded
-
-
-
-
Method Detail
-
produceDataStream
default DataStream<RowData> produceDataStream(ProviderContext providerContext, StreamExecutionEnvironment execEnv)
Creates a scan JavaDataStream
from aStreamExecutionEnvironment
.Note: If the
CompiledPlan
feature should be supported, this method MUST set a unique identifier for each transformation/operator in the data stream. This enables stateful Flink version upgrades for streaming jobs. The identifier is used to map state back from a savepoint to an actual operator in the topology. The framework can generate topology-wide unique identifiers withProviderContext.generateUid(String)
.- See Also:
SingleOutputStreamOperator.uid(String)
-
produceDataStream
@Deprecated default DataStream<RowData> produceDataStream(StreamExecutionEnvironment execEnv)
Deprecated.Creates a scan JavaDataStream
from aStreamExecutionEnvironment
.
-
-