Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Class and Description |
---|---|
static class |
MiniHBaseCluster.MiniHBaseClusterRegionServer
Subclass so can get at protected methods (none at moment).
|
static class |
TestLocalHBaseCluster.MyHMaster
A private master class similar to that used by HMasterCommandLine when
running in local mode.
|
static class |
TestLocalHBaseCluster.MyHRegionServer
A private regionserver class with a dummy method for testing casts
|
Modifier and Type | Method and Description |
---|---|
HRegionServer |
LocalHBaseCluster.getRegionServer(int serverNumber) |
HRegionServer |
MiniHBaseCluster.getRegionServer(int serverNumber)
Grab a numbered region server of your choice.
|
HRegionServer |
HBaseTestingUtility.getRSForFirstRegionInTable(TableName tableName)
Tool to get the reference to the region server object that holds the
region of the specified user table.
|
Constructor and Description |
---|
LocalHBaseCluster(Configuration conf,
int noMasters,
int noRegionServers,
Class<? extends HMaster> masterClass,
Class<? extends HRegionServer> regionServerClass)
Constructor.
|
Constructor and Description |
---|
CoprocessorHConnection(ClusterConnection delegate,
HRegionServer server)
Deprecated.
delegate is not used
|
CoprocessorHConnection(Configuration conf,
HRegionServer server)
Constructor that accepts custom configuration
|
CoprocessorHConnection(HRegionServer server)
Constructor that uses server configuration
|
Modifier and Type | Class and Description |
---|---|
class |
HMaster
HMaster is the "master server" for HBase.
|
static class |
HMasterCommandLine.LocalHMaster |
static class |
TestAssignmentManagerOnCluster.MyMaster |
static class |
TestAssignmentManagerOnCluster.MyRegionServer |
static class |
TestMasterMetrics.MyMaster |
static class |
TestMetaShutdownHandler.MyRegionServer |
Modifier and Type | Method and Description |
---|---|
void |
TestDistributedLogSplitting.makeWAL(HRegionServer hrs,
List<HRegionInfo> regions,
String tname,
String fname,
int num_edits,
int edit_size) |
void |
TestDistributedLogSplitting.makeWAL(HRegionServer hrs,
List<HRegionInfo> regions,
String tname,
String fname,
int num_edits,
int edit_size,
boolean cleanShutdown) |
Modifier and Type | Class and Description |
---|---|
class |
OOMERegionServer
A region server that will OOME.
|
static class |
TestRegionServerReportForDuty.MyRegionServer |
static class |
TestRSKilledWhenInitializing.MockedRegionServer |
static class |
TestSplitTransactionOnCluster.MockMasterWithoutCatalogJanitor |
Modifier and Type | Method and Description |
---|---|
static HRegionServer |
HRegionServer.constructRegionServer(Class<? extends HRegionServer> regionServerClass,
Configuration conf2,
CoordinatedStateManager cp)
Utility for constructing an instance of the passed HRegionServer class.
|
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 |
TestEndToEndSplitTransaction.compactAndBlockUntilDone(Admin admin,
HRegionServer rs,
byte[] regionName) |
static void |
RSDumpServlet.dumpQueue(HRegionServer hrs,
PrintWriter out) |
static void |
TestEndToEndSplitTransaction.flushAndBlockUntilDone(Admin admin,
HRegionServer rs,
byte[] regionName) |
static void |
TestRegionServerNoMaster.openRegion(HBaseTestingUtility HTU,
HRegionServer rs,
HRegionInfo hri) |
Modifier and Type | Method and Description |
---|---|
static HRegionServer |
HRegionServer.constructRegionServer(Class<? extends HRegionServer> regionServerClass,
Configuration conf2,
CoordinatedStateManager cp)
Utility for constructing an instance of the passed HRegionServer class.
|
Constructor and Description |
---|
RSRpcServices(HRegionServer rs) |
StorefileRefresherChore(int period,
boolean onlyMetaRefresh,
HRegionServer regionServer,
Stoppable stoppable) |
Constructor and Description |
---|
HRegionServerCommandLine(Class<? extends HRegionServer> clazz) |
Modifier and Type | Method and Description |
---|---|
protected void |
TestVisibilityLabels.waitForLabelsRegionAvailability(HRegionServer regionServer) |
Modifier and Type | Method and Description |
---|---|
HRegionServer |
JVMClusterUtil.RegionServerThread.getRegionServer() |
Modifier and Type | Method and Description |
---|---|
static JVMClusterUtil.RegionServerThread |
JVMClusterUtil.createRegionServerThread(Configuration c,
CoordinatedStateManager cp,
Class<? extends HRegionServer> hrsc,
int index)
Creates a
JVMClusterUtil.RegionServerThread . |
Constructor and Description |
---|
RegionServerThread(HRegionServer r,
int index) |
Constructor and Description |
---|
RecoveringRegionWatcher(ZooKeeperWatcher watcher,
HRegionServer server)
Construct a ZooKeeper event listener.
|