Interface DataStreamScanProvider
-
- All Superinterfaces:
org.apache.flink.table.connector.ParallelismProvider,org.apache.flink.table.connector.source.ScanTableSource.ScanRuntimeProvider
@PublicEvolving public interface DataStreamScanProvider extends org.apache.flink.table.connector.source.ScanTableSource.ScanRuntimeProvider, org.apache.flink.table.connector.ParallelismProviderProvider that produces a JavaDataStreamas 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 Abstract Methods Modifier and Type Method Description org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData>produceDataStream(org.apache.flink.table.connector.ProviderContext providerContext, org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)Creates a scan JavaDataStreamfrom aStreamExecutionEnvironment.
-
-
-
Method Detail
-
produceDataStream
org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> produceDataStream(org.apache.flink.table.connector.ProviderContext providerContext, org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)Creates a scan JavaDataStreamfrom aStreamExecutionEnvironment.Note: If the
CompiledPlanfeature 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)
-
-