All Methods Static Methods Instance Methods Concrete Methods
Modifier and Type |
Method and Description |
void |
doTestDelete_AndPostInsert(Delete delete) |
static HRegion |
initHRegion(byte[] tableName,
byte[] startKey,
byte[] stopKey,
String callingMethod,
Configuration conf,
boolean isReadOnly,
byte[]... families) |
static HRegion |
initHRegion(byte[] tableName,
byte[] startKey,
byte[] stopKey,
String callingMethod,
Configuration conf,
boolean isReadOnly,
Durability durability,
WAL wal,
byte[]... families) |
static HRegion |
initHRegion(byte[] tableName,
String callingMethod,
Configuration conf,
boolean isReadOnly,
byte[]... families) |
static HRegion |
initHRegion(byte[] tableName,
String callingMethod,
Configuration conf,
byte[]... families) |
static HRegion |
initHRegion(TableName tableName,
String callingMethod,
Configuration conf,
byte[]... families) |
void |
setup() |
void |
tearDown() |
void |
testAllColumnsWithBloomFilter() |
void |
testAppendTimestampsAreMonotonic() |
void |
testAppendWithReadOnlyTable() |
void |
testBasicSplit()
Splits twice and verifies getting from each of the split regions.
|
void |
testBatchMutateWithWrongRegionException() |
void |
testBatchPut_whileMultipleRowLocksHeld() |
void |
testBatchPut_whileNoRowLocksHeld() |
void |
testBatchPutWithTsSlop() |
void |
testBloomFilterSize() |
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 |
testClearForceSplit() |
void |
testCloseCarryingSnapshot()
Test for Bug 2 of HBASE-10466.
|
void |
testCloseRegionWrittenToWAL() |
void |
testCloseWithFailingFlush() |
void |
testCompactionAffectedByScanners() |
void |
testCompactionFromPrimary() |
void |
testDelete_CheckFamily() |
void |
testDelete_CheckTimestampUpdated() |
void |
testDelete_mixed() |
void |
testDelete_multiDeleteColumn() |
void |
testDeleteColumns_PostInsert() |
void |
testDeleteFamily_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 |
testFlushCacheWhileScanning()
Flushes the cache in a thread while scanning.
|
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 |
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 |
testMemstoreSnapshotSize() |
void |
testMerge() |
void |
testOpenRegionWrittenToWAL() |
void |
testOpenRegionWrittenToWALForLogReplay() |
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 |
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 |
testSkipRecoveredEditsReplay() |
void |
testSkipRecoveredEditsReplayAllIgnored() |
void |
testSkipRecoveredEditsReplaySomeIgnored() |
void |
testSkipRecoveredEditsReplayTheLastFileIgnored() |
void |
testSplitRegion() |
void |
testSplitRegionWithReverseScan() |
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 |
testWritesWhileScanning()
Writes very wide records and scans for the latest every time..
|