@Experimental public interface DeltaWriterFactory extends DataWriterFactory
DeltaWriter
s returned by
DeltaBatchWrite.createBatchWriterFactory(PhysicalWriteInfo)
, which is responsible for
creating and initializing writers at the executor side.Modifier and Type | Method and Description |
---|---|
DeltaWriter<org.apache.spark.sql.catalyst.InternalRow> |
createWriter(int partitionId,
long taskId)
Returns a data writer to do the actual writing work.
|
DeltaWriter<org.apache.spark.sql.catalyst.InternalRow> createWriter(int partitionId, long taskId)
DataWriterFactory
If this method fails (by throwing an exception), the corresponding Spark write task would fail and get retried until hitting the maximum retry times.
createWriter
in interface DataWriterFactory
partitionId
- A unique id of the RDD partition that the returned writer will process.
Usually Spark processes many RDD partitions at the same time,
implementations should use the partition id to distinguish writers for
different partitions.taskId
- The task id returned by TaskContext.taskAttemptId()
. Spark may run
multiple tasks for the same partition (due to speculation or task failures,
for example).