public class TestHRegion extends Object
Modifier and Type | Class and Description |
---|---|
private static class |
TestHRegion.Appender
TestCase for append
|
protected class |
TestHRegion.FlushThread |
(package private) class |
TestHRegion.GetTillDoneOrException |
static class |
TestHRegion.HRegionForTesting
The same as HRegion class, the only difference is that instantiateHStore will
create a different HStore - HStoreForTesting.
|
(package private) static class |
TestHRegion.HRegionWithSeqId |
static class |
TestHRegion.HStoreForTesting
HStoreForTesting is merely the same as HStore, the difference is in the doCompaction method
of HStoreForTesting there is a checkpoint "hbase.hstore.compaction.complete" which
doesn't let hstore compaction complete.
|
private static class |
TestHRegion.Incrementer
TestCase for increment
|
(package private) static class |
TestHRegion.IsFlushWALMarker |
protected class |
TestHRegion.PutThread |
Modifier and Type | Field and Description |
---|---|
static HBaseClassTestRule |
CLASS_RULE |
private static String |
COLUMN_FAMILY |
private static byte[] |
COLUMN_FAMILY_BYTES |
static org.apache.hadoop.conf.Configuration |
CONF |
private String |
dir |
private static org.apache.hadoop.fs.FileSystem |
FILESYSTEM |
private static org.apache.hbase.thirdparty.io.netty.channel.EventLoopGroup |
GROUP |
private static org.slf4j.Logger |
LOG |
private int |
MAX_VERSIONS |
protected String |
method |
protected MetricsAssertHelper |
metricsAssertHelper |
org.junit.rules.TestName |
name |
protected byte[] |
qual |
protected byte[] |
qual1 |
protected byte[] |
qual2 |
protected byte[] |
qual3 |
(package private) org.apache.hadoop.hbase.regionserver.HRegion |
region |
protected byte[] |
row |
protected byte[] |
row2 |
protected org.apache.hadoop.hbase.TableName |
tableName |
protected static HBaseTestingUtility |
TEST_UTIL |
org.junit.rules.ExpectedException |
thrown |
protected byte[] |
value |
protected byte[] |
value1 |
protected byte[] |
value2 |
Constructor and Description |
---|
TestHRegion() |
Modifier and Type | Method and Description |
---|---|
(package private) static void |
assertGet(org.apache.hadoop.hbase.regionserver.HRegion r,
byte[] family,
byte[] k) |
protected void |
assertScan(org.apache.hadoop.hbase.regionserver.HRegion r,
byte[] fs,
byte[] firstValue) |
private org.apache.hadoop.hbase.regionserver.InternalScanner |
buildScanner(String keyPrefix,
String value,
org.apache.hadoop.hbase.regionserver.HRegion r) |
private void |
checkOneCell(org.apache.hadoop.hbase.Cell kv,
byte[] cf,
int rowIdx,
int colIdx,
long ts)
Assert that the passed in Cell has expected contents for the specified row,
column & timestamp.
|
private static org.apache.hadoop.hbase.wal.WAL |
createWALCompatibleWithFaultyFileSystem(String callingMethod,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.TableName tableName)
Create a WAL outside of the usual helper in
HBaseTestingUtility.createWal(Configuration, Path, RegionInfo) because that method
doesn't play nicely with FaultyFileSystem. |
(package private) static org.apache.hadoop.hbase.wal.WALFactory |
createWALFactory(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir) |
private void |
deleteColumns(org.apache.hadoop.hbase.regionserver.HRegion r,
String value,
String keyPrefix) |
void |
doTestDelete_AndPostInsert(org.apache.hadoop.hbase.client.Delete delete) |
private void |
durabilityTest(String method,
org.apache.hadoop.hbase.client.Durability tableDurability,
org.apache.hadoop.hbase.client.Durability mutationDurability,
long timeout,
boolean expectAppend,
boolean expectSync,
boolean expectSyncFromLogSyncer) |
private int |
getNumberOfRows(String keyPrefix,
String value,
org.apache.hadoop.hbase.regionserver.HRegion r) |
org.apache.hadoop.hbase.regionserver.HRegion |
initHRegion(org.apache.hadoop.hbase.TableName tableName,
byte[] startKey,
byte[] stopKey,
boolean isReadOnly,
org.apache.hadoop.hbase.client.Durability durability,
org.apache.hadoop.hbase.wal.WAL wal,
byte[]... families) |
protected org.apache.hadoop.hbase.regionserver.HRegion |
initHRegion(org.apache.hadoop.hbase.TableName tableName,
byte[] startKey,
byte[] stopKey,
String callingMethod,
org.apache.hadoop.conf.Configuration conf,
boolean isReadOnly,
byte[]... families) |
(package private) org.apache.hadoop.hbase.regionserver.HRegion |
initHRegion(org.apache.hadoop.hbase.TableName tableName,
String callingMethod,
byte[]... families) |
protected org.apache.hadoop.hbase.regionserver.HRegion |
initHRegion(org.apache.hadoop.hbase.TableName tableName,
String callingMethod,
org.apache.hadoop.conf.Configuration conf,
boolean isReadOnly,
byte[]... families) |
protected org.apache.hadoop.hbase.regionserver.HRegion |
initHRegion(org.apache.hadoop.hbase.TableName tableName,
String callingMethod,
org.apache.hadoop.conf.Configuration conf,
byte[]... families) |
protected org.apache.hadoop.conf.Configuration |
initSplit() |
private org.apache.hadoop.hbase.wal.WAL |
mockWAL()
Utility method to setup a WAL mock.
|
private long |
prepareRegionForBachPut(org.apache.hadoop.hbase.client.Put[] puts,
org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource source,
boolean slop) |
(package private) static void |
putData(org.apache.hadoop.hbase.regionserver.HRegion region,
org.apache.hadoop.hbase.client.Durability durability,
int startRow,
int numRows,
byte[] qf,
byte[]... families) |
private void |
putData(org.apache.hadoop.hbase.regionserver.HRegion region,
int startRow,
int numRows,
byte[] qf,
byte[]... families) |
private void |
putData(int startRow,
int numRows,
byte[] qf,
byte[]... families) |
private void |
putRows(org.apache.hadoop.hbase.regionserver.HRegion r,
int numRows,
String value,
String key) |
void |
setup() |
void |
tearDown() |
void |
testaddFamily_PostInsert() |
void |
testAllColumnsWithBloomFilter() |
void |
testAppendTimestampsAreMonotonic() |
void |
testAppendWithReadOnlyTable() |
void |
testAtomicBatchPut() |
void |
testBatchMutateWithWrongRegionException() |
void |
testBatchPut_whileMultipleRowLocksHeld() |
void |
testBatchPut_whileNoRowLocksHeld() |
void |
testBatchPutWithTsSlop() |
void |
testBloomFilterSize() |
void |
testBulkLoadReplicationEnabled() |
void |
testCellTTLs() |
void |
testCheckAndDelete_ThatDeleteWasWritten() |
void |
testCheckAndMutate_WithCorrectValue() |
void |
testCheckAndMutate_WithEmptyRowValue() |
void |
testCheckAndMutate_WithNonEqualCompareOp() |
void |
testCheckAndMutate_WithWrongValue() |
void |
testCheckAndMutateTimestampsAreMonotonic() |
void |
testCheckAndPut_ThatPutWasWritten() |
void |
testCheckAndPut_wrongRowInPut() |
void |
testCheckAndRowMutateTimestampsAreMonotonic() |
void |
testCloseCarryingSnapshot()
Test for Bug 2 of HBASE-10466.
|
void |
testCloseRegionWrittenToWAL() |
void |
testCloseWithFailingFlush() |
void |
testCompactionAffectedByScanners() |
void |
testCompactionFromPrimary() |
void |
testDataInMemoryWithoutWAL() |
private static void |
testDataInMemoryWithoutWAL(org.apache.hadoop.hbase.regionserver.HRegion region,
org.apache.hadoop.hbase.client.Put originalPut,
org.apache.hadoop.hbase.client.Put addPut,
long delta) |
void |
testDelete_CheckFamily() |
void |
testDelete_CheckTimestampUpdated() |
void |
testDelete_mixed() |
void |
testDelete_multiDeleteColumn() |
void |
testDeleteColumns_PostInsert() |
void |
testDeleteRowWithBloomFilter()
Testcase to cover bug-fix for HBASE-2823 Ensures correct delete when
issuing delete row on columns with bloom filter set to row+col
(BloomType.ROWCOL)
|
void |
testDeleteRowWithFutureTs() |
void |
testDurability() |
void |
testFamilyWithAndWithoutColon() |
void |
testFlushAndMemstoreSizeCounting()
A test case of HBASE-21041
|
void |
testFlushCacheWhileScanning()
Flushes the cache in a thread while scanning.
|
void |
testFlushedFileWithNoTags() |
void |
testFlushMarkers() |
void |
testFlushMarkersWALFail() |
void |
testFlushResult()
Test that we get the expected flush results back
|
void |
testFlushSizeAccounting()
Test we do not lose data if we fail a flush and then close.
|
void |
testGet_Basic() |
void |
testGet_Empty() |
void |
testGet_FamilyChecker() |
void |
testgetHDFSBlocksDistribution() |
void |
testGetScanner_WithNoFamilies() |
void |
testGetScanner_WithNotOkFamilies() |
void |
testGetScanner_WithOkFamilies() |
void |
testGetScanner_WithRegionClosed()
This method tests https://issues.apache.org/jira/browse/HBASE-2516.
|
void |
testGetWhileRegionClose() |
void |
testGetWithFilter() |
void |
testHolesInMeta() |
void |
testIncrementTimestampsAreMonotonic() |
void |
testIncrWithReadOnlyTable() |
void |
testIndexesScanWithOneDeletedRow() |
void |
testLongQualifier()
Write an HFile block full with Cells whose qualifier that are identical between
0 and Short.MAX_VALUE.
|
void |
testMemstoreSizeAccountingWithFailedPostBatchMutate() |
void |
testMemstoreSnapshotSize() |
void |
testMutateRow_WriteRequestCount() |
void |
testOpenRegionWrittenToWAL() |
void |
testParallelAppendWithMemStoreFlush()
Test case to check append function with memstore flushing
|
void |
testParallelIncrementWithMemStoreFlush()
Test case to check increment function with memstore flushing
|
void |
testPutWithLatestTS()
Tests that the special LATEST_TIMESTAMP option for puts gets replaced by
the actual timestamp
|
void |
testPutWithMemStoreFlush()
Test case to check put function with memstore flushing for same row, same ts
|
void |
testPutWithTsSlop()
Tests that there is server-side filtering for invalid timestamp upper
bound.
|
void |
testRecoveredEditsReplayCompaction() |
void |
testRecoveredEditsReplayCompaction(boolean mismatchedRegionName) |
void |
testRegionInfoFileCreation()
Verifies that the .regioninfo file is written on region creation and that
is recreated if missing during region opening.
|
void |
testRegionReplicaSecondary() |
void |
testRegionReplicaSecondaryIsReadOnly() |
void |
testRegionScanner_Next() |
void |
testRegionTooBusy()
Test RegionTooBusyException thrown when region is busy
|
void |
testReverseScanner_FromMemStore_SingleCF_FullScan() |
void |
testReverseScanner_FromMemStore_SingleCF_LargerKey() |
void |
testReverseScanner_FromMemStore_SingleCF_Normal() |
void |
testReverseScanner_FromMemStoreAndHFiles_MultiCFs1() |
void |
testReverseScanner_FromMemStoreAndHFiles_MultiCFs2() |
void |
testReverseScanner_moreRowsMayExistAfter() |
void |
testReverseScanner_smaller_blocksize() |
void |
testReverseScanner_StackOverflow()
Test for HBASE-14497: Reverse Scan threw StackOverflow caused by readPt checking
|
void |
testReverseScanShouldNotScanMemstoreIfReadPtLesser() |
void |
testReverseScanWhenPutCellsAfterOpenReverseScan() |
void |
testScanner_DeleteOneFamilyNotAnother() |
void |
testScanner_ExplicitColumns_FromFilesOnly_EnforceVersions() |
void |
testScanner_ExplicitColumns_FromMemStore_EnforceVersions() |
void |
testScanner_ExplicitColumns_FromMemStoreAndFiles_EnforceVersions() |
void |
testScanner_JoinedScanners()
Added for HBASE-5416
Here we test scan optimization when only subset of CFs are used in filter
conditions.
|
void |
testScanner_JoinedScannersWithLimits()
HBASE-5416
Test case when scan limits amount of KVs returned on each next() call.
|
void |
testScanner_StopRow1542() |
void |
testScanner_Wildcard_FromFilesOnly_EnforceVersions() |
void |
testScanner_Wildcard_FromMemStore_EnforceVersions() |
void |
testScanner_Wildcard_FromMemStoreAndFiles_EnforceVersions() |
void |
testSequenceId()
Test that I can use the max flushed sequence id after the close.
|
void |
testSkipRecoveredEditsReplay() |
void |
testSkipRecoveredEditsReplayAllIgnored() |
void |
testSkipRecoveredEditsReplaySomeIgnored() |
void |
testSkipRecoveredEditsReplayTheLastFileIgnored() |
void |
testStatusSettingToAbortIfAnyExceptionDuringRegionInitilization()
Testcase to check state of region initialization task set to ABORTED or not
if any exceptions during initialization
|
void |
testToShowNPEOnRegionScannerReseek() |
void |
testWeirdCacheBehaviour() |
void |
testWriteRequestsCounter() |
void |
testWritesWhileGetting()
Writes very wide records and gets the latest row every time..
|
void |
testWritesWhileRollWriter()
HBASE-16429 Make sure no stuck if roll writer when ring buffer is filled with appends
|
void |
testWritesWhileScanning()
Writes very wide records and scans for the latest every time..
|
(package private) static void |
verifyData(org.apache.hadoop.hbase.regionserver.HRegion newReg,
int startRow,
int numRows,
byte[] qf,
byte[]... families) |
private void |
waitForCounter(org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource source,
String metricName,
long expectedCount) |
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
public org.junit.rules.TestName name
public final org.junit.rules.ExpectedException thrown
private static final String COLUMN_FAMILY
private static final byte[] COLUMN_FAMILY_BYTES
private static final org.apache.hbase.thirdparty.io.netty.channel.EventLoopGroup GROUP
org.apache.hadoop.hbase.regionserver.HRegion region
protected static HBaseTestingUtility TEST_UTIL
public static org.apache.hadoop.conf.Configuration CONF
private static org.apache.hadoop.fs.FileSystem FILESYSTEM
private final int MAX_VERSIONS
protected org.apache.hadoop.hbase.TableName tableName
protected final byte[] qual
protected final byte[] qual1
protected final byte[] qual2
protected final byte[] qual3
protected final byte[] value
protected final byte[] value1
protected final byte[] value2
protected final byte[] row
protected final byte[] row2
protected final MetricsAssertHelper metricsAssertHelper
public TestHRegion()
public void setup() throws IOException
IOException
public void testSequenceId() throws IOException
IOException
public void testCloseCarryingSnapshot() throws IOException
IOException
public void testMemstoreSnapshotSize() throws IOException
IOException
private static org.apache.hadoop.hbase.wal.WAL createWALCompatibleWithFaultyFileSystem(String callingMethod, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName) throws IOException
HBaseTestingUtility.createWal(Configuration, Path, RegionInfo)
because that method
doesn't play nicely with FaultyFileSystem. Call this method before overriding
fs.file.impl
.callingMethod
- a unique component for the path, probably the name of the test method.IOException
public void testMemstoreSizeAccountingWithFailedPostBatchMutate() throws IOException
IOException
public void testFlushAndMemstoreSizeCounting() throws Exception
Exception
- Exceptionpublic void testFlushSizeAccounting() throws Exception
Exception
public void testCloseWithFailingFlush() throws Exception
Exception
public void testCompactionAffectedByScanners() throws Exception
Exception
public void testToShowNPEOnRegionScannerReseek() throws Exception
Exception
public void testSkipRecoveredEditsReplay() throws Exception
Exception
public void testSkipRecoveredEditsReplaySomeIgnored() throws Exception
Exception
public void testSkipRecoveredEditsReplayAllIgnored() throws Exception
Exception
public void testSkipRecoveredEditsReplayTheLastFileIgnored() throws Exception
Exception
public void testRecoveredEditsReplayCompaction() throws Exception
Exception
public void testRecoveredEditsReplayCompaction(boolean mismatchedRegionName) throws Exception
Exception
public void testFlushMarkers() throws Exception
Exception
public void testFlushMarkersWALFail() throws Exception
Exception
public void testGetWhileRegionClose() throws IOException
IOException
public void testWeirdCacheBehaviour() throws Exception
Exception
public void testAppendWithReadOnlyTable() throws Exception
Exception
public void testIncrWithReadOnlyTable() throws Exception
Exception
private void deleteColumns(org.apache.hadoop.hbase.regionserver.HRegion r, String value, String keyPrefix) throws IOException
IOException
private int getNumberOfRows(String keyPrefix, String value, org.apache.hadoop.hbase.regionserver.HRegion r) throws Exception
Exception
private org.apache.hadoop.hbase.regionserver.InternalScanner buildScanner(String keyPrefix, String value, org.apache.hadoop.hbase.regionserver.HRegion r) throws IOException
IOException
private void putRows(org.apache.hadoop.hbase.regionserver.HRegion r, int numRows, String value, String key) throws IOException
IOException
public void testFamilyWithAndWithoutColon() throws Exception
Exception
public void testBatchPut_whileNoRowLocksHeld() throws IOException
IOException
public void testBatchPut_whileMultipleRowLocksHeld() throws Exception
Exception
private void waitForCounter(org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource source, String metricName, long expectedCount) throws InterruptedException
InterruptedException
public void testAtomicBatchPut() throws IOException
IOException
public void testBatchPutWithTsSlop() throws Exception
Exception
private long prepareRegionForBachPut(org.apache.hadoop.hbase.client.Put[] puts, org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource source, boolean slop) throws IOException
IOException
public void testCheckAndMutate_WithEmptyRowValue() throws IOException
IOException
public void testCheckAndMutate_WithWrongValue() throws IOException
IOException
public void testCheckAndMutate_WithCorrectValue() throws IOException
IOException
public void testCheckAndMutate_WithNonEqualCompareOp() throws IOException
IOException
public void testCheckAndPut_ThatPutWasWritten() throws IOException
IOException
public void testCheckAndPut_wrongRowInPut() throws IOException
IOException
public void testCheckAndDelete_ThatDeleteWasWritten() throws IOException
IOException
public void testDelete_multiDeleteColumn() throws IOException
IOException
public void testDelete_CheckFamily() throws IOException
IOException
public void testDelete_mixed() throws IOException, InterruptedException
IOException
InterruptedException
public void testDeleteRowWithFutureTs() throws IOException
IOException
public void testPutWithLatestTS() throws IOException
IOException
public void testPutWithTsSlop() throws IOException
IOException
public void testScanner_DeleteOneFamilyNotAnother() throws IOException
IOException
public void testDataInMemoryWithoutWAL() throws IOException
IOException
private static void testDataInMemoryWithoutWAL(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.client.Put originalPut, org.apache.hadoop.hbase.client.Put addPut, long delta) throws IOException
IOException
public void testDeleteColumns_PostInsert() throws IOException, InterruptedException
IOException
InterruptedException
public void testaddFamily_PostInsert() throws IOException, InterruptedException
IOException
InterruptedException
public void doTestDelete_AndPostInsert(org.apache.hadoop.hbase.client.Delete delete) throws IOException, InterruptedException
IOException
InterruptedException
public void testDelete_CheckTimestampUpdated() throws IOException
IOException
public void testGet_FamilyChecker() throws IOException
IOException
public void testGet_Basic() throws IOException
IOException
public void testGet_Empty() throws IOException
IOException
public void testGetWithFilter() throws IOException, InterruptedException
IOException
InterruptedException
public void testGetScanner_WithOkFamilies() throws IOException
IOException
public void testGetScanner_WithNotOkFamilies() throws IOException
IOException
public void testGetScanner_WithNoFamilies() throws IOException
IOException
public void testGetScanner_WithRegionClosed() throws IOException
IOException
public void testRegionScanner_Next() throws IOException
IOException
public void testScanner_ExplicitColumns_FromMemStore_EnforceVersions() throws IOException
IOException
public void testScanner_ExplicitColumns_FromFilesOnly_EnforceVersions() throws IOException
IOException
public void testScanner_ExplicitColumns_FromMemStoreAndFiles_EnforceVersions() throws IOException
IOException
public void testScanner_Wildcard_FromMemStore_EnforceVersions() throws IOException
IOException
public void testScanner_Wildcard_FromFilesOnly_EnforceVersions() throws IOException
IOException
public void testScanner_StopRow1542() throws IOException
IOException
public void testScanner_Wildcard_FromMemStoreAndFiles_EnforceVersions() throws IOException
IOException
public void testScanner_JoinedScanners() throws IOException
IOException
public void testScanner_JoinedScannersWithLimits() throws IOException
IOException
public void testLongQualifier() throws Exception
Exception
public void testFlushCacheWhileScanning() throws IOException, InterruptedException
IOException
- scan / compactInterruptedException
- thread joinpublic void testWritesWhileScanning() throws IOException, InterruptedException
IOException
- by flush / scan / compactionInterruptedException
- when joining threadspublic void testWritesWhileGetting() throws Exception
IOException
- by flush / scan / compactionInterruptedException
- when joining threadsException
public void testHolesInMeta() throws Exception
Exception
public void testIndexesScanWithOneDeletedRow() throws IOException
IOException
public void testBloomFilterSize() throws IOException
IOException
public void testAllColumnsWithBloomFilter() throws IOException
IOException
public void testDeleteRowWithBloomFilter() throws IOException
IOException
public void testgetHDFSBlocksDistribution() throws Exception
Exception
public void testStatusSettingToAbortIfAnyExceptionDuringRegionInitilization() throws Exception
Exception
public void testRegionInfoFileCreation() throws IOException
IOException
public void testParallelIncrementWithMemStoreFlush() throws Exception
Exception
public void testParallelAppendWithMemStoreFlush() throws Exception
Exception
public void testPutWithMemStoreFlush() throws Exception
Exception
public void testDurability() throws Exception
Exception
private void durabilityTest(String method, org.apache.hadoop.hbase.client.Durability tableDurability, org.apache.hadoop.hbase.client.Durability mutationDurability, long timeout, boolean expectAppend, boolean expectSync, boolean expectSyncFromLogSyncer) throws Exception
Exception
public void testRegionReplicaSecondary() throws IOException
IOException
public void testRegionReplicaSecondaryIsReadOnly() throws IOException
IOException
static org.apache.hadoop.hbase.wal.WALFactory createWALFactory(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path rootDir) throws IOException
IOException
public void testCompactionFromPrimary() throws IOException
IOException
private void putData(int startRow, int numRows, byte[] qf, byte[]... families) throws IOException
IOException
private void putData(org.apache.hadoop.hbase.regionserver.HRegion region, int startRow, int numRows, byte[] qf, byte[]... families) throws IOException
IOException
static void putData(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.client.Durability durability, int startRow, int numRows, byte[] qf, byte[]... families) throws IOException
IOException
static void verifyData(org.apache.hadoop.hbase.regionserver.HRegion newReg, int startRow, int numRows, byte[] qf, byte[]... families) throws IOException
IOException
static void assertGet(org.apache.hadoop.hbase.regionserver.HRegion r, byte[] family, byte[] k) throws IOException
IOException
protected void assertScan(org.apache.hadoop.hbase.regionserver.HRegion r, byte[] fs, byte[] firstValue) throws IOException
IOException
public void testFlushResult() throws IOException
IOException
protected org.apache.hadoop.conf.Configuration initSplit()
protected org.apache.hadoop.hbase.regionserver.HRegion initHRegion(org.apache.hadoop.hbase.TableName tableName, String callingMethod, org.apache.hadoop.conf.Configuration conf, byte[]... families) throws IOException
HBaseTestingUtility.closeRegionAndWAL(HRegion)
when done.IOException
protected org.apache.hadoop.hbase.regionserver.HRegion initHRegion(org.apache.hadoop.hbase.TableName tableName, String callingMethod, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, byte[]... families) throws IOException
HBaseTestingUtility.closeRegionAndWAL(HRegion)
when done.IOException
protected org.apache.hadoop.hbase.regionserver.HRegion initHRegion(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] stopKey, String callingMethod, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, byte[]... families) throws IOException
IOException
public org.apache.hadoop.hbase.regionserver.HRegion initHRegion(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] stopKey, boolean isReadOnly, org.apache.hadoop.hbase.client.Durability durability, org.apache.hadoop.hbase.wal.WAL wal, byte[]... families) throws IOException
HBaseTestingUtility.closeRegionAndWAL(HRegion)
when done.IOException
private void checkOneCell(org.apache.hadoop.hbase.Cell kv, byte[] cf, int rowIdx, int colIdx, long ts)
public void testReverseScanner_FromMemStore_SingleCF_Normal() throws IOException
IOException
public void testReverseScanner_FromMemStore_SingleCF_LargerKey() throws IOException
IOException
public void testReverseScanner_FromMemStore_SingleCF_FullScan() throws IOException
IOException
public void testReverseScanner_moreRowsMayExistAfter() throws IOException
IOException
public void testReverseScanner_smaller_blocksize() throws IOException
IOException
public void testReverseScanner_FromMemStoreAndHFiles_MultiCFs1() throws IOException
IOException
public void testReverseScanner_FromMemStoreAndHFiles_MultiCFs2() throws IOException
IOException
public void testReverseScanner_StackOverflow() throws IOException
IOException
public void testReverseScanShouldNotScanMemstoreIfReadPtLesser() throws Exception
Exception
public void testReverseScanWhenPutCellsAfterOpenReverseScan() throws Exception
Exception
public void testWriteRequestsCounter() throws IOException
IOException
public void testOpenRegionWrittenToWAL() throws Exception
Exception
public void testFlushedFileWithNoTags() throws Exception
Exception
private org.apache.hadoop.hbase.wal.WAL mockWAL() throws IOException
IOException
public void testCloseRegionWrittenToWAL() throws Exception
Exception
public void testRegionTooBusy() throws IOException
IOException
public void testCellTTLs() throws IOException
IOException
public void testIncrementTimestampsAreMonotonic() throws IOException
IOException
public void testAppendTimestampsAreMonotonic() throws IOException
IOException
public void testCheckAndMutateTimestampsAreMonotonic() throws IOException
IOException
public void testBatchMutateWithWrongRegionException() throws Exception
Exception
public void testCheckAndRowMutateTimestampsAreMonotonic() throws IOException
IOException
org.apache.hadoop.hbase.regionserver.HRegion initHRegion(org.apache.hadoop.hbase.TableName tableName, String callingMethod, byte[]... families) throws IOException
IOException
public void testWritesWhileRollWriter() throws IOException
IOException
- if IO error occurred during testpublic void testMutateRow_WriteRequestCount() throws Exception
Exception
public void testBulkLoadReplicationEnabled() throws IOException
IOException
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.