Interface DeltaWriterFactory

  • All Superinterfaces:
    org.apache.spark.sql.connector.write.DataWriterFactory, java.io.Serializable

    public interface DeltaWriterFactory
    extends org.apache.spark.sql.connector.write.DataWriterFactory
    A factory for creating and initializing delta writers at the executor side.
    • Method Detail

      • createWriter

        DeltaWriter<org.apache.spark.sql.catalyst.InternalRow> createWriter​(int partitionId,
                                                                            long taskId)
        Specified by:
        createWriter in interface org.apache.spark.sql.connector.write.DataWriterFactory