@InterfaceAudience.Private public interface RegionServerServices extends PriorityFunction
HRegionServer
Modifier and Type | Method and Description |
---|---|
void |
addToOnlineRegions(HRegion r)
Add to online regions.
|
CatalogTracker |
getCatalogTracker() |
CompactionRequestor |
getCompactionRequester() |
ExecutorService |
getExecutorService() |
InetSocketAddress[] |
getFavoredNodesForRegion(String encodedRegionName)
Get the favored nodes mapping for this region.
|
org.apache.hadoop.fs.FileSystem |
getFileSystem() |
FlushRequester |
getFlushRequester() |
HRegion |
getFromOnlineRegions(String encodedRegionName)
Return
HRegion instance. |
Leases |
getLeases() |
ServerNonceManager |
getNonceManager()
Only required for "old" log replay; if it's removed, remove this.
|
List<HRegion> |
getOnlineRegions(TableName tableName)
Get all online regions of a table in this RS.
|
Map<String,HRegion> |
getRecoveringRegions() |
RegionServerAccounting |
getRegionServerAccounting() |
ConcurrentMap<byte[],Boolean> |
getRegionsInTransitionInRS()
Get the regions that are currently being opened or closed in the RS
|
RpcServerInterface |
getRpcServer()
Returns a reference to the region server's RPC server
|
TableLockManager |
getTableLockManager() |
HLog |
getWAL(HRegionInfo regionInfo) |
boolean |
isStopping() |
void |
postOpenDeployTasks(HRegion r,
CatalogTracker ct)
Tasks to perform after region open to complete deploy of region on
regionserver
|
boolean |
removeFromOnlineRegions(HRegion r,
ServerName destination)
This method removes HRegion corresponding to hri from the Map of onlineRegions.
|
boolean |
reportRegionTransition(RegionServerStatusProtos.RegionTransition.TransitionCode code,
HRegionInfo... hris)
Notify master that a handler requests to change a region state
|
boolean |
reportRegionTransition(RegionServerStatusProtos.RegionTransition.TransitionCode code,
long openSeqNum,
HRegionInfo... hris)
Notify master that a handler requests to change a region state
|
void |
updateRegionFavoredNodesMapping(String encodedRegionName,
List<HBaseProtos.ServerName> favoredNodes)
Used to update the favored nodes mapping when required.
|
getConfiguration, getServerName, getZooKeeper
getPriority
boolean isStopping()
HLog getWAL(HRegionInfo regionInfo) throws IOException
IOException
CompactionRequestor getCompactionRequester()
CompactionRequestor
or null.FlushRequester getFlushRequester()
FlushRequester
or null.RegionServerAccounting getRegionServerAccounting()
TableLockManager getTableLockManager()
TableLockManager
void postOpenDeployTasks(HRegion r, CatalogTracker ct) throws org.apache.zookeeper.KeeperException, IOException
r
- Region to open.ct
- Instance of CatalogTracker
org.apache.zookeeper.KeeperException
IOException
boolean reportRegionTransition(RegionServerStatusProtos.RegionTransition.TransitionCode code, long openSeqNum, HRegionInfo... hris)
boolean reportRegionTransition(RegionServerStatusProtos.RegionTransition.TransitionCode code, HRegionInfo... hris)
RpcServerInterface getRpcServer()
ConcurrentMap<byte[],Boolean> getRegionsInTransitionInRS()
org.apache.hadoop.fs.FileSystem getFileSystem()
Leases getLeases()
ExecutorService getExecutorService()
CatalogTracker getCatalogTracker()
Map<String,HRegion> getRecoveringRegions()
ServerNonceManager getNonceManager()
void addToOnlineRegions(HRegion r)
r
- boolean removeFromOnlineRegions(HRegion r, ServerName destination)
r
- Region to remove.destination
- Destination, if any, null otherwise.HRegion getFromOnlineRegions(String encodedRegionName)
HRegion
instance.
Only works if caller is in same context, in same JVM. HRegion is not
serializable.encodedRegionName
- encodedRegionName
or
null if named region is not member of the online regions.List<HRegion> getOnlineRegions(TableName tableName) throws IOException
tableName
- IOException
void updateRegionFavoredNodesMapping(String encodedRegionName, List<HBaseProtos.ServerName> favoredNodes)
encodedRegionName
- favoredNodes
- InetSocketAddress[] getFavoredNodesForRegion(String encodedRegionName)
encodedRegionName
- Copyright © 2014 The Apache Software Foundation. All rights reserved.