Package org.apache.hadoop.hbase
Class MiniHBaseCluster
java.lang.Object
org.apache.hadoop.hbase.HBaseCluster
org.apache.hadoop.hbase.MiniHBaseCluster
- All Implemented Interfaces:
Closeable
,AutoCloseable
,org.apache.hadoop.conf.Configurable
Deprecated.
This class creates a single process HBase cluster. each server. The master uses the 'default'
FileSystem. The RegionServers, if we are running on DistributedFilesystem, create a FileSystem
instance each and will close down their instance on the way out.
-
Nested Class Summary
Modifier and TypeClassDescriptionstatic class
Deprecated.Subclass so can get at protected methods (none at moment).(package private) static class
Deprecated.Alternate shutdown hook. -
Field Summary
Modifier and TypeFieldDescriptionDeprecated.private static int
Deprecated.private static final org.slf4j.Logger
Deprecated.Fields inherited from class org.apache.hadoop.hbase.HBaseCluster
conf, initialClusterStatus
-
Constructor Summary
ConstructorDescriptionMiniHBaseCluster
(org.apache.hadoop.conf.Configuration conf, int numRegionServers) Deprecated.Start a MiniHBaseCluster.MiniHBaseCluster
(org.apache.hadoop.conf.Configuration conf, int numMasters, int numRegionServers) Deprecated.Start a MiniHBaseCluster.MiniHBaseCluster
(org.apache.hadoop.conf.Configuration conf, int numMasters, int numAlwaysStandByMasters, int numRegionServers, List<Integer> rsPorts, Class<? extends HMaster> masterClass, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer> regionserverClass) Deprecated.MiniHBaseCluster
(org.apache.hadoop.conf.Configuration conf, int numMasters, int numRegionServers, Class<? extends HMaster> masterClass, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer> regionserverClass) Deprecated.Start a MiniHBaseCluster. -
Method Summary
Modifier and TypeMethodDescriptionabortMaster
(int serverNumber) Deprecated.Cause a master to exit without shutting down entire cluster.abortRegionServer
(int serverNumber) Deprecated.Cause a region server to exit doing basic clean up only on its way out.void
close()
Deprecated.Closes all the resources held open for this cluster.void
compact
(boolean major) Deprecated.Call flushCache on all regions on all participating regionservers.void
Deprecated.Call flushCache on all regions of the specified table.long
Deprecated.Counts the total numbers of regions being served by the currently online region servers by asking each how many regions they have.private void
executeFlush
(HRegion region) Deprecated.findRegionsForTable
(TableName tableName) Deprecated.void
Deprecated.Call flushCache on all regions on all participating regionservers.void
flushcache
(TableName tableName) Deprecated.Call flushCache on all regions of the specified table.Deprecated.Returns a ClusterMetrics for this HBase cluster.org.apache.hadoop.conf.Configuration
Deprecated.Deprecated.Returns List of live master threads (skips the aborted and the killed)Deprecated.Returns List of live region server threads (skips the aborted and the killed)Deprecated.Returns the current active master, if available.getMaster
(int serverNumber) Deprecated.Returns the master at the specified index, if available.protected int
getMasterIndex
(ServerName serverName) Deprecated.Deprecated.Returns the current active master thread, if available.Deprecated.Returns List of master threads.int
Deprecated.Returns Number of live region servers in the cluster currently.getRegions
(byte[] tableName) Deprecated.getRegions
(TableName tableName) Deprecated.getRegionServer
(int serverNumber) Deprecated.Grab a numbered region server of your choice.getRegionServer
(ServerName serverName) Deprecated.protected int
getRegionServerIndex
(ServerName serverName) Deprecated.Deprecated.getServerHoldingRegion
(TableName tn, byte[] regionName) Deprecated.Get the ServerName of region server serving the specified regionint
getServerWith
(byte[] regionName) Deprecated.Get the location of the specified regionint
Deprecated.private void
init
(int nMasterNodes, int numAlwaysStandByMasters, int nRegionNodes, List<Integer> rsPorts, Class<? extends HMaster> masterClass, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer> regionserverClass) Deprecated.boolean
isKilledRS
(ServerName serverName) Deprecated.Keeping track of killed servers and being able to check if a particular server was killed makes it possible to do fault tolerance testing for dead servers in a deterministic way.void
join()
Deprecated.Wait for Mini HBase Cluster to shut down.void
killAll()
Deprecated.Do a simulated kill all masters and regionservers.void
killDataNode
(ServerName serverName) Deprecated.Kills the datanode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.void
killMaster
(ServerName serverName) Deprecated.Kills the master process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.void
killNameNode
(ServerName serverName) Deprecated.Kills the namenode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.void
killRegionServer
(ServerName serverName) Deprecated.Kills the region server process if this is a distributed cluster, otherwise this causes the region server to exit doing basic clean up only.void
killZkNode
(ServerName serverName) Deprecated.Kills the zookeeper node process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.resumeRegionServer
(int serverNumber) Deprecated.Resume the specified region servervoid
resumeRegionServer
(ServerName serverName) Deprecated.Resume the region servervoid
shutdown()
Deprecated.Shut down the mini HBase clustervoid
startDataNode
(ServerName serverName) Deprecated.Starts a new datanode on the given hostname or if this is a mini/local cluster, silently logs warning message.Deprecated.Starts a master thread runningvoid
startMaster
(String hostname, int port) Deprecated.Starts a new master on the given hostname or if this is a mini/local cluster, starts a master locally.void
startNameNode
(ServerName serverName) Deprecated.Starts a new namenode on the given hostname or if this is a mini/local cluster, silently logs warning message.Deprecated.Starts a region server thread runningvoid
startRegionServer
(String hostname, int port) Deprecated.Starts a new region server on the given hostname or if this is a mini/local cluster, starts a region server locally.startRegionServer
(org.apache.hadoop.conf.Configuration configuration) Deprecated.startRegionServerAndWait
(long timeout) Deprecated.Starts a region server thread and waits until its processed by master.void
startZkNode
(String hostname, int port) Deprecated.Starts a new zookeeper node on the given hostname or if this is a mini/local cluster, silently logs warning message.void
stopDataNode
(ServerName serverName) Deprecated.Stops the datanode if this is a distributed cluster, otherwise silently logs warning message.stopMaster
(int serverNumber) Deprecated.Shut down the specified master cleanlystopMaster
(int serverNumber, boolean shutdownFS) Deprecated.Shut down the specified master cleanlyvoid
stopMaster
(ServerName serverName) Deprecated.Stops the given master, by attempting a gradual stop.void
stopNameNode
(ServerName serverName) Deprecated.Stops the namenode if this is a distributed cluster, otherwise silently logs warning message.stopRegionServer
(int serverNumber) Deprecated.Shut down the specified region server cleanlystopRegionServer
(int serverNumber, boolean shutdownFS) Deprecated.Shut down the specified region server cleanlyvoid
stopRegionServer
(ServerName serverName) Deprecated.Stops the given region server, by attempting a gradual stop.void
stopZkNode
(ServerName serverName) Deprecated.Stops the region zookeeper if this is a distributed cluster, otherwise silently logs warning message.suspendRegionServer
(int serverNumber) Deprecated.Suspend the specified region servervoid
suspendRegionServer
(ServerName serverName) Deprecated.Suspend the region serverboolean
waitForActiveAndReadyMaster
(long timeout) Deprecated.Blocks until there is an active master and that master has completed initialization.void
waitForDataNodeToStart
(ServerName serverName, long timeout) Deprecated.Wait for the specified datanode to join the clustervoid
waitForDataNodeToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified datanode to stop the thread / process.void
waitForMasterToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified master to stop the thread / process.void
waitForNameNodeToStart
(ServerName serverName, long timeout) Deprecated.Wait for the specified namenode to join the clustervoid
waitForNameNodeToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified namenode to stopvoid
waitForRegionServerToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified region server to stop the thread / process.void
waitForZkNodeToStart
(ServerName serverName, long timeout) Deprecated.Wait for the specified zookeeper node to join the clustervoid
waitForZkNodeToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified zookeeper node to stop the thread / process.waitOnMaster
(int serverNumber) Deprecated.Wait for the specified master to stop.waitOnRegionServer
(int serverNumber) Deprecated.Wait for the specified region server to stop.void
Deprecated.Wait for HBase Cluster to shut down.Methods inherited from class org.apache.hadoop.hbase.HBaseCluster
getConf, getInitialClusterMetrics, getServerHoldingMeta, isDistributedCluster, restoreClusterMetrics, restoreInitialStatus, setConf, waitForActiveAndReadyMaster, waitForDatanodesRegistered, waitForNamenodeAvailable, waitForRegionServerToStart
-
Field Details
-
LOG
Deprecated. -
hbaseCluster
Deprecated. -
index
Deprecated.
-
-
Constructor Details
-
MiniHBaseCluster
public MiniHBaseCluster(org.apache.hadoop.conf.Configuration conf, int numRegionServers) throws IOException, InterruptedException Deprecated.Start a MiniHBaseCluster.- Parameters:
conf
- Configuration to be used for clusternumRegionServers
- initial number of region servers to start.- Throws:
IOException
InterruptedException
-
MiniHBaseCluster
public MiniHBaseCluster(org.apache.hadoop.conf.Configuration conf, int numMasters, int numRegionServers) throws IOException, InterruptedException Deprecated.Start a MiniHBaseCluster.- Parameters:
conf
- Configuration to be used for clusternumMasters
- initial number of masters to start.numRegionServers
- initial number of region servers to start.- Throws:
IOException
InterruptedException
-
MiniHBaseCluster
public MiniHBaseCluster(org.apache.hadoop.conf.Configuration conf, int numMasters, int numRegionServers, Class<? extends HMaster> masterClass, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer> regionserverClass) throws IOException, InterruptedException Deprecated.Start a MiniHBaseCluster.- Parameters:
conf
- Configuration to be used for clusternumMasters
- initial number of masters to start.numRegionServers
- initial number of region servers to start.- Throws:
IOException
InterruptedException
-
MiniHBaseCluster
public MiniHBaseCluster(org.apache.hadoop.conf.Configuration conf, int numMasters, int numAlwaysStandByMasters, int numRegionServers, List<Integer> rsPorts, Class<? extends HMaster> masterClass, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer> regionserverClass) throws IOException, InterruptedException Deprecated.- Parameters:
rsPorts
- Ports that RegionServer should use; pass ports if you want to test cluster restart where for sure the regionservers come up on same address+port (but just with different startcode); by default mini hbase clusters choose new arbitrary ports on each cluster start.- Throws:
IOException
InterruptedException
-
-
Method Details
-
getConfiguration
Deprecated. -
init
private void init(int nMasterNodes, int numAlwaysStandByMasters, int nRegionNodes, List<Integer> rsPorts, Class<? extends HMaster> masterClass, Class<? extends MiniHBaseCluster.MiniHBaseClusterRegionServer> regionserverClass) throws IOException, InterruptedException Deprecated.- Throws:
IOException
InterruptedException
-
startRegionServer
Deprecated.Description copied from class:HBaseCluster
Starts a new region server on the given hostname or if this is a mini/local cluster, starts a region server locally.- Specified by:
startRegionServer
in classHBaseCluster
- Parameters:
hostname
- the hostname to start the regionserver on- Throws:
IOException
- if something goes wrong
-
killRegionServer
Deprecated.Description copied from class:HBaseCluster
Kills the region server process if this is a distributed cluster, otherwise this causes the region server to exit doing basic clean up only.- Specified by:
killRegionServer
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
isKilledRS
Deprecated.Description copied from class:HBaseCluster
Keeping track of killed servers and being able to check if a particular server was killed makes it possible to do fault tolerance testing for dead servers in a deterministic way. A concrete example of such case is - killing servers and waiting for all regions of a particular table to be assigned. We can check for server column in META table and that its value is not one of the killed servers.- Specified by:
isKilledRS
in classHBaseCluster
-
stopRegionServer
Deprecated.Description copied from class:HBaseCluster
Stops the given region server, by attempting a gradual stop.- Specified by:
stopRegionServer
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
suspendRegionServer
Deprecated.Description copied from class:HBaseCluster
Suspend the region server- Specified by:
suspendRegionServer
in classHBaseCluster
- Parameters:
serverName
- the hostname to suspend the regionserver on- Throws:
IOException
- if something goes wrong
-
resumeRegionServer
Deprecated.Description copied from class:HBaseCluster
Resume the region server- Specified by:
resumeRegionServer
in classHBaseCluster
- Parameters:
serverName
- the hostname to resume the regionserver on- Throws:
IOException
- if something goes wrong
-
waitForRegionServerToStop
Deprecated.Description copied from class:HBaseCluster
Wait for the specified region server to stop the thread / process.- Specified by:
waitForRegionServerToStop
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
startZkNode
Deprecated.Description copied from class:HBaseCluster
Starts a new zookeeper node on the given hostname or if this is a mini/local cluster, silently logs warning message.- Specified by:
startZkNode
in classHBaseCluster
- Parameters:
hostname
- the hostname to start the regionserver on- Throws:
IOException
- if something goes wrong
-
killZkNode
Deprecated.Description copied from class:HBaseCluster
Kills the zookeeper node process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.- Specified by:
killZkNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
stopZkNode
Deprecated.Description copied from class:HBaseCluster
Stops the region zookeeper if this is a distributed cluster, otherwise silently logs warning message.- Specified by:
stopZkNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
waitForZkNodeToStart
Deprecated.Description copied from class:HBaseCluster
Wait for the specified zookeeper node to join the cluster- Specified by:
waitForZkNodeToStart
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
waitForZkNodeToStop
Deprecated.Description copied from class:HBaseCluster
Wait for the specified zookeeper node to stop the thread / process.- Specified by:
waitForZkNodeToStop
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
startDataNode
Deprecated.Description copied from class:HBaseCluster
Starts a new datanode on the given hostname or if this is a mini/local cluster, silently logs warning message.- Specified by:
startDataNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
killDataNode
Deprecated.Description copied from class:HBaseCluster
Kills the datanode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.- Specified by:
killDataNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
stopDataNode
Deprecated.Description copied from class:HBaseCluster
Stops the datanode if this is a distributed cluster, otherwise silently logs warning message.- Specified by:
stopDataNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
waitForDataNodeToStart
Deprecated.Description copied from class:HBaseCluster
Wait for the specified datanode to join the cluster- Specified by:
waitForDataNodeToStart
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
waitForDataNodeToStop
Deprecated.Description copied from class:HBaseCluster
Wait for the specified datanode to stop the thread / process.- Specified by:
waitForDataNodeToStop
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
startNameNode
Deprecated.Description copied from class:HBaseCluster
Starts a new namenode on the given hostname or if this is a mini/local cluster, silently logs warning message.- Specified by:
startNameNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
killNameNode
Deprecated.Description copied from class:HBaseCluster
Kills the namenode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.- Specified by:
killNameNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
stopNameNode
Deprecated.Description copied from class:HBaseCluster
Stops the namenode if this is a distributed cluster, otherwise silently logs warning message.- Specified by:
stopNameNode
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
waitForNameNodeToStart
Deprecated.Description copied from class:HBaseCluster
Wait for the specified namenode to join the cluster- Specified by:
waitForNameNodeToStart
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
waitForNameNodeToStop
Deprecated.Description copied from class:HBaseCluster
Wait for the specified namenode to stop- Specified by:
waitForNameNodeToStop
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
startMaster
Deprecated.Description copied from class:HBaseCluster
Starts a new master on the given hostname or if this is a mini/local cluster, starts a master locally.- Specified by:
startMaster
in classHBaseCluster
- Parameters:
hostname
- the hostname to start the master on- Throws:
IOException
- if something goes wrong
-
killMaster
Deprecated.Description copied from class:HBaseCluster
Kills the master process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.- Specified by:
killMaster
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
stopMaster
Deprecated.Description copied from class:HBaseCluster
Stops the given master, by attempting a gradual stop.- Specified by:
stopMaster
in classHBaseCluster
- Throws:
IOException
- if something goes wrong
-
waitForMasterToStop
Deprecated.Description copied from class:HBaseCluster
Wait for the specified master to stop the thread / process.- Specified by:
waitForMasterToStop
in classHBaseCluster
- Throws:
IOException
- if something goes wrong or timeout occurs
-
startRegionServer
Deprecated.Starts a region server thread running- Returns:
- New RegionServerThread
- Throws:
IOException
-
startRegionServer
private JVMClusterUtil.RegionServerThread startRegionServer(org.apache.hadoop.conf.Configuration configuration) throws IOException Deprecated.- Throws:
IOException
-
startRegionServerAndWait
Deprecated.Starts a region server thread and waits until its processed by master. Throws an exception when it can't start a region server or when the region server is not processed by master within the timeout.- Returns:
- New RegionServerThread
- Throws:
IOException
-
abortRegionServer
Deprecated.Cause a region server to exit doing basic clean up only on its way out.- Parameters:
serverNumber
- Used as index into a list.
-
stopRegionServer
Deprecated.Shut down the specified region server cleanly- Parameters:
serverNumber
- Used as index into a list.- Returns:
- the region server that was stopped
-
stopRegionServer
Deprecated.Shut down the specified region server cleanly- Parameters:
serverNumber
- Used as index into a list.shutdownFS
- True is we are to shutdown the filesystem as part of this regionserver's shutdown. Usually we do but you do not want to do this if you are running multiple regionservers in a test and you shut down one before end of the test.- Returns:
- the region server that was stopped
-
suspendRegionServer
Deprecated.Suspend the specified region server- Parameters:
serverNumber
- Used as index into a list.
-
resumeRegionServer
Deprecated.Resume the specified region server- Parameters:
serverNumber
- Used as index into a list.
-
waitOnRegionServer
Deprecated.Wait for the specified region server to stop. Removes this thread from list of running threads.- Returns:
- Name of region server that just went down.
-
startMaster
Deprecated.Starts a master thread running- Returns:
- New RegionServerThread
- Throws:
IOException
-
getMaster
Deprecated.Returns the current active master, if available.- Returns:
- the active HMaster, null if none is active.
-
getMasterThread
Deprecated.Returns the current active master thread, if available.- Returns:
- the active MasterThread, null if none is active.
-
getMaster
Deprecated.Returns the master at the specified index, if available.- Returns:
- the active HMaster, null if none is active.
-
abortMaster
Deprecated.Cause a master to exit without shutting down entire cluster.- Parameters:
serverNumber
- Used as index into a list.
-
stopMaster
Deprecated.Shut down the specified master cleanly- Parameters:
serverNumber
- Used as index into a list.- Returns:
- the region server that was stopped
-
stopMaster
Deprecated.Shut down the specified master cleanly- Parameters:
serverNumber
- Used as index into a list.shutdownFS
- True is we are to shutdown the filesystem as part of this master's shutdown. Usually we do but you do not want to do this if you are running multiple master in a test and you shut down one before end of the test.- Returns:
- the master that was stopped
-
waitOnMaster
Deprecated.Wait for the specified master to stop. Removes this thread from list of running threads.- Returns:
- Name of master that just went down.
-
waitForActiveAndReadyMaster
Deprecated.Blocks until there is an active master and that master has completed initialization.- Specified by:
waitForActiveAndReadyMaster
in classHBaseCluster
- Parameters:
timeout
- the timeout limit in ms- Returns:
- true if an active master becomes available. false if there are no masters left.
- Throws:
IOException
-
getMasterThreads
Deprecated.Returns List of master threads. -
getLiveMasterThreads
Deprecated.Returns List of live master threads (skips the aborted and the killed) -
join
Deprecated.Wait for Mini HBase Cluster to shut down. -
shutdown
Deprecated.Shut down the mini HBase cluster- Specified by:
shutdown
in classHBaseCluster
- Throws:
IOException
-
close
Deprecated.Description copied from class:HBaseCluster
Closes all the resources held open for this cluster. Note that this call does not shutdown the cluster.- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceCloseable
- Specified by:
close
in classHBaseCluster
- Throws:
IOException
- See Also:
-
getClusterMetrics
Deprecated.Description copied from class:HBaseCluster
Returns a ClusterMetrics for this HBase cluster.- Specified by:
getClusterMetrics
in classHBaseCluster
- Throws:
IOException
- See Also:
-
executeFlush
Deprecated.- Throws:
IOException
-
flushcache
Deprecated.Call flushCache on all regions on all participating regionservers.- Throws:
IOException
-
flushcache
Deprecated.Call flushCache on all regions of the specified table.- Throws:
IOException
-
compact
Deprecated.Call flushCache on all regions on all participating regionservers.- Throws:
IOException
-
compact
Deprecated.Call flushCache on all regions of the specified table.- Throws:
IOException
-
getNumLiveRegionServers
Deprecated.Returns Number of live region servers in the cluster currently. -
getRegionServerThreads
Deprecated.- Returns:
- List of region server threads. Does not return the master even though it is also a region server.
-
getLiveRegionServerThreads
Deprecated.Returns List of live region server threads (skips the aborted and the killed) -
getRegionServer
Deprecated.Grab a numbered region server of your choice.- Returns:
- region server
-
getRegionServer
Deprecated. -
getRegions
Deprecated. -
getRegions
Deprecated. -
getServerWithMeta
Deprecated.- Returns:
- Index into List of
getRegionServerThreads()
of HRS carrying regionName. Returns -1 if none found.
-
getServerWith
Deprecated.Get the location of the specified region- Parameters:
regionName
- Name of the region in bytes- Returns:
- Index into List of
getRegionServerThreads()
of HRS carrying hbase:meta. Returns -1 if none found.
-
getServerHoldingRegion
Deprecated.Description copied from class:HBaseCluster
Get the ServerName of region server serving the specified region- Specified by:
getServerHoldingRegion
in classHBaseCluster
- Parameters:
tn
- Table name that has the region.regionName
- Name of the region in bytes- Returns:
- ServerName that hosts the region or null
- Throws:
IOException
-
countServedRegions
Deprecated.Counts the total numbers of regions being served by the currently online region servers by asking each how many regions they have. Does not look at hbase:meta at all. Count includes catalog tables.- Returns:
- number of regions being served by all region servers
-
killAll
Deprecated.Do a simulated kill all masters and regionservers. Useful when it is impossible to bring the mini-cluster back for clean shutdown. -
waitUntilShutDown
Deprecated.Description copied from class:HBaseCluster
Wait for HBase Cluster to shut down.- Specified by:
waitUntilShutDown
in classHBaseCluster
-
findRegionsForTable
Deprecated. -
getRegionServerIndex
Deprecated. -
getMasterIndex
Deprecated.
-
TestingHBaseCluster
instead.