PushReplicationEvent.Type.TRANSITION_RECORDS
event for this partition replica.PushReplicationEvent
s for a given destination broker and
(eventually) to build an AppendRecords out of them.PushReplicationEvent
s for a given partition replica and
(eventually) to build a AppendRecordsRequestData.PartitionData
out of them.MultiBufferRecords
that can send the buffers of multiple memory records in a
single org.apache.kafka.common.network.Send
.AppendRecordsRequestData
from all the buffered data in the builder.AppendRecordsRequestData.PartitionData
out of the consumed push replication events for this
partition replica with the given leader epoch and replication session ID.MemoryRecords
.PushReplicationEvent.Type.HWM_UPDATE
with its payload being an
PushReplicationEvent.OffsetPayload
containing the updated high watermark.PushReplicationEvent.Type.LSO_UPDATE
with its payload being an
PushReplicationEvent.OffsetPayload
containing the updated log start offset.PushReplicationEvent.Type.MEMORY_RECORDS
or PushReplicationEvent.Type.FILE_RECORDS
with its payload being a PushReplicationEvent.RecordsPayload
containing the given records and offsets.PushReplicationEvent.Type.START_PUSH
with its payload being the given
PushSession
.PushReplicationEvent.Type.STOP_PUSH
with its payload being an
CompletableFuture
containing the future that will be used as the result of
the push replication stop operation.PushReplicationEvent.Type.TRANSITION_RECORDS
from a given
PushReplicationEvent.Type.FILE_RECORDS
event and a completable future.FileRecords
needed to have the follower catch up to the leader.AbstractRecords
representing some records already appended on
the partition replica leader, their append offset, and the high watermark value at the time
of creating the records.ReplicationConfig.REPLICATION_MODE_PROP
config property.PushReplicationEvent.Type.STOP_PUSH
event for this partition replica.