Class Hierarchy
- java.lang.Object
- com.linkedin.venice.spark.input.pubsub.SparkPubSubInputFormat (implements org.apache.spark.sql.connector.read.Batch, org.apache.spark.sql.connector.read.Scan)
- com.linkedin.venice.spark.input.pubsub.SparkPubSubInputPartition (implements org.apache.spark.sql.connector.read.InputPartition, java.io.Serializable)
- com.linkedin.venice.spark.input.pubsub.SparkPubSubInputPartitionReader (implements org.apache.spark.sql.connector.read.PartitionReader<T>)
- com.linkedin.venice.spark.input.pubsub.SparkPubSubPartitionReaderFactory (implements org.apache.spark.sql.connector.read.PartitionReaderFactory)
- com.linkedin.venice.spark.input.pubsub.VenicePubSubMessageToRow (implements com.linkedin.venice.spark.input.pubsub.PubSubMessageConverter)
Interface Hierarchy
- com.linkedin.venice.spark.input.pubsub.PubSubMessageConverter