public class TestFromClientSide5 extends FromClientSideBase
Table.
Sets up the HBase mini cluster once at start and runs through all client tests.
Each creates a table named for the method and does its stuff against that.
Parameterized to run with different registry implementations.| Modifier and Type | Field and Description |
|---|---|
static HBaseClassTestRule |
CLASS_RULE |
private static org.slf4j.Logger |
LOG |
TableNameTestRule |
name |
FAMILY, INVALID_FAMILY, QUALIFIER, ROW, SLAVES, TEST_UTIL, VALUE| Constructor and Description |
|---|
TestFromClientSide5() |
TestFromClientSide5(Class registry,
int numHedgedReqs) |
| Modifier and Type | Method and Description |
|---|---|
private void |
createTableAndValidateTableSchemaModification(org.apache.hadoop.hbase.TableName tableName,
boolean modifyTable)
Create table and validate online schema modification
|
private List<org.apache.hadoop.hbase.client.Result> |
doAppend(boolean walUsed) |
private List<org.apache.hadoop.hbase.HRegionLocation> |
getRegionsInRange(org.apache.hadoop.hbase.TableName tableName,
byte[] startKey,
byte[] endKey) |
private org.apache.hadoop.hbase.client.Result |
getReverseScanResult(org.apache.hadoop.hbase.client.Table table,
byte[] row) |
static Collection |
parameters() |
private void |
reverseScanTest(org.apache.hadoop.hbase.client.Table table,
boolean small) |
static void |
tearDownAfterClass() |
void |
testAppend() |
void |
testAppendWithoutWAL() |
void |
testBatchAppendWithReturnResultFalse() |
void |
testCacheOnWriteEvictOnClose()
Tests that cache on write works all the way up from the client-side.
|
void |
testCellSizeLimit() |
void |
testCellSizeNoLimit() |
void |
testCellUtilTypeMethods() |
void |
testCheckAndDelete() |
void |
testCheckAndDeleteWithCompareOp() |
void |
testCheckAndMutateWithTimeRange() |
void |
testCheckAndPut() |
void |
testCheckAndPutWithCompareOp() |
void |
testClientPoolRoundRobin() |
void |
testClientPoolThreadLocal() |
void |
testCreateTableWithZeroRegionReplicas() |
void |
testDeleteCFWithMemstoreData() |
void |
testDeleteLatestVersionOfSpecifiedColumn() |
void |
testDeleteSpecifiedVersionOfSpecifiedColumn() |
void |
testDeletesWithReverseScan() |
void |
testEmptyFilterList() |
void |
testFilterAllRecords() |
void |
testFiltersWithReverseScan() |
void |
testGetClosestRowBefore() |
void |
testGetRegionsInRange()
Tests getRegionsInRange by creating some regions over which a range of
keys spans; then changing the key range.
|
void |
testJira6912() |
void |
testKeyOnlyFilterWithReverseScan() |
void |
testModifyTableWithMemstoreData() |
void |
testModifyTableWithZeroRegionReplicas() |
void |
testMultiRowMutation() |
void |
testNegativeTimestamp() |
void |
testNonCachedGetRegionLocation()
Tests the non cached version of getRegionLocator by moving a region.
|
void |
testNullWithReverseScan() |
void |
testRawScanRespectsVersions() |
void |
testReadWithFilter()
Test for HBASE-17125
|
void |
testReversedScanUnderMultiRegions()
Tests reversed scan under multi regions
|
void |
testRowMutation() |
void |
testScan_NullQualifier() |
void |
testScanMetrics()
Test ScanMetrics
|
void |
testScanVariableReuse()
For HBASE-2156
|
void |
testSimpleMissingWithReverseScan()
Test simple table and non-existent row cases.
|
void |
testSmallReversedScanUnderMultiRegions()
Tests reversed scan under multi regions
|
void |
testSmallScan() |
void |
testSuperSimpleWithReverseScan() |
private void |
waitForStoreFileCount(org.apache.hadoop.hbase.regionserver.HStore store,
int count,
int timeout) |
afterClass, assertDoubleResult, assertEmptyResult, assertIncrementKey, assertKey, assertNResult, assertNResult, assertNullResult, assertNumKeys, assertRowCount, assertSingleResult, assertSingleResult, assertSingleResult, buildScanner, createScanWithRowFilter, createScanWithRowFilter, deleteColumns, equals, getAllVersionsAndVerify, getNumberOfRows, getSingleScanResult, getTestNull, getTestNull, getVerifySingleColumn, getVerifySingleEmpty, getVersionAndVerify, getVersionAndVerifyMissing, getVersionRangeAndVerify, getVersionRangeAndVerifyGreaterThan, initialize, isSameParameterizedCluster, makeN, makeNAscii, makeNBig, makeStamps, putRows, scanAllVersionsAndVerify, scanTestNull, scanTestNull, scanVerifySingleColumn, scanVerifySingleEmpty, scanVersionAndVerify, scanVersionAndVerifyMissing, scanVersionRangeAndVerify, scanVersionRangeAndVerifyGreaterThan, singleRowGetTest, singleRowScanTest, splitTableprivate static final org.slf4j.Logger LOG
public static final HBaseClassTestRule CLASS_RULE
public TableNameTestRule name
TestFromClientSide5()
public TestFromClientSide5(Class registry, int numHedgedReqs) throws Exception
Exceptionpublic static Collection parameters()
public static void tearDownAfterClass() throws Exception
Exceptionpublic void testGetClosestRowBefore() throws IOException, InterruptedException
IOExceptionInterruptedExceptionprivate org.apache.hadoop.hbase.client.Result getReverseScanResult(org.apache.hadoop.hbase.client.Table table, byte[] row) throws IOException
IOExceptionpublic void testScanVariableReuse()
public void testMultiRowMutation() throws Exception
Exceptionpublic void testRowMutation() throws Exception
Exceptionpublic void testBatchAppendWithReturnResultFalse() throws Exception
Exceptionpublic void testAppend() throws Exception
Exceptionprivate List<org.apache.hadoop.hbase.client.Result> doAppend(boolean walUsed) throws IOException
IOExceptionpublic void testAppendWithoutWAL() throws Exception
Exceptionpublic void testClientPoolRoundRobin() throws IOException
IOExceptionpublic void testClientPoolThreadLocal() throws IOException
IOExceptionpublic void testCheckAndPut() throws IOException
IOExceptionpublic void testCheckAndMutateWithTimeRange() throws IOException
IOExceptionpublic void testCheckAndPutWithCompareOp() throws IOException
IOExceptionpublic void testCheckAndDelete() throws IOException
IOExceptionpublic void testCheckAndDeleteWithCompareOp() throws IOException
IOExceptionpublic void testScanMetrics() throws Exception
Exceptionpublic void testCacheOnWriteEvictOnClose() throws Exception
Exceptionprivate void waitForStoreFileCount(org.apache.hadoop.hbase.regionserver.HStore store, int count, int timeout) throws InterruptedException
InterruptedExceptionpublic void testNonCachedGetRegionLocation() throws Exception
Exceptionpublic void testGetRegionsInRange() throws Exception
Exceptionprivate List<org.apache.hadoop.hbase.HRegionLocation> getRegionsInRange(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey) throws IOException
IOExceptionpublic void testJira6912() throws Exception
Exceptionpublic void testScan_NullQualifier() throws IOException
IOExceptionpublic void testNegativeTimestamp() throws IOException
IOExceptionpublic void testRawScanRespectsVersions() throws Exception
Exceptionpublic void testEmptyFilterList() throws Exception
Exceptionpublic void testSmallScan() throws Exception
Exceptionpublic void testSuperSimpleWithReverseScan() throws Exception
Exceptionpublic void testFiltersWithReverseScan() throws Exception
Exceptionpublic void testKeyOnlyFilterWithReverseScan() throws Exception
Exceptionpublic void testSimpleMissingWithReverseScan() throws Exception
Exceptionpublic void testNullWithReverseScan() throws Exception
Exceptionpublic void testDeletesWithReverseScan() throws Exception
Exceptionpublic void testReversedScanUnderMultiRegions() throws Exception
Exceptionpublic void testSmallReversedScanUnderMultiRegions() throws Exception
Exceptionprivate void reverseScanTest(org.apache.hadoop.hbase.client.Table table, boolean small) throws IOException
IOExceptionpublic void testFilterAllRecords() throws IOException
IOExceptionpublic void testCellSizeLimit() throws IOException
IOExceptionpublic void testCellSizeNoLimit() throws IOException
IOExceptionpublic void testDeleteSpecifiedVersionOfSpecifiedColumn() throws Exception
Exceptionpublic void testDeleteLatestVersionOfSpecifiedColumn() throws Exception
Exceptionpublic void testReadWithFilter() throws Exception
Exceptionpublic void testCellUtilTypeMethods() throws IOException
IOExceptionpublic void testCreateTableWithZeroRegionReplicas() throws Exception
Exceptionpublic void testModifyTableWithZeroRegionReplicas() throws Exception
Exceptionpublic void testModifyTableWithMemstoreData() throws Exception
Exceptionpublic void testDeleteCFWithMemstoreData() throws Exception
Exceptionprivate void createTableAndValidateTableSchemaModification(org.apache.hadoop.hbase.TableName tableName, boolean modifyTable) throws Exception
tableName - Table namemodifyTable - Modify table if true otherwise delete column familyIOException - in case of failuresExceptionCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.