Interface SupportsMerge

  • All Superinterfaces:
    org.apache.spark.sql.connector.catalog.Table
    All Known Implementing Classes:
    SparkTable, StagedSparkTable

    public interface SupportsMerge
    extends org.apache.spark.sql.connector.catalog.Table
    A mix-in interface for Table to indicate that it supports row-level operations.

    This adds newMergeBuilder(String, LogicalWriteInfo) that is used to create a scan and a write for a row-level operation.

    • Method Summary

      All Methods Instance Methods Abstract Methods 
      Modifier and Type Method Description
      MergeBuilder newMergeBuilder​(java.lang.String operation, org.apache.spark.sql.connector.write.LogicalWriteInfo info)
      Returns a MergeBuilder which can be used to create both a scan and a write for a row-level operation.
      • Methods inherited from interface org.apache.spark.sql.connector.catalog.Table

        capabilities, name, partitioning, properties, schema
    • Method Detail

      • newMergeBuilder

        MergeBuilder newMergeBuilder​(java.lang.String operation,
                                     org.apache.spark.sql.connector.write.LogicalWriteInfo info)
        Returns a MergeBuilder which can be used to create both a scan and a write for a row-level operation. Spark will call this method to configure each data source row-level operation.
        Parameters:
        info - write info
        Returns:
        a merge builder