Packages

t

org.apache.spark.sql.connector.read.streaming

ContinuousPartitionReaderFactory

trait ContinuousPartitionReaderFactory extends PartitionReaderFactory

A variation on PartitionReaderFactory that returns ContinuousPartitionReader instead of PartitionReader. It's used for continuous streaming processing.

Annotations
@Evolving()
Source
ContinuousPartitionReaderFactory.java
Since

3.0.0

Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ContinuousPartitionReaderFactory
  2. PartitionReaderFactory
  3. Serializable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Abstract Value Members

  1. abstract def createReader(partition: InputPartition): ContinuousPartitionReader[InternalRow]

    Returns a row-based partition reader to read data from the given InputPartition.

    Returns a row-based partition reader to read data from the given InputPartition.

    Implementations probably need to cast the input partition to the concrete InputPartition class defined for the data source.

    Definition Classes
    ContinuousPartitionReaderFactoryPartitionReaderFactory
    Annotations
    @Override()

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
  6. def createColumnarReader(partition: InputPartition): ContinuousPartitionReader[ColumnarBatch]

    Returns a columnar partition reader to read data from the given InputPartition.

    Returns a columnar partition reader to read data from the given InputPartition.

    Implementations probably need to cast the input partition to the concrete InputPartition class defined for the data source.

    Definition Classes
    ContinuousPartitionReaderFactoryPartitionReaderFactory
    Annotations
    @Override()
  7. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  8. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  9. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  10. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  11. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  12. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  13. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  14. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  15. def supportColumnarReads(partition: InputPartition): Boolean

    Returns true if the given InputPartition should be read by Spark in a columnar way.

    Returns true if the given InputPartition should be read by Spark in a columnar way. This means, implementations must also implement #createColumnarReader(InputPartition) for the input partitions that this method returns true.

    As of Spark 2.4, Spark can only read all input partition in a columnar way, or none of them. Data source can't mix columnar and row-based partitions. This may be relaxed in future versions.

    Definition Classes
    PartitionReaderFactory
  16. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  17. def toString(): String
    Definition Classes
    AnyRef → Any
  18. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  19. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  20. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

    (Since version 9)

Inherited from PartitionReaderFactory

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped