You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by ap...@apache.org on 2018/05/31 22:29:02 UTC

[2/3] hbase git commit: Revert "HBASE-18116 fix replication source in-memory calculation by excluding bulk load file"

Revert "HBASE-18116 fix replication source in-memory calculation by excluding bulk load file"

This reverts commit 050fae501a6db95260356279e071c8577e87624f.


Project: http://git-wip-us.apache.org/repos/asf/hbase/repo
Commit: http://git-wip-us.apache.org/repos/asf/hbase/commit/b22409d5
Tree: http://git-wip-us.apache.org/repos/asf/hbase/tree/b22409d5
Diff: http://git-wip-us.apache.org/repos/asf/hbase/diff/b22409d5

Branch: refs/heads/branch-2
Commit: b22409d51d170a5ccf0c1a29095d1442cb6db708
Parents: 050fae5
Author: Andrew Purtell <ap...@apache.org>
Authored: Thu May 31 15:28:37 2018 -0700
Committer: Andrew Purtell <ap...@apache.org>
Committed: Thu May 31 15:28:37 2018 -0700

----------------------------------------------------------------------
 .../ReplicationSourceWALReader.java             | 22 +++++---------------
 1 file changed, 5 insertions(+), 17 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase/blob/b22409d5/hbase-server/src/main/java/org/apache/hadoop/hbase/replication/regionserver/ReplicationSourceWALReader.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/replication/regionserver/ReplicationSourceWALReader.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/replication/regionserver/ReplicationSourceWALReader.java
index ee54931..64fd48d 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/replication/regionserver/ReplicationSourceWALReader.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/replication/regionserver/ReplicationSourceWALReader.java
@@ -36,7 +36,6 @@ import org.apache.hadoop.hbase.util.Pair;
 import org.apache.hadoop.hbase.util.Threads;
 import org.apache.hadoop.hbase.wal.WAL.Entry;
 import org.apache.hadoop.hbase.wal.WALEdit;
-import org.apache.hadoop.hbase.wal.WALKey;
 import org.apache.yetus.audience.InterfaceAudience;
 import org.apache.yetus.audience.InterfaceStability;
 import org.slf4j.Logger;
@@ -169,12 +168,10 @@ class ReplicationSourceWALReader extends Thread {
     if (edit == null || edit.isEmpty()) {
       return false;
     }
-    long entrySize = getEntrySizeIncludeBulkLoad(entry);
-    long entrySizeExlucdeBulkLoad = getEntrySizeExcludeBulkLoad(entry);
+    long entrySize = getEntrySize(entry);
     batch.addEntry(entry);
     updateBatchStats(batch, entry, entrySize);
-    boolean totalBufferTooLarge = acquireBufferQuota(entrySizeExlucdeBulkLoad);
-
+    boolean totalBufferTooLarge = acquireBufferQuota(entrySize);
     // Stop if too many entries or too big
     return totalBufferTooLarge || batch.getHeapSize() >= replicationBatchSizeCapacity ||
       batch.getNbEntries() >= replicationBatchCountCapacity;
@@ -299,20 +296,11 @@ class ReplicationSourceWALReader extends Thread {
     return entryBatchQueue.take();
   }
 
-  private long getEntrySizeIncludeBulkLoad(Entry entry) {
+  private long getEntrySize(Entry entry) {
     WALEdit edit = entry.getEdit();
-    WALKey key = entry.getKey();
-    return edit.heapSize() + sizeOfStoreFilesIncludeBulkLoad(edit) +
-        key.estimatedSerializedSizeOf();
+    return edit.heapSize() + calculateTotalSizeOfStoreFiles(edit);
   }
 
-  private long getEntrySizeExcludeBulkLoad(Entry entry) {
-    WALEdit edit = entry.getEdit();
-    WALKey key = entry.getKey();
-    return edit.heapSize() + key.estimatedSerializedSizeOf();
-  }
-
-
   private void updateBatchStats(WALEntryBatch batch, Entry entry, long entrySize) {
     WALEdit edit = entry.getEdit();
     batch.incrementHeapSize(entrySize);
@@ -365,7 +353,7 @@ class ReplicationSourceWALReader extends Thread {
    * @param edit edit to count row keys from
    * @return the total size of the store files
    */
-  private int sizeOfStoreFilesIncludeBulkLoad(WALEdit edit) {
+  private int calculateTotalSizeOfStoreFiles(WALEdit edit) {
     List<Cell> cells = edit.getCells();
     int totalStoreFilesSize = 0;