Uses of Class
org.apache.hadoop.hbase.HBaseTestingUtil
Package
Description
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase
Modifier and TypeClassDescriptionclass
Facility for integration/system tests.Modifier and TypeMethodDescriptionMiniClusterRule.getTestingUtility()
Returns the underlying instance ofHBaseTestingUtil
Modifier and TypeMethodDescriptionstatic void
ProcedureTestUtil.waitUntilProcedureTimeoutIncrease
(HBaseTestingUtil util, Class<? extends org.apache.hadoop.hbase.procedure2.Procedure<?>> clazz, int times) static void
ProcedureTestUtil.waitUntilProcedureWaitingTimeout
(HBaseTestingUtil util, Class<? extends org.apache.hadoop.hbase.procedure2.Procedure<?>> clazz, long timeout) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.backup
Modifier and TypeFieldDescriptionprotected static HBaseTestingUtil
TestBackupBase.TEST_UTIL
protected static HBaseTestingUtil
TestBackupUtils.TEST_UTIL
protected static HBaseTestingUtil
TestBackupBase.TEST_UTIL2
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
AbstractTestAsyncTableRegionReplicasRead.TEST_UTIL
protected static final HBaseTestingUtil
AbstractTestCITimeout.TEST_UTIL
protected static final HBaseTestingUtil
AbstractTestScanCursor.TEST_UTIL
protected static final HBaseTestingUtil
AbstractTestShell.TEST_UTIL
protected static final HBaseTestingUtil
CloneSnapshotFromClientTestBase.TEST_UTIL
protected static final HBaseTestingUtil
MetaWithReplicasTestBase.TEST_UTIL
protected static final HBaseTestingUtil
RestoreSnapshotFromClientTestBase.TEST_UTIL
protected static HBaseTestingUtil
SnapshotWithAclTestBase.TEST_UTIL
protected static final HBaseTestingUtil
TestAdminBase.TEST_UTIL
protected static final HBaseTestingUtil
TestAppendFromClientSide.TEST_UTIL
protected static final HBaseTestingUtil
TestAsyncAdminBase.TEST_UTIL
protected static final HBaseTestingUtil
TestAvoidCellReferencesIntoShippedBlocks.TEST_UTIL
protected static final HBaseTestingUtil
TestBlockEvictionFromClient.TEST_UTIL
protected static final HBaseTestingUtil
TestFromClientSideNoCodec.TEST_UTIL
protected static final HBaseTestingUtil
TestFromClientSideScanExcpetion.TEST_UTIL
protected static final HBaseTestingUtil
TestIllegalTableDescriptor.TEST_UTIL
protected static final HBaseTestingUtil
TestIncrementsFromClientSide.TEST_UTIL
protected static final HBaseTestingUtil
TestSizeFailures.TEST_UTIL
protected static final HBaseTestingUtil
AbstractTestRegionLocator.UTIL
protected static final HBaseTestingUtil
ClientPushbackTestBase.UTIL
protected static final HBaseTestingUtil
TestSnapshotCloneIndependence.UTIL
protected static final HBaseTestingUtil
TestSnapshotFromClient.UTIL
protected static final HBaseTestingUtil
TestSnapshotTemporaryDirectory.UTIL
protected HBaseTestingUtil
TestServerLoadDurability.utility
Modifier and TypeMethodDescriptionprotected static void
AbstractTestUpdateConfiguration.addResourceToRegionServerConfiguration
(HBaseTestingUtil testUtil) static void
RegionReplicaTestHelper.assertReplicaDistributed
(HBaseTestingUtil util, Table t) static void
TestTableSnapshotScanner.blockUntilSplitFinished
(HBaseTestingUtil util, TableName tableName, int expectedRegionSize) static void
TestEnableTable.createTable
(HBaseTestingUtil testUtil, TableDescriptor tableDescriptor, byte[][] splitKeys) static void
TestTableSnapshotScanner.createTableAndSnapshot
(HBaseTestingUtil util, TableName tableName, String snapshotName, int numRegions) static void
TestEnableTable.deleteTable
(HBaseTestingUtil testUtil, TableName tableName) protected static void
AbstractTestUpdateConfiguration.setUpConfigurationFiles
(HBaseTestingUtil testUtil) static void
TestMetaWithReplicasShutdownHandling.shutdownMetaAndDoValidations
(HBaseTestingUtil util) protected void
CloneSnapshotFromClientTestBase.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
RestoreSnapshotFromClientTestBase.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobCloneSnapshotFromClientNormal.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientAfterSplittingRegions.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientAfterTruncate.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientClone.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientGetCompactionState.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientSchemaChange.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobRestoreSnapshotFromClientSimple.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.coprocessor
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.io.compress
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.io.hfile
ModifierConstructorDescriptionHFileTestRule
(HBaseTestingUtil testingUtility, org.junit.rules.TestName testName) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprotected static HBaseTestingUtil
TestNettyRpcServer.TEST_UTIL
protected static final HBaseTestingUtil
TestRpcSkipInitialSaslHandshake.TEST_UTIL
protected static final HBaseTestingUtil
TestSecurityRpcSentBytesMetrics.TEST_UTIL
protected static HBaseTestingUtil
TestSimpleRpcServer.TEST_UTIL
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.mapred
Modifier and TypeMethodDescriptionstatic void
TestTableSnapshotInputFormat.doTestWithMapReduce
(HBaseTestingUtil util, TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TestTableSnapshotInputFormat.testWithMapReduceImpl
(HBaseTestingUtil util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TestTableSnapshotInputFormat.testWithMockedMapReduce
(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionstatic final HBaseTestingUtil
MultiTableInputFormatTestBase.TEST_UTIL
protected static final HBaseTestingUtil
TestSimpleTotalOrderPartitioner.TEST_UTIL
protected static HBaseTestingUtil
TestImportTsv.util
protected static HBaseTestingUtil
TestImportTSVWithOperationAttributes.util
protected static HBaseTestingUtil
TestImportTSVWithTTLs.util
protected static HBaseTestingUtil
TestImportTSVWithVisibilityLabels.util
protected final HBaseTestingUtil
TableSnapshotInputFormatTestBase.UTIL
protected static final HBaseTestingUtil
TestImportExport.UTIL
protected static final HBaseTestingUtil
TestTableMapReduceBase.UTIL
protected static final HBaseTestingUtil
CopyTableToPeerClusterTestBase.UTIL1
protected static final HBaseTestingUtil
CopyTableToPeerClusterTestBase.UTIL2
Modifier and TypeMethodDescriptionprotected static void
TableSnapshotInputFormatTestBase.createTableAndSnapshot
(HBaseTestingUtil util, TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, int numRegions) protected static org.apache.hadoop.util.Tool
TestImportTsv.doMROnTableTest
(HBaseTestingUtil util, TableName table, String family, String data, Map<String, String> args) protected static org.apache.hadoop.util.Tool
TestImportTsv.doMROnTableTest
(HBaseTestingUtil util, TableName table, String family, String data, Map<String, String> args, int valueMultiplier, int expectedKVCount) Run an ImportTsv job and perform basic validation on the results.protected static org.apache.hadoop.util.Tool
TestImportTSVWithTTLs.doMROnTableTest
(HBaseTestingUtil util, String family, String data, String[] args, int valueMultiplier) protected static org.apache.hadoop.util.Tool
TestImportTSVWithVisibilityLabels.doMROnTableTest
(HBaseTestingUtil util, String family, String data, String[] args, int valueMultiplier) protected static org.apache.hadoop.util.Tool
TestImportTSVWithVisibilityLabels.doMROnTableTest
(HBaseTestingUtil util, String family, String data, String[] args, int valueMultiplier, int expectedKVCount) Run an ImportTsv job and perform basic validation on the results.static void
TestTableSnapshotInputFormat.doTestWithMapReduce
(HBaseTestingUtil util, TableName tableName, String snapshotName, byte[] startRow, byte[] endRow, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TableSnapshotInputFormatTestBase.testWithMapReduce
(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected abstract void
TableSnapshotInputFormatTestBase.testWithMapReduceImpl
(HBaseTestingUtil util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected void
TestTableSnapshotInputFormat.testWithMapReduceImpl
(HBaseTestingUtil util, TableName tableName, String snapshotName, org.apache.hadoop.fs.Path tableDir, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean shutdownCluster) protected abstract void
TableSnapshotInputFormatTestBase.testWithMockedMapReduce
(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) void
TestTableSnapshotInputFormat.testWithMockedMapReduce
(HBaseTestingUtil util, String snapshotName, int numRegions, int numSplitsPerRegion, int expectedNumSplits, boolean setLocalityEnabledTo) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
TestWarmupRegion.TEST_UTIL
protected HBaseTestingUtil
AbstractTestRestartCluster.UTIL
protected static final HBaseTestingUtil
TestMergeTableRegionsWhileRSCrash.UTIL
protected static final HBaseTestingUtil
TestSplitRegionWhileRSCrash.UTIL
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.mob
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.namequeues
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
TestTooLargeLog.TEST_UTIL
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.namespace
Modifier and TypeMethodDescriptionstatic void
TestNamespaceAuditor.waitForQuotaInitialize
(HBaseTestingUtil util) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.quotas
ModifierConstructorDescriptionSpaceQuotaHelperForTests
(HBaseTestingUtil testUtil, org.junit.rules.TestName testName, AtomicLong counter) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
TestCompactionPolicy.TEST_UTIL
protected static final HBaseTestingUtil
TestCompactionWithShippingCoprocessor.TEST_UTIL
protected static HBaseTestingUtil
TestHRegion.TEST_UTIL
protected static HBaseTestingUtil
TestRecoveredEditsReplayAndAbort.TEST_UTIL
TestCompactionArchiveIOException.testUtil
protected static final HBaseTestingUtil
TestSecureBulkLoadManager.testUtil
protected static HBaseTestingUtil
TestHRegionServerBulkLoad.UTIL
protected static final HBaseTestingUtil
TestSplitWithBlockingFiles.UTIL
protected static final HBaseTestingUtil
TestBulkLoadReplication.UTIL3
Modifier and TypeMethodDescriptionprotected void
TestBulkLoadReplication.assertBulkLoadConditions
(TableName tableName, byte[] row, byte[] value, HBaseTestingUtil utility, Table... tables) protected void
TestBulkLoadReplication.bulkLoadOnCluster
(TableName tableName, byte[] row, byte[] value, HBaseTestingUtil cluster) static void
TestRegionServerNoMaster.checkRegionIsClosed
(HBaseTestingUtil HTU, HRegionServer rs, RegionInfo hri) static void
TestRegionServerNoMaster.checkRegionIsOpened
(HBaseTestingUtil HTU, HRegionServer rs, RegionInfo hri) static void
TestRegionServerNoMaster.closeRegion
(HBaseTestingUtil HTU, HRegionServer rs, RegionInfo hri) static void
TestRegionServerNoMaster.flushRegion
(HBaseTestingUtil HTU, RegionInfo regionInfo) Flush the given region in the mini cluster.static void
TestRegionServerNoMaster.openRegion
(HBaseTestingUtil HTU, HRegionServer rs, RegionInfo hri) static void
TestRegionServerNoMaster.stopMasterAndCacheMetaLocation
(HBaseTestingUtil HTU) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
AbstractTestFSWAL.TEST_UTIL
protected static final HBaseTestingUtil
AbstractTestLogRolling.TEST_UTIL
protected static final HBaseTestingUtil
AbstractTestLogRollPeriod.TEST_UTIL
protected static final HBaseTestingUtil
AbstractTestProtobufLog.TEST_UTIL
protected static final HBaseTestingUtil
TestLogRollAbort.TEST_UTIL
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
SerialReplicationTestBase.UTIL
protected static final HBaseTestingUtil
SyncReplicationTestBase.UTIL1
protected static final HBaseTestingUtil
TestReplicationBase.UTIL1
protected static final HBaseTestingUtil
TestReplicationSyncUpToolBase.UTIL1
protected static final HBaseTestingUtil
SyncReplicationTestBase.UTIL2
protected static final HBaseTestingUtil
TestReplicationBase.UTIL2
protected static final HBaseTestingUtil
TestReplicationSyncUpToolBase.UTIL2
protected static HBaseTestingUtil
TestReplicationEditsDroppedWithDeletedTableCFs.utility1
protected static HBaseTestingUtil
TestReplicationEditsDroppedWithDroppedTable.utility1
protected static HBaseTestingUtil
TestReplicationStuckWithDeletedTableCFs.utility1
protected static HBaseTestingUtil
TestReplicationStuckWithDroppedTable.utility1
protected static HBaseTestingUtil
TestReplicationEditsDroppedWithDeletedTableCFs.utility2
protected static HBaseTestingUtil
TestReplicationEditsDroppedWithDroppedTable.utility2
protected static HBaseTestingUtil
TestReplicationStuckWithDeletedTableCFs.utility2
protected static HBaseTestingUtil
TestReplicationStuckWithDroppedTable.utility2
Modifier and TypeMethodDescriptionprotected String
TestReplicationBase.getClusterKey
(HBaseTestingUtil util) protected String
TestReplicationDisableInactivePeer.getClusterKey
(HBaseTestingUtil util) protected String
TestReplicationStatusAfterLagging.getClusterKey
(HBaseTestingUtil util) protected String
TestVerifyReplicationAdjunct.getClusterKey
(HBaseTestingUtil util) protected String
TestVerifyReplicationRpcConnectionUri.getClusterKey
(HBaseTestingUtil util) protected String
TestVerifyReplicationZkClusterKey.getClusterKey
(HBaseTestingUtil util) protected String
TestVerifyReplicationZkConnectionUri.getClusterKey
(HBaseTestingUtil util) protected static void
SyncReplicationTestBase.initTestingUtility
(HBaseTestingUtil util, String zkParent) protected void
TestReplicationKillRS.loadTableAndKillRS
(HBaseTestingUtil util) Load up 1 tables over 2 region servers and kill a source during the upload.protected static void
TestReplicationBase.setupConfig
(HBaseTestingUtil util, String znodeParent) protected static void
TestReplicationBase.stopAllRegionServers
(HBaseTestingUtil util) protected final void
SyncReplicationTestBase.verify
(HBaseTestingUtil util, int start, int end) protected final void
SyncReplicationTestBase.verifyNotReplicatedThroughRegion
(HBaseTestingUtil util, int start, int end) protected final void
SyncReplicationTestBase.verifyRemovedPeer
(String peerId, org.apache.hadoop.fs.Path remoteWALDir, HBaseTestingUtil utility) protected final void
SyncReplicationTestBase.verifyReplicationRequestRejection
(HBaseTestingUtil utility, boolean expectedRejection) protected final void
SyncReplicationTestBase.verifyThroughRegion
(HBaseTestingUtil util, int start, int end) protected final void
SyncReplicationTestBase.waitUntilDeleted
(HBaseTestingUtil util, org.apache.hadoop.fs.Path remoteWAL) protected final void
SyncReplicationTestBase.waitUntilReplicationDone
(HBaseTestingUtil util, int end) protected final void
SyncReplicationTestBase.write
(HBaseTestingUtil util, int start, int end) protected final void
SyncReplicationTestBase.writeAndVerifyReplication
(HBaseTestingUtil util1, HBaseTestingUtil util2, int start, int end) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.rest
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
RowResourceBase.TEST_UTIL
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.rsgroup
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.security
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
AbstractTestSecureIPC.TEST_UTIL
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.snapshot
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
TestExportSnapshot.TEST_UTIL
protected static final HBaseTestingUtil
TestExportSnapshotAdjunct.TEST_UTIL
protected static final HBaseTestingUtil
TestRestoreSnapshotHelper.TEST_UTIL
protected static final HBaseTestingUtil
TestFlushSnapshotFromClient.UTIL
protected static final HBaseTestingUtil
TestRestoreFlushSnapshotFromClient.UTIL
Modifier and TypeMethodDescriptionstatic void
SnapshotTestingUtils.confirmSnapshotValid
(HBaseTestingUtil testUtil, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshotDescriptor, TableName tableName, byte[] family) static ArrayList
SnapshotTestingUtils.corruptSnapshot
(HBaseTestingUtil util, String snapshotName) Corrupt the specified snapshot by deleting some files.static Table
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtil util, TableName tableName, byte[]... families) Create a Mob table.static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtil util, TableName tableName, byte[][] splitKeys, int regionReplication, byte[]... families) static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtil util, TableName tableName, byte[][] splitKeys, int regionReplication, String storeFileTracker, byte[]... families) static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtil util, TableName tableName, byte[][] splitKeys, int regionReplication, String storeFileTracker, String cpClassName, byte[]... families) static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtil util, TableName tableName, int regionReplication, byte[]... families) Create the Mob Table.static void
MobSnapshotTestingUtils.createMobTable
(HBaseTestingUtil util, TableName tableName, int regionReplication, String storeFileTracker, byte[]... families) static void
MobSnapshotTestingUtils.createPreSplitMobTable
(HBaseTestingUtil util, TableName tableName, int nRegions, byte[]... families) static void
SnapshotTestingUtils.createPreSplitTable
(HBaseTestingUtil util, TableName tableName, int nRegions, byte[]... families) static void
SnapshotTestingUtils.createTable
(HBaseTestingUtil util, TableName tableName, byte[]... families) static void
SnapshotTestingUtils.createTable
(HBaseTestingUtil util, TableName tableName, int regionReplication, byte[]... families) static void
SnapshotTestingUtils.createTable
(HBaseTestingUtil util, TableName tableName, int regionReplication, int nRegions, byte[]... families) static void
SnapshotTestingUtils.deleteArchiveDirectory
(HBaseTestingUtil util) static void
SnapshotTestingUtils.loadData
(HBaseTestingUtil util, BufferedMutator mutator, int rows, byte[]... families) static void
SnapshotTestingUtils.loadData
(HBaseTestingUtil util, TableName tableName, int rows, byte[]... families) static void
MobSnapshotTestingUtils.verifyMobRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) static void
SnapshotTestingUtils.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestMobRestoreFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) protected void
TestRestoreFlushSnapshotFromClient.verifyRowCount
(HBaseTestingUtil util, TableName tableName, long expectedRows) static void
SnapshotTestingUtils.waitForTableToBeOnline
(HBaseTestingUtil util, TableName tableName) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.thrift
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
TestThriftHttpServer.TEST_UTIL
protected static final HBaseTestingUtil
TestThriftServerCmdLine.TEST_UTIL
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
BaseTestHBaseFsck.TEST_UTIL
protected static final HBaseTestingUtil
TestCoprocessorScanPolicy.TEST_UTIL
protected static final HBaseTestingUtil
TestMiniClusterLoadSequential.TEST_UTIL
static final HBaseTestingUtil
TestRegionSplitCalculator.TEST_UTIL
Modifier and TypeMethodDescriptionstatic void
BaseTestHBaseFsck.createTable
(HBaseTestingUtil testUtil, TableDescriptor tableDescriptor, byte[][] splitKeys) static void
BaseTestHBaseFsck.deleteTable
(HBaseTestingUtil testUtil, TableName tableName) static org.apache.hadoop.fs.Path
HFileArchiveTestingUtil.getStoreArchivePath
(HBaseTestingUtil util, String tableName, byte[] storeName) -
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.util.compaction
Modifier and TypeFieldDescriptionprotected HBaseTestingUtil
TestMajorCompactor.utility
protected static final HBaseTestingUtil
TestMajorCompactionRequest.UTILITY
-
Uses of HBaseTestingUtil in org.apache.hadoop.hbase.wal
Modifier and TypeFieldDescriptionprotected static final HBaseTestingUtil
CompressedWALTestBase.TEST_UTIL
protected static final HBaseTestingUtil
TestBoundedRegionGroupingStrategy.TEST_UTIL
protected static final HBaseTestingUtil
TestWALFactory.TEST_UTIL
protected static final HBaseTestingUtil
TestWALSplit.TEST_UTIL
protected static final HBaseTestingUtil
WALCorruptionDueToDanglingByteBufferTestBase.UTIL
protected static final HBaseTestingUtil
WALCorruptionWithMultiPutDueToDanglingByteBufferTestBase.UTIL