Hierarchy For Package org.apache.flink.table.runtime.arrow.sources

Package Hierarchies:

Class Hierarchy

  • java.lang.Object
    • org.apache.flink.api.common.functions.AbstractRichFunction (implements org.apache.flink.api.common.functions.RichFunction, java.io.Serializable)
      • org.apache.flink.streaming.api.functions.source.legacy.RichParallelSourceFunction<OUT> (implements org.apache.flink.streaming.api.functions.source.legacy.ParallelSourceFunction<OUT>)
        • org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction (implements org.apache.flink.streaming.api.checkpoint.CheckpointedFunction, org.apache.flink.api.java.typeutils.ResultTypeQueryable<T>)
    • org.apache.flink.table.runtime.arrow.sources.ArrowTableSource (implements org.apache.flink.table.connector.source.ScanTableSource)
    • org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceFactory (implements org.apache.flink.table.factories.DynamicTableSourceFactory)
    • org.apache.flink.table.runtime.arrow.sources.ArrowTableSourceOptions