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
IOExceptionpublic void testSequenceId() throws IOException
IOExceptionpublic void testCloseCarryingSnapshot() throws IOException
IOExceptionpublic void testMemstoreSnapshotSize() throws IOException
IOExceptionprivate 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.IOExceptionpublic void testMemstoreSizeAccountingWithFailedPostBatchMutate() throws IOException
IOExceptionpublic void testFlushAndMemstoreSizeCounting() throws Exception
Exception - Exceptionpublic void testFlushSizeAccounting() throws Exception
Exceptionpublic void testCloseWithFailingFlush() throws Exception
Exceptionpublic void testCompactionAffectedByScanners() throws Exception
Exceptionpublic void testToShowNPEOnRegionScannerReseek() throws Exception
Exceptionpublic void testSkipRecoveredEditsReplay() throws Exception
Exceptionpublic void testSkipRecoveredEditsReplaySomeIgnored() throws Exception
Exceptionpublic void testSkipRecoveredEditsReplayAllIgnored() throws Exception
Exceptionpublic void testSkipRecoveredEditsReplayTheLastFileIgnored() throws Exception
Exceptionpublic void testRecoveredEditsReplayCompaction() throws Exception
Exceptionpublic void testRecoveredEditsReplayCompaction(boolean mismatchedRegionName) throws Exception
Exceptionpublic void testFlushMarkers() throws Exception
Exceptionpublic void testFlushMarkersWALFail() throws Exception
Exceptionpublic void testGetWhileRegionClose() throws IOException
IOExceptionpublic void testWeirdCacheBehaviour() throws Exception
Exceptionpublic void testAppendWithReadOnlyTable() throws Exception
Exceptionpublic void testIncrWithReadOnlyTable() throws Exception
Exceptionprivate void deleteColumns(org.apache.hadoop.hbase.regionserver.HRegion r, String value, String keyPrefix) throws IOException
IOExceptionprivate int getNumberOfRows(String keyPrefix, String value, org.apache.hadoop.hbase.regionserver.HRegion r) throws Exception
Exceptionprivate org.apache.hadoop.hbase.regionserver.InternalScanner buildScanner(String keyPrefix, String value, org.apache.hadoop.hbase.regionserver.HRegion r) throws IOException
IOExceptionprivate void putRows(org.apache.hadoop.hbase.regionserver.HRegion r, int numRows, String value, String key) throws IOException
IOExceptionpublic void testFamilyWithAndWithoutColon() throws Exception
Exceptionpublic void testBatchPut_whileNoRowLocksHeld() throws IOException
IOExceptionpublic void testBatchPut_whileMultipleRowLocksHeld() throws Exception
Exceptionprivate void waitForCounter(org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource source, String metricName, long expectedCount) throws InterruptedException
InterruptedExceptionpublic void testAtomicBatchPut() throws IOException
IOExceptionpublic void testBatchPutWithTsSlop() throws Exception
Exceptionprivate long prepareRegionForBachPut(org.apache.hadoop.hbase.client.Put[] puts, org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource source, boolean slop) throws IOException
IOExceptionpublic void testCheckAndMutate_WithEmptyRowValue() throws IOException
IOExceptionpublic void testCheckAndMutate_WithWrongValue() throws IOException
IOExceptionpublic void testCheckAndMutate_WithCorrectValue() throws IOException
IOExceptionpublic void testCheckAndMutate_WithNonEqualCompareOp() throws IOException
IOExceptionpublic void testCheckAndPut_ThatPutWasWritten() throws IOException
IOExceptionpublic void testCheckAndPut_wrongRowInPut() throws IOException
IOExceptionpublic void testCheckAndDelete_ThatDeleteWasWritten() throws IOException
IOExceptionpublic void testDelete_multiDeleteColumn() throws IOException
IOExceptionpublic void testDelete_CheckFamily() throws IOException
IOExceptionpublic void testDelete_mixed() throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void testDeleteRowWithFutureTs() throws IOException
IOExceptionpublic void testPutWithLatestTS() throws IOException
IOExceptionpublic void testPutWithTsSlop() throws IOException
IOExceptionpublic void testScanner_DeleteOneFamilyNotAnother() throws IOException
IOExceptionpublic void testDataInMemoryWithoutWAL() throws IOException
IOExceptionprivate 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
IOExceptionpublic void testDeleteColumns_PostInsert() throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void testaddFamily_PostInsert() throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void doTestDelete_AndPostInsert(org.apache.hadoop.hbase.client.Delete delete) throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void testDelete_CheckTimestampUpdated() throws IOException
IOExceptionpublic void testGet_FamilyChecker() throws IOException
IOExceptionpublic void testGet_Basic() throws IOException
IOExceptionpublic void testGet_Empty() throws IOException
IOExceptionpublic void testGetWithFilter() throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void testGetScanner_WithOkFamilies() throws IOException
IOExceptionpublic void testGetScanner_WithNotOkFamilies() throws IOException
IOExceptionpublic void testGetScanner_WithNoFamilies() throws IOException
IOExceptionpublic void testGetScanner_WithRegionClosed() throws IOException
IOExceptionpublic void testRegionScanner_Next() throws IOException
IOExceptionpublic void testScanner_ExplicitColumns_FromMemStore_EnforceVersions() throws IOException
IOExceptionpublic void testScanner_ExplicitColumns_FromFilesOnly_EnforceVersions() throws IOException
IOExceptionpublic void testScanner_ExplicitColumns_FromMemStoreAndFiles_EnforceVersions() throws IOException
IOExceptionpublic void testScanner_Wildcard_FromMemStore_EnforceVersions() throws IOException
IOExceptionpublic void testScanner_Wildcard_FromFilesOnly_EnforceVersions() throws IOException
IOExceptionpublic void testScanner_StopRow1542() throws IOException
IOExceptionpublic void testScanner_Wildcard_FromMemStoreAndFiles_EnforceVersions() throws IOException
IOExceptionpublic void testScanner_JoinedScanners() throws IOException
IOExceptionpublic void testScanner_JoinedScannersWithLimits() throws IOException
IOExceptionpublic void testLongQualifier() throws Exception
Exceptionpublic 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 threadsExceptionpublic void testHolesInMeta() throws Exception
Exceptionpublic void testIndexesScanWithOneDeletedRow() throws IOException
IOExceptionpublic void testBloomFilterSize() throws IOException
IOExceptionpublic void testAllColumnsWithBloomFilter() throws IOException
IOExceptionpublic void testDeleteRowWithBloomFilter() throws IOException
IOExceptionpublic void testgetHDFSBlocksDistribution() throws Exception
Exceptionpublic void testStatusSettingToAbortIfAnyExceptionDuringRegionInitilization() throws Exception
Exceptionpublic void testRegionInfoFileCreation() throws IOException
IOExceptionpublic void testParallelIncrementWithMemStoreFlush() throws Exception
Exceptionpublic void testParallelAppendWithMemStoreFlush() throws Exception
Exceptionpublic void testPutWithMemStoreFlush() throws Exception
Exceptionpublic void testDurability() throws Exception
Exceptionprivate 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
Exceptionpublic void testRegionReplicaSecondary() throws IOException
IOExceptionpublic void testRegionReplicaSecondaryIsReadOnly() throws IOException
IOExceptionstatic org.apache.hadoop.hbase.wal.WALFactory createWALFactory(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path rootDir) throws IOException
IOExceptionpublic void testCompactionFromPrimary() throws IOException
IOExceptionprivate void putData(int startRow, int numRows, byte[] qf, byte[]... families) throws IOException
IOExceptionprivate void putData(org.apache.hadoop.hbase.regionserver.HRegion region, int startRow, int numRows, byte[] qf, byte[]... families) throws IOException
IOExceptionstatic 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
IOExceptionstatic void verifyData(org.apache.hadoop.hbase.regionserver.HRegion newReg, int startRow, int numRows, byte[] qf, byte[]... families) throws IOException
IOExceptionstatic void assertGet(org.apache.hadoop.hbase.regionserver.HRegion r, byte[] family, byte[] k) throws IOException
IOExceptionprotected void assertScan(org.apache.hadoop.hbase.regionserver.HRegion r, byte[] fs, byte[] firstValue) throws IOException
IOExceptionpublic void testFlushResult() throws IOException
IOExceptionprotected 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.IOExceptionprotected 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.IOExceptionprotected 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
IOExceptionpublic 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.IOExceptionprivate void checkOneCell(org.apache.hadoop.hbase.Cell kv, byte[] cf, int rowIdx, int colIdx, long ts)
public void testReverseScanner_FromMemStore_SingleCF_Normal() throws IOException
IOExceptionpublic void testReverseScanner_FromMemStore_SingleCF_LargerKey() throws IOException
IOExceptionpublic void testReverseScanner_FromMemStore_SingleCF_FullScan() throws IOException
IOExceptionpublic void testReverseScanner_moreRowsMayExistAfter() throws IOException
IOExceptionpublic void testReverseScanner_smaller_blocksize() throws IOException
IOExceptionpublic void testReverseScanner_FromMemStoreAndHFiles_MultiCFs1() throws IOException
IOExceptionpublic void testReverseScanner_FromMemStoreAndHFiles_MultiCFs2() throws IOException
IOExceptionpublic void testReverseScanner_StackOverflow() throws IOException
IOExceptionpublic void testReverseScanShouldNotScanMemstoreIfReadPtLesser() throws Exception
Exceptionpublic void testReverseScanWhenPutCellsAfterOpenReverseScan() throws Exception
Exceptionpublic void testWriteRequestsCounter() throws IOException
IOExceptionpublic void testOpenRegionWrittenToWAL() throws Exception
Exceptionpublic void testFlushedFileWithNoTags() throws Exception
Exceptionprivate org.apache.hadoop.hbase.wal.WAL mockWAL() throws IOException
IOExceptionpublic void testCloseRegionWrittenToWAL() throws Exception
Exceptionpublic void testRegionTooBusy() throws IOException
IOExceptionpublic void testCellTTLs() throws IOException
IOExceptionpublic void testIncrementTimestampsAreMonotonic() throws IOException
IOExceptionpublic void testAppendTimestampsAreMonotonic() throws IOException
IOExceptionpublic void testCheckAndMutateTimestampsAreMonotonic() throws IOException
IOExceptionpublic void testBatchMutateWithWrongRegionException() throws Exception
Exceptionpublic void testCheckAndRowMutateTimestampsAreMonotonic() throws IOException
IOExceptionorg.apache.hadoop.hbase.regionserver.HRegion initHRegion(org.apache.hadoop.hbase.TableName tableName, String callingMethod, byte[]... families) throws IOException
IOExceptionpublic void testWritesWhileRollWriter() throws IOException
IOException - if IO error occurred during testpublic void testMutateRow_WriteRequestCount() throws Exception
Exceptionpublic void testBulkLoadReplicationEnabled() throws IOException
IOExceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.