public class TestFromClientSide extends Object
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.| Modifier and Type | Field and Description |
|---|---|
static HBaseClassTestRule |
CLASS_RULE |
private static byte[] |
FAMILY |
private static byte[] |
INVALID_FAMILY |
private static org.slf4j.Logger |
LOG |
org.junit.rules.TestName |
name |
private static byte[] |
QUALIFIER |
private static byte[] |
ROW |
protected static int |
SLAVES |
protected static HBaseTestingUtility |
TEST_UTIL |
private static byte[] |
VALUE |
| Constructor and Description |
|---|
TestFromClientSide() |
| Modifier and Type | Method and Description |
|---|---|
private void |
assertDoubleResult(org.apache.hadoop.hbase.client.Result result,
byte[] row,
byte[] familyA,
byte[] qualifierA,
byte[] valueA,
byte[] familyB,
byte[] qualifierB,
byte[] valueB)
Validate that result contains two specified keys, exactly.
|
private void |
assertEmptyResult(org.apache.hadoop.hbase.client.Result result) |
(package private) static void |
assertIncrementKey(org.apache.hadoop.hbase.Cell key,
byte[] row,
byte[] family,
byte[] qualifier,
long value) |
private void |
assertKey(org.apache.hadoop.hbase.Cell key,
byte[] row,
byte[] family,
byte[] qualifier,
byte[] value) |
private void |
assertNResult(org.apache.hadoop.hbase.client.Result result,
byte[] row,
byte[][] families,
byte[][] qualifiers,
byte[][] values,
int[][] idxs) |
private void |
assertNResult(org.apache.hadoop.hbase.client.Result result,
byte[] row,
byte[] family,
byte[] qualifier,
long[] stamps,
byte[][] values,
int start,
int end) |
private void |
assertNullResult(org.apache.hadoop.hbase.client.Result result) |
private void |
assertNumKeys(org.apache.hadoop.hbase.client.Result result,
int n) |
private void |
assertRowCount(org.apache.hadoop.hbase.client.Table t,
int expected) |
private void |
assertSingleResult(org.apache.hadoop.hbase.client.Result result,
byte[] row,
byte[] family,
byte[] qualifier,
byte[] value) |
private void |
assertSingleResult(org.apache.hadoop.hbase.client.Result result,
byte[] row,
byte[] family,
byte[] qualifier,
long value) |
private void |
assertSingleResult(org.apache.hadoop.hbase.client.Result result,
byte[] row,
byte[] family,
byte[] qualifier,
long ts,
byte[] value) |
private org.apache.hadoop.hbase.client.ResultScanner |
buildScanner(String keyPrefix,
String value,
org.apache.hadoop.hbase.client.Table ht) |
private org.apache.hadoop.hbase.client.Scan |
createScanWithRowFilter(byte[] key) |
private org.apache.hadoop.hbase.client.Scan |
createScanWithRowFilter(byte[] key,
byte[] startRow,
org.apache.hadoop.hbase.CompareOperator op) |
private void |
deleteColumns(org.apache.hadoop.hbase.client.Table ht,
String value,
String keyPrefix) |
private List<org.apache.hadoop.hbase.client.Result> |
doAppend(boolean walUsed) |
(package private) static boolean |
equals(byte[] left,
byte[] right) |
private void |
getAllVersionsAndVerify(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long[] stamps,
byte[][] values,
int start,
int end) |
private int |
getNumberOfRows(String keyPrefix,
String value,
org.apache.hadoop.hbase.client.Table ht) |
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,
byte[] fam) |
private org.apache.hadoop.hbase.client.metrics.ScanMetrics |
getScanMetrics(org.apache.hadoop.hbase.client.Scan scan) |
private org.apache.hadoop.hbase.client.Result |
getSingleScanResult(org.apache.hadoop.hbase.client.Table ht,
org.apache.hadoop.hbase.client.Scan scan) |
private void |
getTestNull(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] value) |
private void |
getTestNull(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
long value) |
private void |
getVerifySingleColumn(org.apache.hadoop.hbase.client.Table ht,
byte[][] ROWS,
int ROWIDX,
byte[][] FAMILIES,
int FAMILYIDX,
byte[][] QUALIFIERS,
int QUALIFIERIDX,
byte[][] VALUES,
int VALUEIDX)
Verify a single column using gets.
|
private void |
getVerifySingleEmpty(org.apache.hadoop.hbase.client.Table ht,
byte[][] ROWS,
int ROWIDX,
byte[][] FAMILIES,
int FAMILYIDX,
byte[][] QUALIFIERS,
int QUALIFIERIDX)
Verify we do not read any values by accident around a single column
Same requirements as getVerifySingleColumn
|
private void |
getVersionAndVerify(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long stamp,
byte[] value) |
private void |
getVersionAndVerifyMissing(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long stamp) |
private void |
getVersionRangeAndVerify(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long[] stamps,
byte[][] values,
int start,
int end) |
private void |
getVersionRangeAndVerifyGreaterThan(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long[] stamps,
byte[][] values,
int start,
int end) |
protected static void |
initialize(Class<?>... cps) |
private byte[][] |
makeN(byte[] base,
int n) |
private byte[][] |
makeNAscii(byte[] base,
int n) |
private byte[][] |
makeNBig(byte[] base,
int n) |
private long[] |
makeStamps(int n) |
private void |
putRows(org.apache.hadoop.hbase.client.Table ht,
int numRows,
String value,
String key) |
private void |
reverseScanTest(org.apache.hadoop.hbase.client.Table table,
boolean small) |
private void |
scanAllVersionsAndVerify(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long[] stamps,
byte[][] values,
int start,
int end) |
private void |
scanTestNull(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] value) |
private void |
scanTestNull(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] value,
boolean isReversedScan) |
private void |
scanVerifySingleColumn(org.apache.hadoop.hbase.client.Table ht,
byte[][] ROWS,
int ROWIDX,
byte[][] FAMILIES,
int FAMILYIDX,
byte[][] QUALIFIERS,
int QUALIFIERIDX,
byte[][] VALUES,
int VALUEIDX)
Verify a single column using scanners.
|
private void |
scanVerifySingleEmpty(org.apache.hadoop.hbase.client.Table ht,
byte[][] ROWS,
int ROWIDX,
byte[][] FAMILIES,
int FAMILYIDX,
byte[][] QUALIFIERS,
int QUALIFIERIDX) |
private void |
scanVersionAndVerify(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long stamp,
byte[] value) |
private void |
scanVersionAndVerifyMissing(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long stamp) |
private void |
scanVersionRangeAndVerify(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long[] stamps,
byte[][] values,
int start,
int end) |
private void |
scanVersionRangeAndVerifyGreaterThan(org.apache.hadoop.hbase.client.Table ht,
byte[] row,
byte[] family,
byte[] qualifier,
long[] stamps,
byte[][] values,
int start,
int end) |
static void |
setUpBeforeClass() |
private void |
singleRowGetTest(org.apache.hadoop.hbase.client.Table ht,
byte[][] ROWS,
byte[][] FAMILIES,
byte[][] QUALIFIERS,
byte[][] VALUES) |
private void |
singleRowScanTest(org.apache.hadoop.hbase.client.Table ht,
byte[][] ROWS,
byte[][] FAMILIES,
byte[][] QUALIFIERS,
byte[][] VALUES) |
private List<org.apache.hadoop.hbase.HRegionLocation> |
splitTable(org.apache.hadoop.hbase.client.Table t) |
static void |
tearDownAfterClass() |
void |
testAddKeyValue() |
void |
testAppend() |
void |
testAppendWithoutWAL() |
void |
testBatchAppendWithReturnResultFalse() |
void |
testBatchOperationsWithErrors()
Test batch operations with combination of valid and invalid args
|
void |
testCacheOnWriteEvictOnClose()
Tests that cache on write works all the way up from the client-side.
|
void |
testCellSizeLimit() |
void |
testCellUtilTypeMethods() |
void |
testCheckAndDelete() |
void |
testCheckAndDeleteWithCompareOp() |
void |
testCheckAndMutateWithTimeRange() |
void |
testCheckAndPut() |
void |
testCheckAndPutWithCompareOp() |
void |
testClientPoolRoundRobin() |
void |
testClientPoolThreadLocal() |
void |
testCreateTableWithZeroRegionReplicas() |
void |
testDeleteFamilyVersion() |
void |
testDeleteFamilyVersionWithOtherDeletes() |
void |
testDeleteLatestVersionOfSpecifiedColumn() |
void |
testDeletes() |
void |
testDeleteSpecifiedVersionOfSpecifiedColumn() |
void |
testDeletesWithReverseScan() |
void |
testDeleteWithFailed() |
void |
testDuplicateAppend()
Test append result when there are duplicate rpc request.
|
void |
testDuplicateVersions() |
void |
testEmptyFilterList() |
void |
testFilterAcrossMultipleRegions()
Test filters when multiple regions.
|
void |
testFilterAllRecords() |
void |
testFilters() |
void |
testFiltersWithReverseScan() |
void |
testFilterWithLongCompartor() |
void |
testGet_EmptyTable() |
void |
testGet_NonExistentRow() |
void |
testGet_NullQualifier() |
void |
testGetClosestRowBefore() |
void |
testGetConfiguration()
Verifies that getConfiguration returns the same Configuration object used
to create the HTable instance.
|
void |
testGetRegionsInRange() |
void |
testGetStartEndKeysWithRegionReplicas() |
void |
testHBase737()
test for HBASE-737
|
void |
testJira6912() |
void |
testJiraTest1014()
HBASE-1014
commit(BatchUpdate) method should return timestamp
|
void |
testJiraTest1182()
HBASE-1182
Scan for columns > some timestamp
|
void |
testJiraTest33()
HBASE-33
Add a HTable get/obtainScanner method that retrieves all versions of a
particular column and row between two timestamps
|
void |
testJiraTest52()
HBASE-52
Add a means of scanning over all versions
|
void |
testJiraTest861()
HBASE-861
get with timestamp will return a value if there is a version with an
earlier timestamp
|
void |
testJiraTest867()
HBASE-867
If millions of columns in a column family, hbase scanner won't come up
Test will create numRows rows, each with numColsPerRow columns
(1 version each), and attempt to scan them all.
|
void |
testKeepDeletedCells()
Basic client side validation of HBASE-4536
|
void |
testKeyOnlyFilter() |
void |
testKeyOnlyFilterWithReverseScan() |
void |
testListTables() |
void |
testMajorCompactionBetweenTwoUpdates() |
void |
testMaxKeyValueSize() |
void |
testMillions() |
void |
testMiscHTableStuff() |
void |
testModifyTableWithZeroRegionReplicas() |
void |
testMultipleRegionsAndBatchPuts() |
void |
testMultipleRowMultipleFamily() |
void |
testMultiRowMutation() |
void |
testNegativeTimestamp() |
void |
testNonCachedGetRegionLocation() |
void |
testNull() |
void |
testNullQualifier() |
void |
testNullWithReverseScan() |
void |
testPurgeFutureDeletes()
Basic client side validation of HBASE-10118
|
void |
testPut() |
void |
testPutNoCF() |
void |
testRawScanRespectsVersions() |
void |
testReadWithFilter()
Test for HBASE-17125
|
void |
testRegionCache() |
void |
testReversedScanUnderMultiRegions()
Tests reversed scan under multi regions
|
void |
testRowMutation() |
void |
testRowsPut() |
void |
testRowsPutBufferedManyManyFlushes() |
void |
testScan_NullQualifier() |
void |
testScanMetrics()
Test ScanMetrics
|
void |
testScanVariableReuse()
For HBASE-2156
|
void |
testSimpleMissing()
Test simple table and non-existent row cases.
|
void |
testSimpleMissingWithReverseScan()
Test simple table and non-existent row cases.
|
void |
testSingleRowMultipleFamily()
Test basic puts, gets, scans, and deletes for a single row
in a multiple family table.
|
void |
testSmallReversedScanUnderMultiRegions()
Tests reversed scan under multi regions
|
void |
testSmallScan() |
void |
testSuperSimple() |
void |
testSuperSimpleWithReverseScan() |
void |
testUnmanagedHConnection()
simple test that just executes parts of the client
API that accept a pre-created Connection instance
|
void |
testUnmanagedHConnectionReconnect()
test of that unmanaged HConnections are able to reconnect
properly (see HBASE-5058)
|
void |
testUpdates() |
void |
testUpdatesWithMajorCompaction() |
void |
testVersionLimits() |
void |
testVersions() |
void |
testWeirdCacheBehaviour()
Test from client side of an involved filter against a multi family that
involves deletes.
|
private void |
waitForStoreFileCount(org.apache.hadoop.hbase.regionserver.HStore store,
int count,
int timeout) |
private List<org.apache.hadoop.hbase.HRegionLocation> |
waitOnSplit(org.apache.hadoop.hbase.client.Table t) |
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
protected static final HBaseTestingUtility TEST_UTIL
private static byte[] ROW
private static byte[] FAMILY
private static final byte[] INVALID_FAMILY
private static byte[] QUALIFIER
private static byte[] VALUE
protected static int SLAVES
public org.junit.rules.TestName name
public TestFromClientSide()
protected static final void initialize(Class<?>... cps) throws Exception
Exceptionpublic static void setUpBeforeClass() throws Exception
Exceptionpublic static void tearDownAfterClass() throws Exception
Exceptionpublic void testDuplicateAppend() throws Exception
Exceptionpublic void testKeepDeletedCells() throws Exception
Exceptionpublic void testPurgeFutureDeletes() throws Exception
Exceptionpublic void testGetConfiguration() throws Exception
Exceptionpublic void testWeirdCacheBehaviour() throws Exception
Exceptionprivate void deleteColumns(org.apache.hadoop.hbase.client.Table ht, String value, String keyPrefix) throws IOException
IOExceptionprivate int getNumberOfRows(String keyPrefix, String value, org.apache.hadoop.hbase.client.Table ht) throws Exception
Exceptionprivate org.apache.hadoop.hbase.client.ResultScanner buildScanner(String keyPrefix, String value, org.apache.hadoop.hbase.client.Table ht) throws IOException
IOExceptionprivate void putRows(org.apache.hadoop.hbase.client.Table ht, int numRows, String value, String key) throws IOException
IOExceptionpublic void testFilterAcrossMultipleRegions() throws IOException, InterruptedException
IOExceptionInterruptedExceptionprivate org.apache.hadoop.hbase.client.Scan createScanWithRowFilter(byte[] key)
private org.apache.hadoop.hbase.client.Scan createScanWithRowFilter(byte[] key, byte[] startRow, org.apache.hadoop.hbase.CompareOperator op)
private void assertRowCount(org.apache.hadoop.hbase.client.Table t, int expected) throws IOException
IOExceptionprivate List<org.apache.hadoop.hbase.HRegionLocation> splitTable(org.apache.hadoop.hbase.client.Table t) throws IOException, InterruptedException
IOExceptionInterruptedExceptionprivate List<org.apache.hadoop.hbase.HRegionLocation> waitOnSplit(org.apache.hadoop.hbase.client.Table t) throws IOException
IOExceptionpublic void testSuperSimple() throws Exception
Exceptionpublic void testMaxKeyValueSize() throws Exception
Exceptionpublic void testFilters() throws Exception
Exceptionpublic void testFilterWithLongCompartor() throws Exception
Exceptionpublic void testKeyOnlyFilter() throws Exception
Exceptionpublic void testSimpleMissing() throws Exception
Exceptionpublic void testSingleRowMultipleFamily() throws Exception
Exceptionpublic void testNullQualifier() throws Exception
Exceptionpublic void testVersions() throws Exception
Exceptionpublic void testVersionLimits() throws Exception
Exceptionpublic void testDeleteFamilyVersion() throws Exception
Exceptionpublic void testDeleteFamilyVersionWithOtherDeletes() throws Exception
Exceptionpublic void testDeleteWithFailed() throws Exception
Exceptionpublic void testDeletes() throws Exception
Exceptionpublic void testBatchOperationsWithErrors() throws Exception
Exceptionpublic void testMillions() throws Exception
Exceptionpublic void testMultipleRegionsAndBatchPuts() throws Exception
Exceptionpublic void testMultipleRowMultipleFamily() throws Exception
Exceptionpublic void testJiraTest867() throws Exception
Exceptionpublic void testJiraTest861() throws Exception
Exceptionpublic void testJiraTest33() throws Exception
Exceptionpublic void testJiraTest1014() throws Exception
Exceptionpublic void testJiraTest1182() throws Exception
Exceptionpublic void testJiraTest52() throws Exception
Exceptionprivate void getVersionRangeAndVerifyGreaterThan(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long[] stamps, byte[][] values, int start, int end) throws IOException
IOExceptionprivate void getVersionRangeAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long[] stamps, byte[][] values, int start, int end) throws IOException
IOExceptionprivate void getAllVersionsAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long[] stamps, byte[][] values, int start, int end) throws IOException
IOExceptionprivate void scanVersionRangeAndVerifyGreaterThan(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long[] stamps, byte[][] values, int start, int end) throws IOException
IOExceptionprivate void scanVersionRangeAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long[] stamps, byte[][] values, int start, int end) throws IOException
IOExceptionprivate void scanAllVersionsAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long[] stamps, byte[][] values, int start, int end) throws IOException
IOExceptionprivate void getVersionAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp, byte[] value) throws Exception
Exceptionprivate void getVersionAndVerifyMissing(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp) throws Exception
Exceptionprivate void scanVersionAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp, byte[] value) throws Exception
Exceptionprivate void scanVersionAndVerifyMissing(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp) throws Exception
Exceptionprivate void getTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] value) throws Exception
Exceptionprivate void getTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, long value) throws Exception
Exceptionprivate void scanTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] value) throws Exception
Exceptionprivate void scanTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] value, boolean isReversedScan) throws Exception
Exceptionprivate void singleRowGetTest(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, byte[][] FAMILIES, byte[][] QUALIFIERS, byte[][] VALUES) throws Exception
Exceptionprivate void singleRowScanTest(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, byte[][] FAMILIES, byte[][] QUALIFIERS, byte[][] VALUES) throws Exception
Exceptionprivate void getVerifySingleColumn(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, int ROWIDX, byte[][] FAMILIES, int FAMILYIDX, byte[][] QUALIFIERS, int QUALIFIERIDX, byte[][] VALUES, int VALUEIDX) throws Exception
Exceptionprivate void scanVerifySingleColumn(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, int ROWIDX, byte[][] FAMILIES, int FAMILYIDX, byte[][] QUALIFIERS, int QUALIFIERIDX, byte[][] VALUES, int VALUEIDX) throws Exception
Exceptionprivate void getVerifySingleEmpty(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, int ROWIDX, byte[][] FAMILIES, int FAMILYIDX, byte[][] QUALIFIERS, int QUALIFIERIDX) throws Exception
Exceptionprivate void scanVerifySingleEmpty(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, int ROWIDX, byte[][] FAMILIES, int FAMILYIDX, byte[][] QUALIFIERS, int QUALIFIERIDX) throws Exception
Exceptionprivate void assertKey(org.apache.hadoop.hbase.Cell key, byte[] row, byte[] family, byte[] qualifier, byte[] value) throws Exception
Exceptionstatic void assertIncrementKey(org.apache.hadoop.hbase.Cell key, byte[] row, byte[] family, byte[] qualifier, long value) throws Exception
Exceptionprivate void assertNumKeys(org.apache.hadoop.hbase.client.Result result, int n) throws Exception
Exceptionprivate void assertNResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[][] families, byte[][] qualifiers, byte[][] values, int[][] idxs) throws Exception
Exceptionprivate void assertNResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] family, byte[] qualifier, long[] stamps, byte[][] values, int start, int end) throws IOException
IOExceptionprivate void assertDoubleResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] familyA, byte[] qualifierA, byte[] valueA, byte[] familyB, byte[] qualifierB, byte[] valueB) throws Exception
Exceptionprivate void assertSingleResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] family, byte[] qualifier, byte[] value) throws Exception
Exceptionprivate void assertSingleResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] family, byte[] qualifier, long value) throws Exception
Exceptionprivate void assertSingleResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] family, byte[] qualifier, long ts, byte[] value) throws Exception
Exceptionprivate void assertEmptyResult(org.apache.hadoop.hbase.client.Result result) throws Exception
Exceptionprivate void assertNullResult(org.apache.hadoop.hbase.client.Result result) throws Exception
Exceptionprivate org.apache.hadoop.hbase.client.Result getSingleScanResult(org.apache.hadoop.hbase.client.Table ht, org.apache.hadoop.hbase.client.Scan scan) throws IOException
IOExceptionprivate byte[][] makeNAscii(byte[] base, int n)
private byte[][] makeN(byte[] base, int n)
private byte[][] makeNBig(byte[] base, int n)
private long[] makeStamps(int n)
static boolean equals(byte[] left, byte[] right)
public void testDuplicateVersions() throws Exception
Exceptionpublic void testUpdates() throws Exception
Exceptionpublic void testUpdatesWithMajorCompaction() throws Exception
Exceptionpublic void testMajorCompactionBetweenTwoUpdates() throws Exception
Exceptionpublic void testGet_EmptyTable() throws IOException
IOExceptionpublic void testGet_NullQualifier() throws IOException
IOExceptionpublic void testGet_NonExistentRow() throws IOException
IOExceptionpublic void testPut() throws IOException
IOExceptionpublic void testPutNoCF() throws IOException
IOExceptionpublic void testRowsPut() throws IOException
IOExceptionpublic void testRowsPutBufferedManyManyFlushes() throws IOException
IOExceptionpublic void testAddKeyValue() throws IOException
IOExceptionpublic void testHBase737() throws IOException
IOExceptionpublic void testListTables() throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void testUnmanagedHConnection() throws IOException
IOExceptionpublic void testUnmanagedHConnectionReconnect() throws Exception
Exceptionpublic void testMiscHTableStuff() throws IOException
IOExceptionpublic void testGetClosestRowBefore() throws IOException, InterruptedException
IOExceptionInterruptedExceptionprivate org.apache.hadoop.hbase.client.Result getReverseScanResult(org.apache.hadoop.hbase.client.Table table, byte[] row, byte[] fam) throws IOException
IOExceptionpublic void testScanVariableReuse() throws Exception
Exceptionpublic 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
Exceptionprivate org.apache.hadoop.hbase.client.metrics.ScanMetrics getScanMetrics(org.apache.hadoop.hbase.client.Scan scan) 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 testGetStartEndKeysWithRegionReplicas() throws IOException
IOExceptionpublic void testFilterAllRecords() throws IOException
IOExceptionpublic void testRegionCache() throws IOException
IOExceptionpublic void testCellSizeLimit() 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
ExceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.