Class VeniceRawPubsubInputScan

java.lang.Object
com.linkedin.venice.spark.input.pubsub.raw.VeniceRawPubsubInputScan
All Implemented Interfaces:
org.apache.spark.sql.connector.read.Batch, org.apache.spark.sql.connector.read.Scan

public class VeniceRawPubsubInputScan extends Object implements org.apache.spark.sql.connector.read.Scan, org.apache.spark.sql.connector.read.Batch
  • Constructor Details

    • VeniceRawPubsubInputScan

      public VeniceRawPubsubInputScan(VeniceProperties jobConfig)
  • Method Details

    • planInputPartitions

      public org.apache.spark.sql.connector.read.InputPartition[] planInputPartitions()
      Specified by:
      planInputPartitions in interface org.apache.spark.sql.connector.read.Batch
    • createReaderFactory

      public org.apache.spark.sql.connector.read.PartitionReaderFactory createReaderFactory()
      Specified by:
      createReaderFactory in interface org.apache.spark.sql.connector.read.Batch
    • readSchema

      public org.apache.spark.sql.types.StructType readSchema()
      Specified by:
      readSchema in interface org.apache.spark.sql.connector.read.Scan