public static class TestHStore.MyDefaultMemStore extends org.apache.hadoop.hbase.regionserver.DefaultMemStore
Modifier and Type | Field and Description |
---|---|
private AtomicInteger |
clearSnapshotCounter |
private static String |
FLUSH_THREAD_NAME |
private static String |
GET_SCANNER_THREAD_NAME |
private CyclicBarrier |
getScannerCyclicBarrier
Only when flush thread enters
AbstractMemStore.doClearSnapShot() , getScanner thread
could start. |
private AtomicInteger |
getSnapshotSegmentsCounter |
private CyclicBarrier |
postClearSnapShotCyclicBarrier
Used by flush thread notifies getScanner thread
AbstractMemStore.doClearSnapShot()
completed, DefaultMemStore.getScanners(long) could continue. |
private CyclicBarrier |
preClearSnapShotCyclicBarrier
Used by getScanner thread notifies flush thread
DefaultMemStore.getSnapshotSegments()
completed, AbstractMemStore.doClearSnapShot() could continue. |
private boolean |
shouldWait |
private org.apache.hadoop.hbase.regionserver.HStore |
store |
Constructor and Description |
---|
MyDefaultMemStore(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.CellComparator cellComparator,
org.apache.hadoop.hbase.regionserver.RegionServicesForStores regionServices) |
Modifier and Type | Method and Description |
---|---|
protected void |
doClearSnapShot() |
protected List<org.apache.hadoop.hbase.regionserver.Segment> |
getSnapshotSegments() |
getFlushableSize, getNextRow, getScanners, getSegments, heapSize, isSloppy, keySize, main, postUpdate, preFlushSeqIDEstimation, preUpdate, size, sizeAddedPreOperation, snapshot, updateLowestUnflushedSequenceIdInWAL
add, add, addToScanners, addToScanners, clearSnapshot, doAdd, dump, getActive, getComparator, getConfiguration, getLowest, getNextRow, getSnapshot, getSnapshotSize, resetActive, resetTimeOfOldestEdit, timeOfOldestEdit, toString, upsert
private static final String GET_SCANNER_THREAD_NAME
private static final String FLUSH_THREAD_NAME
private final CyclicBarrier getScannerCyclicBarrier
AbstractMemStore.doClearSnapShot()
, getScanner thread
could start.private final CyclicBarrier preClearSnapShotCyclicBarrier
DefaultMemStore.getSnapshotSegments()
completed, AbstractMemStore.doClearSnapShot()
could continue.private final CyclicBarrier postClearSnapShotCyclicBarrier
AbstractMemStore.doClearSnapShot()
completed, DefaultMemStore.getScanners(long)
could continue.private final AtomicInteger getSnapshotSegmentsCounter
private final AtomicInteger clearSnapshotCounter
private volatile boolean shouldWait
private volatile org.apache.hadoop.hbase.regionserver.HStore store
public MyDefaultMemStore(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.CellComparator cellComparator, org.apache.hadoop.hbase.regionserver.RegionServicesForStores regionServices) throws IOException
IOException
protected List<org.apache.hadoop.hbase.regionserver.Segment> getSnapshotSegments()
getSnapshotSegments
in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
protected void doClearSnapShot()
doClearSnapShot
in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.