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
Exception
public static void setUpBeforeClass() throws Exception
Exception
public static void tearDownAfterClass() throws Exception
Exception
public void testDuplicateAppend() throws Exception
Exception
public void testKeepDeletedCells() throws Exception
Exception
public void testPurgeFutureDeletes() throws Exception
Exception
public void testGetConfiguration() throws Exception
Exception
public void testWeirdCacheBehaviour() throws Exception
Exception
private void deleteColumns(org.apache.hadoop.hbase.client.Table ht, String value, String keyPrefix) throws IOException
IOException
private int getNumberOfRows(String keyPrefix, String value, org.apache.hadoop.hbase.client.Table ht) throws Exception
Exception
private org.apache.hadoop.hbase.client.ResultScanner buildScanner(String keyPrefix, String value, org.apache.hadoop.hbase.client.Table ht) throws IOException
IOException
private void putRows(org.apache.hadoop.hbase.client.Table ht, int numRows, String value, String key) throws IOException
IOException
public void testFilterAcrossMultipleRegions() throws IOException, InterruptedException
IOException
InterruptedException
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 assertRowCount(org.apache.hadoop.hbase.client.Table t, int expected) throws IOException
IOException
private List<org.apache.hadoop.hbase.HRegionLocation> splitTable(org.apache.hadoop.hbase.client.Table t) throws IOException, InterruptedException
IOException
InterruptedException
private List<org.apache.hadoop.hbase.HRegionLocation> waitOnSplit(org.apache.hadoop.hbase.client.Table t) throws IOException
IOException
public void testSuperSimple() throws Exception
Exception
public void testMaxKeyValueSize() throws Exception
Exception
public void testFilters() throws Exception
Exception
public void testFilterWithLongCompartor() throws Exception
Exception
public void testKeyOnlyFilter() throws Exception
Exception
public void testSimpleMissing() throws Exception
Exception
public void testSingleRowMultipleFamily() throws Exception
Exception
public void testNullQualifier() throws Exception
Exception
public void testVersions() throws Exception
Exception
public void testVersionLimits() throws Exception
Exception
public void testDeleteFamilyVersion() throws Exception
Exception
public void testDeleteFamilyVersionWithOtherDeletes() throws Exception
Exception
public void testDeleteWithFailed() throws Exception
Exception
public void testDeletes() throws Exception
Exception
public void testBatchOperationsWithErrors() throws Exception
Exception
public void testMillions() throws Exception
Exception
public void testMultipleRegionsAndBatchPuts() throws Exception
Exception
public void testMultipleRowMultipleFamily() throws Exception
Exception
public void testJiraTest867() throws Exception
Exception
public void testJiraTest861() throws Exception
Exception
public void testJiraTest33() throws Exception
Exception
public void testJiraTest1014() throws Exception
Exception
public void testJiraTest1182() throws Exception
Exception
public void testJiraTest52() throws Exception
Exception
private 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
IOException
private 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
IOException
private 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
IOException
private 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
IOException
private 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
IOException
private 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
IOException
private void getVersionAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp, byte[] value) throws Exception
Exception
private void getVersionAndVerifyMissing(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp) throws Exception
Exception
private void scanVersionAndVerify(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp, byte[] value) throws Exception
Exception
private void scanVersionAndVerifyMissing(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] qualifier, long stamp) throws Exception
Exception
private void getTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] value) throws Exception
Exception
private void getTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, long value) throws Exception
Exception
private void scanTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] value) throws Exception
Exception
private void scanTestNull(org.apache.hadoop.hbase.client.Table ht, byte[] row, byte[] family, byte[] value, boolean isReversedScan) throws Exception
Exception
private void singleRowGetTest(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, byte[][] FAMILIES, byte[][] QUALIFIERS, byte[][] VALUES) throws Exception
Exception
private void singleRowScanTest(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, byte[][] FAMILIES, byte[][] QUALIFIERS, byte[][] VALUES) throws Exception
Exception
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) throws Exception
Exception
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) throws Exception
Exception
private void getVerifySingleEmpty(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, int ROWIDX, byte[][] FAMILIES, int FAMILYIDX, byte[][] QUALIFIERS, int QUALIFIERIDX) throws Exception
Exception
private void scanVerifySingleEmpty(org.apache.hadoop.hbase.client.Table ht, byte[][] ROWS, int ROWIDX, byte[][] FAMILIES, int FAMILYIDX, byte[][] QUALIFIERS, int QUALIFIERIDX) throws Exception
Exception
private void assertKey(org.apache.hadoop.hbase.Cell key, byte[] row, byte[] family, byte[] qualifier, byte[] value) throws Exception
Exception
static void assertIncrementKey(org.apache.hadoop.hbase.Cell key, byte[] row, byte[] family, byte[] qualifier, long value) throws Exception
Exception
private void assertNumKeys(org.apache.hadoop.hbase.client.Result result, int n) throws Exception
Exception
private void assertNResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[][] families, byte[][] qualifiers, byte[][] values, int[][] idxs) throws Exception
Exception
private 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
IOException
private 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
Exception
private void assertSingleResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] family, byte[] qualifier, byte[] value) throws Exception
Exception
private void assertSingleResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] family, byte[] qualifier, long value) throws Exception
Exception
private void assertSingleResult(org.apache.hadoop.hbase.client.Result result, byte[] row, byte[] family, byte[] qualifier, long ts, byte[] value) throws Exception
Exception
private void assertEmptyResult(org.apache.hadoop.hbase.client.Result result) throws Exception
Exception
private void assertNullResult(org.apache.hadoop.hbase.client.Result result) throws Exception
Exception
private org.apache.hadoop.hbase.client.Result getSingleScanResult(org.apache.hadoop.hbase.client.Table ht, org.apache.hadoop.hbase.client.Scan scan) throws IOException
IOException
private 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
Exception
public void testUpdates() throws Exception
Exception
public void testUpdatesWithMajorCompaction() throws Exception
Exception
public void testMajorCompactionBetweenTwoUpdates() throws Exception
Exception
public void testGet_EmptyTable() throws IOException
IOException
public void testGet_NullQualifier() throws IOException
IOException
public void testGet_NonExistentRow() throws IOException
IOException
public void testPut() throws IOException
IOException
public void testPutNoCF() throws IOException
IOException
public void testRowsPut() throws IOException
IOException
public void testRowsPutBufferedManyManyFlushes() throws IOException
IOException
public void testAddKeyValue() throws IOException
IOException
public void testHBase737() throws IOException
IOException
public void testListTables() throws IOException, InterruptedException
IOException
InterruptedException
public void testUnmanagedHConnection() throws IOException
IOException
public void testUnmanagedHConnectionReconnect() throws Exception
Exception
public void testMiscHTableStuff() throws IOException
IOException
public void testGetClosestRowBefore() throws IOException, InterruptedException
IOException
InterruptedException
private org.apache.hadoop.hbase.client.Result getReverseScanResult(org.apache.hadoop.hbase.client.Table table, byte[] row, byte[] fam) throws IOException
IOException
public void testScanVariableReuse() throws Exception
Exception
public void testMultiRowMutation() throws Exception
Exception
public void testRowMutation() throws Exception
Exception
public void testBatchAppendWithReturnResultFalse() throws Exception
Exception
public void testAppend() throws Exception
Exception
private List<org.apache.hadoop.hbase.client.Result> doAppend(boolean walUsed) throws IOException
IOException
public void testAppendWithoutWAL() throws Exception
Exception
public void testClientPoolRoundRobin() throws IOException
IOException
public void testClientPoolThreadLocal() throws IOException
IOException
public void testCheckAndPut() throws IOException
IOException
public void testCheckAndMutateWithTimeRange() throws IOException
IOException
public void testCheckAndPutWithCompareOp() throws IOException
IOException
public void testCheckAndDelete() throws IOException
IOException
public void testCheckAndDeleteWithCompareOp() throws IOException
IOException
public void testScanMetrics() throws Exception
Exception
private org.apache.hadoop.hbase.client.metrics.ScanMetrics getScanMetrics(org.apache.hadoop.hbase.client.Scan scan) throws Exception
Exception
public void testCacheOnWriteEvictOnClose() throws Exception
Exception
private void waitForStoreFileCount(org.apache.hadoop.hbase.regionserver.HStore store, int count, int timeout) throws InterruptedException
InterruptedException
public void testNonCachedGetRegionLocation() throws Exception
Exception
public void testGetRegionsInRange() throws Exception
Exception
private List<org.apache.hadoop.hbase.HRegionLocation> getRegionsInRange(org.apache.hadoop.hbase.TableName tableName, byte[] startKey, byte[] endKey) throws IOException
IOException
public void testJira6912() throws Exception
Exception
public void testScan_NullQualifier() throws IOException
IOException
public void testNegativeTimestamp() throws IOException
IOException
public void testRawScanRespectsVersions() throws Exception
Exception
public void testEmptyFilterList() throws Exception
Exception
public void testSmallScan() throws Exception
Exception
public void testSuperSimpleWithReverseScan() throws Exception
Exception
public void testFiltersWithReverseScan() throws Exception
Exception
public void testKeyOnlyFilterWithReverseScan() throws Exception
Exception
public void testSimpleMissingWithReverseScan() throws Exception
Exception
public void testNullWithReverseScan() throws Exception
Exception
public void testDeletesWithReverseScan() throws Exception
Exception
public void testReversedScanUnderMultiRegions() throws Exception
Exception
public void testSmallReversedScanUnderMultiRegions() throws Exception
Exception
private void reverseScanTest(org.apache.hadoop.hbase.client.Table table, boolean small) throws IOException
IOException
public void testGetStartEndKeysWithRegionReplicas() throws IOException
IOException
public void testFilterAllRecords() throws IOException
IOException
public void testRegionCache() throws IOException
IOException
public void testCellSizeLimit() throws IOException
IOException
public void testDeleteSpecifiedVersionOfSpecifiedColumn() throws Exception
Exception
public void testDeleteLatestVersionOfSpecifiedColumn() throws Exception
Exception
public void testReadWithFilter() throws Exception
Exception
public void testCellUtilTypeMethods() throws IOException
IOException
public void testCreateTableWithZeroRegionReplicas() throws Exception
Exception
public void testModifyTableWithZeroRegionReplicas() throws Exception
Exception
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.