public class TestHRegion extends Object
| Modifier and Type | Class and Description |
|---|---|
protected class |
TestHRegion.FlushThread |
protected class |
TestHRegion.PutThread |
| Modifier and Type | Field and Description |
|---|---|
static Configuration |
CONF |
protected String |
method |
protected MetricsAssertHelper |
metricsAssertHelper |
TestName |
name |
protected byte[] |
qual1 |
protected byte[] |
qual2 |
protected byte[] |
qual3 |
protected byte[] |
row |
protected byte[] |
row2 |
protected byte[] |
tableName |
protected byte[] |
value1 |
protected byte[] |
value2 |
| Constructor and Description |
|---|
TestHRegion() |
public TestName name
public static Configuration CONF
protected byte[] tableName
protected String method
protected final byte[] qual1
protected final byte[] qual2
protected final byte[] qual3
protected final byte[] value1
protected final byte[] value2
protected final byte[] row
protected final byte[] row2
protected final MetricsAssertHelper metricsAssertHelper
public void setup()
throws IOException
IOExceptionpublic void testCloseCarryingSnapshot()
throws IOException
IOExceptionpublic void testMemstoreSnapshotSize()
throws IOException
IOExceptionpublic void testMemstoreSizeWithFlushCanceling()
throws IOException
IOExceptionpublic void testMemstoreSizeAccountingWithFailedPostBatchMutate()
throws IOException
IOExceptionpublic 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 testGetWhileRegionClose()
throws IOException
IOExceptionpublic void testAppendWithReadOnlyTable()
throws Exception
Exceptionpublic void testIncrWithReadOnlyTable()
throws Exception
Exceptionpublic void testFamilyWithAndWithoutColon()
throws Exception
Exceptionpublic void testBatchPut_whileNoRowLocksHeld()
throws IOException
IOExceptionpublic void testBatchPut_whileMultipleRowLocksHeld()
throws Exception
Exceptionpublic 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 testDeleteColumns_PostInsert()
throws IOException,
InterruptedException
IOExceptionInterruptedExceptionpublic void testDeleteFamily_PostInsert()
throws IOException,
InterruptedException
IOExceptionInterruptedExceptionpublic void doTestDelete_AndPostInsert(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 testMerge()
throws IOException
IOExceptionpublic 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 testBasicSplit()
throws Exception
Exceptionpublic void testSplitRegion()
throws IOException
IOExceptionpublic void testClearForceSplit()
throws IOException
IOExceptionpublic 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 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 testRegionReplicaSecondary()
throws IOException
IOExceptionpublic void testRegionReplicaSecondaryIsReadOnly()
throws IOException
IOExceptionpublic void testCompactionFromPrimary()
throws IOException
IOExceptionpublic void testFlushResult()
throws IOException
IOExceptionpublic static HRegion initHRegion(TableName tableName, String callingMethod, Configuration conf, byte[]... families) throws IOException
tableName - callingMethod - conf - families - HRegion.closeHRegion(HRegion) when done.IOExceptionpublic static HRegion initHRegion(byte[] tableName, String callingMethod, Configuration conf, byte[]... families) throws IOException
tableName - callingMethod - conf - families - HRegion.closeHRegion(HRegion) when done.IOExceptionpublic static HRegion initHRegion(byte[] tableName, String callingMethod, Configuration conf, boolean isReadOnly, byte[]... families) throws IOException
tableName - callingMethod - conf - isReadOnly - families - HRegion.closeHRegion(HRegion) when done.IOExceptionpublic static HRegion initHRegion(byte[] tableName, byte[] startKey, byte[] stopKey, String callingMethod, Configuration conf, boolean isReadOnly, byte[]... families) throws IOException
IOExceptionpublic static HRegion initHRegion(byte[] tableName, byte[] startKey, byte[] stopKey, String callingMethod, Configuration conf, boolean isReadOnly, Durability durability, WAL wal, byte[]... families) throws IOException
tableName - startKey - stopKey - callingMethod - conf - isReadOnly - families - HRegion.closeHRegion(HRegion) when done.IOExceptionpublic 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 testSplitRegionWithReverseScan()
throws IOException
IOExceptionpublic void testWriteRequestsCounter()
throws IOException
IOExceptionpublic void testOpenRegionWrittenToWAL()
throws Exception
Exceptionpublic void testFlushedFileWithNoTags()
throws Exception
Exceptionpublic void testOpenRegionWrittenToWALForLogReplay()
throws Exception
Exceptionpublic 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
IOExceptionpublic void testWritesWhileRollWriter()
throws IOException
IOException - if IO error occurred during test