Package | Description |
---|---|
org.apache.hadoop.hbase.replication.regionserver |
Modifier and Type | Field and Description |
---|---|
static WALEntryBatch |
WALEntryBatch.NO_MORE_DATA |
Modifier and Type | Field and Description |
---|---|
(package private) BlockingQueue<WALEntryBatch> |
ReplicationSourceWALReader.entryBatchQueue |
Modifier and Type | Method and Description |
---|---|
private WALEntryBatch |
ReplicationSourceWALReader.createBatch(WALEntryStream entryStream) |
(package private) static WALEntryBatch |
WALEntryBatch.endOfFile(org.apache.hadoop.fs.Path lastWalPath) |
WALEntryBatch |
ReplicationSourceWALReader.poll(long timeout) |
WALEntryBatch |
ReplicationSourceWALReader.take()
Retrieves the next batch of WAL entries from the queue, waiting up to the specified time for a
batch to become available
|
private WALEntryBatch |
ReplicationSourceWALReader.tryAdvanceStreamAndCreateWALBatch(WALEntryStream entryStream) |
Modifier and Type | Method and Description |
---|---|
private void |
ReplicationSourceWALReader.addBatchToShippingQueue(WALEntryBatch batch)
Update the batch try to ship and return true if shipped
|
protected boolean |
ReplicationSourceWALReader.addEntryToBatch(WALEntryBatch batch,
WAL.Entry entry) |
private int |
ReplicationSourceShipper.getBatchEntrySizeExcludeBulkLoad(WALEntryBatch entryBatch)
get batchEntry size excludes bulk load file sizes.
|
private boolean |
ReplicationSourceWALReader.handleEofException(Exception e,
WALEntryBatch batch)
This is to handle the EOFException from the WAL entry stream.
|
void |
ReplicationSourceManager.logPositionAndCleanOldLogs(ReplicationSourceInterface source,
WALEntryBatch entryBatch)
This method will log the current position to storage.
|
default void |
ReplicationSourceInterface.logPositionAndCleanOldLogs(WALEntryBatch entryBatch)
Log the current position to storage.
|
void |
CatalogReplicationSource.logPositionAndCleanOldLogs(WALEntryBatch entryBatch) |
protected void |
SerialReplicationSourceWALReader.readWALEntries(WALEntryStream entryStream,
WALEntryBatch batch) |
protected void |
ReplicationSourceWALReader.readWALEntries(WALEntryStream entryStream,
WALEntryBatch batch) |
private void |
SerialReplicationSourceWALReader.removeEntryFromStream(WALEntryStream entryStream,
WALEntryBatch batch) |
private void |
ReplicationSourceShipper.shipEdits(WALEntryBatch entryBatch)
Do the shipping logic
|
private void |
ReplicationSourceWALReader.updateBatchStats(WALEntryBatch batch,
WAL.Entry entry,
long entrySize) |
private boolean |
ReplicationSourceShipper.updateLogPosition(WALEntryBatch batch) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.