Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.handler | |
org.apache.hadoop.hbase.master.procedure | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication | |
org.apache.hadoop.hbase.rest | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.snapshot | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.util.hbck | |
org.apache.hadoop.hbase.wal |
Modifier and Type | Class and Description |
---|---|
class |
IntegrationTestingUtility
Facility for integration/system tests.
|
Modifier and Type | Field and Description |
---|---|
protected HBaseTestingUtility |
HBaseTestCase.testUtil
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static HBaseTestingUtility |
HBaseTestingUtility.createLocalHTU()
Create an HBaseTestingUtility where all tmp files are written to the local test data dir.
|
static HBaseTestingUtility |
HBaseTestingUtility.createLocalHTU(Configuration c)
Create an HBaseTestingUtility where all tmp files are written to the local test data dir.
|
Modifier and Type | Method and Description |
---|---|
static ZooKeeperWatcher |
HBaseTestingUtility.createAndForceNodeToOpenedState(HBaseTestingUtility TEST_UTIL,
HRegion region,
ServerName serverName)
Creates a znode with OPENED state.
|
static ZooKeeperWatcher |
HBaseTestingUtility.createAndForceNodeToOpenedState(HBaseTestingUtility TEST_UTIL,
Region region,
ServerName serverName)
Creates a znode with OPENED state.
|
static ZooKeeperWatcher |
HBaseTestingUtility.getZooKeeperWatcher(HBaseTestingUtility TEST_UTIL)
Gets a ZooKeeperWatcher.
|
void |
TestAcidGuarantees.setHBaseTestingUtil(HBaseTestingUtility util) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestFromClientSide.TEST_UTIL |
protected static HBaseTestingUtility |
TestFromClientSideNoCodec.TEST_UTIL |
protected static HBaseTestingUtility |
TestSizeFailures.TEST_UTIL |
protected static HBaseTestingUtility |
AbstractTestShell.TEST_UTIL |
protected static HBaseTestingUtility |
TestSnapshotFromClient.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
TestTableSnapshotScanner.createTableAndSnapshot(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
int numRegions) |
static void |
TestMetaWithReplicas.shutdownMetaAndDoValidations(HBaseTestingUtility util) |
Constructor and Description |
---|
CreateTableThread(HBaseTestingUtility UTIL) |
Modifier and Type | Method and Description |
---|---|
static void |
TestTableSnapshotInputFormat.doTestWithMapReduce(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected void |
TestTableSnapshotInputFormat.testWithMapReduceImpl(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected void |
TestTableSnapshotInputFormat.testWithMockedMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int expectedNumSplits) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestSimpleTotalOrderPartitioner.TEST_UTIL |
protected static HBaseTestingUtility |
TestImportTsv.util |
protected static HBaseTestingUtility |
TestImportTSVWithOperationAttributes.util |
protected static HBaseTestingUtility |
TestImportTSVWithTTLs.util |
protected static HBaseTestingUtility |
TestImportTSVWithVisibilityLabels.util |
protected HBaseTestingUtility |
TableSnapshotInputFormatTestBase.UTIL |
protected static HBaseTestingUtility |
TestTableMapReduceBase.UTIL |
Modifier and Type | Method and Description |
---|---|
protected static void |
TableSnapshotInputFormatTestBase.createTableAndSnapshot(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
int numRegions) |
protected static Tool |
TestImportTsv.doMROnTableTest(HBaseTestingUtility util,
String family,
String data,
String[] args) |
protected static Tool |
TestImportTsv.doMROnTableTest(HBaseTestingUtility util,
String family,
String data,
String[] args,
int valueMultiplier)
Run an ImportTsv job and perform basic validation on the results.
|
protected static Tool |
TestImportTSVWithTTLs.doMROnTableTest(HBaseTestingUtility util,
String family,
String data,
String[] args,
int valueMultiplier) |
protected static Tool |
TestImportTSVWithVisibilityLabels.doMROnTableTest(HBaseTestingUtility util,
String family,
String data,
String[] args,
int valueMultiplier)
Run an ImportTsv job and perform basic validation on the results.
|
static void |
TestTableSnapshotInputFormat.doTestWithMapReduce(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
byte[] startRow,
byte[] endRow,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected void |
TableSnapshotInputFormatTestBase.testWithMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected abstract void |
TableSnapshotInputFormatTestBase.testWithMapReduceImpl(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected void |
TestTableSnapshotInputFormat.testWithMapReduceImpl(HBaseTestingUtility util,
TableName tableName,
String snapshotName,
Path tableDir,
int numRegions,
int expectedNumSplits,
boolean shutdownCluster) |
protected abstract void |
TableSnapshotInputFormatTestBase.testWithMockedMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int expectedNumSplits) |
void |
TestTableSnapshotInputFormat.testWithMockedMapReduce(HBaseTestingUtility util,
String snapshotName,
int numRegions,
int expectedNumSplits) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestWarmupRegion.TEST_UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
TestEnableTableHandler.createTable(HBaseTestingUtility testUtil,
HBaseAdmin admin,
HTableDescriptor htd,
byte[][] splitKeys) |
static void |
TestEnableTableHandler.createTable(HBaseTestingUtility testUtil,
HTableDescriptor htd,
byte[][] splitKeys) |
static void |
TestEnableTableHandler.deleteTable(HBaseTestingUtility testUtil,
HBaseAdmin admin,
TableName tableName) |
static void |
TestEnableTableHandler.deleteTable(HBaseTestingUtility testUtil,
TableName tableName) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestAddColumnFamilyProcedure.UTIL |
protected static HBaseTestingUtility |
TestCreateTableProcedure.UTIL |
protected static HBaseTestingUtility |
TestDeleteColumnFamilyProcedure.UTIL |
protected static HBaseTestingUtility |
TestDeleteTableProcedure.UTIL |
protected static HBaseTestingUtility |
TestDisableTableProcedure.UTIL |
protected static HBaseTestingUtility |
TestEnableTableProcedure.UTIL |
protected static HBaseTestingUtility |
TestMasterFailoverWithProcedures.UTIL |
protected static HBaseTestingUtility |
TestModifyColumnFamilyProcedure.UTIL |
protected static HBaseTestingUtility |
TestModifyTableProcedure.UTIL |
protected static HBaseTestingUtility |
TestProcedureAdmin.UTIL |
protected static HBaseTestingUtility |
TestTruncateTableProcedure.UTIL |
protected static HBaseTestingUtility |
TestWALProcedureStoreOnHDFS.UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
TestMasterFailoverWithProcedures.masterFailover(HBaseTestingUtility testUtil) |
static <TState> void |
TestMasterFailoverWithProcedures.testRecoveryAndDoubleExecution(HBaseTestingUtility testUtil,
long procId,
int lastStepBeforeFailover,
TState[] states) |
static void |
TestMasterFailoverWithProcedures.waitBackupMaster(HBaseTestingUtility testUtil,
HMaster oldMaster) |
Modifier and Type | Method and Description |
---|---|
static void |
TestRegionServerNoMaster.checkRegionIsClosed(HBaseTestingUtility HTU,
HRegionServer rs,
HRegionInfo hri) |
static void |
TestRegionServerNoMaster.checkRegionIsOpened(HBaseTestingUtility HTU,
HRegionServer rs,
HRegionInfo hri) |
static void |
TestRegionServerNoMaster.closeRegion(HBaseTestingUtility HTU,
HRegionServer rs,
HRegionInfo hri) |
static void |
TestRegionServerNoMaster.flushRegion(HBaseTestingUtility HTU,
HRegionInfo regionInfo)
Flush the given region in the mini cluster.
|
static void |
TestRegionServerNoMaster.openRegion(HBaseTestingUtility HTU,
HRegionServer rs,
HRegionInfo hri) |
static void |
TestRegionServerNoMaster.stopMasterAndAssignMeta(HBaseTestingUtility HTU) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestFSHLog.TEST_UTIL |
protected static HBaseTestingUtility |
TestProtobufLog.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestReplicationBase.utility1 |
protected static HBaseTestingUtility |
TestReplicationBase.utility2 |
Modifier and Type | Method and Description |
---|---|
void |
TestReplicationKillRS.loadTableAndKillRS(HBaseTestingUtility util)
Load up 1 tables over 2 region servers and kill a source during
the upload.
|
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
RowResourceBase.TEST_UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
SecureTestUtil.checkGlobalPerms(HBaseTestingUtility testUtil,
Permission.Action... actions) |
static void |
SecureTestUtil.createNamespace(HBaseTestingUtility testUtil,
NamespaceDescriptor nsDesc) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
Admin admin,
HTableDescriptor htd) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
Admin admin,
HTableDescriptor htd,
byte[][] splitKeys) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
HTableDescriptor htd) |
static void |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
HTableDescriptor htd,
byte[][] splitKeys) |
static Table |
SecureTestUtil.createTable(HBaseTestingUtility testUtil,
TableName tableName,
byte[][] families) |
static void |
SecureTestUtil.deleteNamespace(HBaseTestingUtility testUtil,
String namespace) |
static void |
SecureTestUtil.deleteTable(HBaseTestingUtility testUtil,
Admin admin,
TableName tableName) |
static void |
SecureTestUtil.deleteTable(HBaseTestingUtility testUtil,
TableName tableName) |
static void |
SecureTestUtil.grantGlobal(HBaseTestingUtility util,
String user,
Permission.Action... actions)
Grant permissions globally to the given user.
|
static void |
SecureTestUtil.grantGlobalUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
Permission.Action... actions)
Grant global permissions to the given user using AccessControlClient.
|
static void |
SecureTestUtil.grantOnNamespace(HBaseTestingUtility util,
String user,
String namespace,
Permission.Action... actions)
Grant permissions on a namespace to the given user.
|
static void |
SecureTestUtil.grantOnNamespaceUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
String namespace,
Permission.Action... actions)
Grant permissions on a namespace to the given user using AccessControl Client.
|
static void |
SecureTestUtil.grantOnTable(HBaseTestingUtility util,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Grant permissions on a table to the given user.
|
static void |
SecureTestUtil.grantOnTableUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Grant permissions on a table to the given user using AccessControlClient.
|
static void |
SecureTestUtil.revokeFromNamespace(HBaseTestingUtility util,
String user,
String namespace,
Permission.Action... actions)
Revoke permissions on a namespace from the given user.
|
static void |
SecureTestUtil.revokeFromNamespaceUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
String namespace,
Permission.Action... actions)
Revoke permissions on a namespace from the given user using AccessControl Client.
|
static void |
SecureTestUtil.revokeFromTable(HBaseTestingUtility util,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Revoke permissions on a table from the given user.
|
static void |
SecureTestUtil.revokeFromTableUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
TableName table,
byte[] family,
byte[] qualifier,
Permission.Action... actions)
Revoke permissions on a table from the given user using AccessControlClient.
|
static void |
SecureTestUtil.revokeGlobal(HBaseTestingUtility util,
String user,
Permission.Action... actions)
Revoke permissions globally from the given user.
|
static void |
SecureTestUtil.revokeGlobalUsingAccessControlClient(HBaseTestingUtility util,
Connection connection,
String user,
Permission.Action... actions)
Revoke global permissions from the given user using AccessControlClient.
|
Modifier and Type | Field and Description |
---|---|
static HBaseTestingUtility |
TestDefaultScanLabelGeneratorStack.TEST_UTIL |
static HBaseTestingUtility |
TestEnforcingScanLabelGenerator.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabels.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabelsReplication.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabelsWithDeletes.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabelsWithSLGStack.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLablesWithGroups.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityWithCheckAuths.TEST_UTIL |
static HBaseTestingUtility |
TestVisibilityLabelsReplication.TEST_UTIL1 |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestExportSnapshot.TEST_UTIL |
Modifier and Type | Method and Description |
---|---|
static ArrayList |
SnapshotTestingUtils.corruptSnapshot(HBaseTestingUtility util,
String snapshotName)
Corrupt the specified snapshot by deleting some files.
|
static void |
SnapshotTestingUtils.createTable(HBaseTestingUtility util,
TableName tableName,
byte[]... families) |
static void |
SnapshotTestingUtils.createTable(HBaseTestingUtility util,
TableName tableName,
int regionReplication,
byte[]... families) |
static void |
SnapshotTestingUtils.deleteArchiveDirectory(HBaseTestingUtility util) |
static void |
SnapshotTestingUtils.loadData(HBaseTestingUtility util,
BufferedMutator mutator,
int rows,
byte[]... families) |
static void |
SnapshotTestingUtils.loadData(HBaseTestingUtility util,
TableName tableName,
int rows,
byte[]... families) |
static void |
SnapshotTestingUtils.verifyRowCount(HBaseTestingUtility util,
TableName tableName,
long expectedRows) |
static void |
SnapshotTestingUtils.waitForTableToBeOnline(HBaseTestingUtility util,
TableName tableName) |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestCoprocessorScanPolicy.TEST_UTIL |
protected static HBaseTestingUtility |
TestMiniClusterLoadSequential.TEST_UTIL |
Modifier and Type | Method and Description |
---|---|
static void |
TestHBaseFsck.createTable(HBaseTestingUtility testUtil,
HTableDescriptor htd,
byte[][] splitKeys) |
static void |
TestHBaseFsck.deleteTable(HBaseTestingUtility testUtil,
TableName tableName) |
static Path |
HFileArchiveTestingUtil.getStoreArchivePath(HBaseTestingUtility util,
String tableName,
byte[] storeName) |
Constructor and Description |
---|
MockServer(HBaseTestingUtility htu) |
MockServer(HBaseTestingUtility htu,
boolean zkw) |
Modifier and Type | Field and Description |
---|---|
protected HBaseTestingUtility |
OfflineMetaRebuildTestCore.TEST_UTIL |
Modifier and Type | Field and Description |
---|---|
protected static HBaseTestingUtility |
TestBoundedRegionGroupingProvider.TEST_UTIL |
protected static HBaseTestingUtility |
TestDefaultWALProvider.TEST_UTIL |
protected static HBaseTestingUtility |
TestWALFactory.TEST_UTIL |
protected static HBaseTestingUtility |
TestWALSplit.TEST_UTIL |