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.ParallelismProvider
    Provider that produces a Java DataStream as a runtime implementation for ScanTableSource.

    Note: This provider is only meant for advanced connector developers. Usually, a source should consist of a single entity expressed via SourceProvider, SourceFunctionProvider, or InputFormatProvider.

    • Method Summary

      All Methods Instance Methods Default Methods Deprecated Methods 
      Modifier and Type Method Description
      default org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> produceDataStream​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
      Deprecated.
      default org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> produceDataStream​(ProviderContext providerContext, org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
      Creates a scan Java DataStream from a StreamExecutionEnvironment.
      • 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 org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> produceDataStream​(ProviderContext providerContext,
                                                                                                                            org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
        Creates a scan Java DataStream from a StreamExecutionEnvironment.

        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 with ProviderContext.generateUid(String).

        See Also:
        SingleOutputStreamOperator.uid(String)
      • produceDataStream

        @Deprecated
        default org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> produceDataStream​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
        Deprecated.
        Creates a scan Java DataStream from a StreamExecutionEnvironment.