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 |
---|---|
private BlockingQueue<WALEntryBatch> |
ReplicationSourceWALReader.entryBatchQueue |
Modifier and Type | Method and Description |
---|---|
protected WALEntryBatch |
ReplicationSourceWALReader.createBatch(WALEntryStream entryStream) |
(package private) static WALEntryBatch |
WALEntryBatch.endOfFile(org.apache.hadoop.fs.Path lastWalPath) |
WALEntryBatch |
ReplicationSourceWALReader.poll(long timeout) |
protected WALEntryBatch |
SerialReplicationSourceWALReader.readWALEntries(WALEntryStream entryStream) |
protected WALEntryBatch |
ReplicationSourceWALReader.readWALEntries(WALEntryStream entryStream) |
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
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
ReplicationSourceWALReader.addEntryToBatch(WALEntryBatch batch,
WAL.Entry entry) |
private int |
ReplicationSourceShipper.getBatchEntrySizeExcludeBulkLoad(WALEntryBatch entryBatch)
get batchEntry size excludes bulk load file sizes.
|
void |
ReplicationSourceManager.logPositionAndCleanOldLogs(String queueId,
boolean queueRecovered,
WALEntryBatch entryBatch)
This method will log the current position to storage.
|
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.