@InterfaceAudience.Private public class RSRpcServices extends Object implements HBaseRPCErrorHandler, org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface, PriorityFunction, ConfigurationObserver
| Modifier and Type | Field and Description |
|---|---|
protected static org.apache.commons.logging.Log |
LOG |
static String |
REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS
RPC scheduler to use for the region server.
|
| Constructor and Description |
|---|
RSRpcServices(HRegionServer rs) |
| Modifier and Type | Method and Description |
|---|---|
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse |
bulkLoadHFile(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest request)
Atomically bulk load several HFiles into an open region
|
boolean |
checkOOME(Throwable e)
Take actions on the event of an OutOfMemoryError.
|
protected void |
checkOpen()
Called to verify that this server is up and running.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse |
closeRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest request)
Close a region on the region server.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse |
compactRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest request)
Compact a region on the region server.
|
protected PriorityFunction |
createPriority() |
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse |
execRegionServerService(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) |
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse |
execService(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) |
static boolean |
exitIfOOME(Throwable e) |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse |
flushRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest request)
Flush a region on the region server.
|
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse |
get(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest request)
Get data from a table.
|
org.apache.hadoop.conf.Configuration |
getConfiguration() |
long |
getDeadline(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader header,
com.google.protobuf.Message param)
Returns the deadline of the specified request.
|
static String |
getHostname(org.apache.hadoop.conf.Configuration conf,
boolean isMaster) |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse |
getOnlineRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest request) |
PriorityFunction |
getPriority() |
int |
getPriority(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader header,
com.google.protobuf.Message param,
User user)
Returns the 'priority type' of the specified request.
|
Region |
getRegion(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier regionSpecifier)
Find the HRegion based on a region specifier
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse |
getRegionInfo(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest request) |
String |
getScanDetailsWithId(long scannerId) |
RegionScanner |
getScanner(long scannerId) |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse |
getServerInfo(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest request)
Get some information of the region server.
|
protected List<RpcServer.BlockingServiceAndInterface> |
getServices() |
InetSocketAddress |
getSocketAddress() |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse |
getStoreFile(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest request) |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse |
mergeRegions(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest request)
Merge regions on the region server.
|
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse |
multi(com.google.protobuf.RpcController rpcc,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest request)
Execute multiple actions on a table: get, mutate, and/or execCoprocessor
|
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse |
mutate(com.google.protobuf.RpcController rpcc,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest request)
Mutate data in a table.
|
void |
onConfigurationChange(org.apache.hadoop.conf.Configuration newConf)
This method would be called by the
ConfigurationManager
object when the Configuration object is reloaded from disk. |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse |
openRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest request)
Open asynchronously a region or a set of regions on the region server.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse |
replay(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request)
Replay the given changes when distributedLogReplay WAL edits from a failed RS.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse |
replicateWALEntry(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request)
Replicate WAL entries on the region server.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse |
rollWALWriter(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest request)
Roll the WAL writer of the region server.
|
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse |
scan(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest request)
Scan data in a table.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse |
splitRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest request)
Split a region on the region server.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse |
stopServer(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest request)
Stop the region server.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse |
updateConfiguration(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest request) |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse |
updateFavoredNodes(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest request) |
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse |
warmupRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest request)
Wamrmup a region on this server.
|
protected static final org.apache.commons.logging.Log LOG
public static final String REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS
public RSRpcServices(HRegionServer rs) throws IOException
IOExceptionpublic void onConfigurationChange(org.apache.hadoop.conf.Configuration newConf)
ConfigurationObserverConfigurationManager
object when the Configuration object is reloaded from disk.onConfigurationChange in interface ConfigurationObserverprotected PriorityFunction createPriority()
public static String getHostname(org.apache.hadoop.conf.Configuration conf, boolean isMaster) throws UnknownHostException
UnknownHostExceptionpublic RegionScanner getScanner(long scannerId)
public String getScanDetailsWithId(long scannerId)
public Region getRegion(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier regionSpecifier) throws IOException
regionSpecifier - the region specifierIOException - if the specifier is not null,
but failed to find the regionpublic PriorityFunction getPriority()
public org.apache.hadoop.conf.Configuration getConfiguration()
protected void checkOpen()
throws IOException
IOExceptionprotected List<RpcServer.BlockingServiceAndInterface> getServices()
public InetSocketAddress getSocketAddress()
public int getPriority(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader header,
com.google.protobuf.Message param,
User user)
PriorityFunctiongetPriority in interface PriorityFunctionpublic long getDeadline(org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader header,
com.google.protobuf.Message param)
PriorityFunctiongetDeadline in interface PriorityFunctionpublic boolean checkOOME(Throwable e)
HBaseRPCErrorHandlercheckOOME in interface HBaseRPCErrorHandlere - the throwablepublic static boolean exitIfOOME(Throwable e)
public org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse closeRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest request)
throws com.google.protobuf.ServiceException
closeRegion in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse compactRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest request)
throws com.google.protobuf.ServiceException
compactRegion in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse flushRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest request)
throws com.google.protobuf.ServiceException
flushRegion in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse getOnlineRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest request)
throws com.google.protobuf.ServiceException
getOnlineRegion in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse getRegionInfo(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest request)
throws com.google.protobuf.ServiceException
getRegionInfo in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse getServerInfo(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest request)
throws com.google.protobuf.ServiceException
getServerInfo in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse getStoreFile(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest request)
throws com.google.protobuf.ServiceException
getStoreFile in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse mergeRegions(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest request)
throws com.google.protobuf.ServiceException
mergeRegions in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse openRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest request)
throws com.google.protobuf.ServiceException
Different manages states for the region are:
Bulk assign: If there are more than 1 region to open, it will be considered as a bulk assign. For a single region opening, errors are sent through a ServiceException. For bulk assign, errors are put in the response as FAILED_OPENING.
openRegion in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse warmupRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest request)
throws com.google.protobuf.ServiceException
warmupRegion in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replay(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request)
throws com.google.protobuf.ServiceException
replay in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replicateWALEntry(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request)
throws com.google.protobuf.ServiceException
replicateWALEntry in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse rollWALWriter(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest request)
throws com.google.protobuf.ServiceException
rollWALWriter in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse splitRegion(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest request)
throws com.google.protobuf.ServiceException
splitRegion in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse stopServer(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest request)
throws com.google.protobuf.ServiceException
stopServer in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecontroller - the RPC controllerrequest - the requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse updateFavoredNodes(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest request)
throws com.google.protobuf.ServiceException
updateFavoredNodes in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse bulkLoadHFile(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest request)
throws com.google.protobuf.ServiceException
bulkLoadHFile in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterfacecom.google.protobuf.ServiceException - if failed unrecoverablypublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse execService(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest request)
throws com.google.protobuf.ServiceException
execService in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse get(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest request)
throws com.google.protobuf.ServiceException
get in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterfacecontroller - the RPC controllerrequest - the get requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse multi(com.google.protobuf.RpcController rpcc,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest request)
throws com.google.protobuf.ServiceException
multi in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterfacerpcc - the RPC controllerrequest - the multi requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse mutate(com.google.protobuf.RpcController rpcc,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest request)
throws com.google.protobuf.ServiceException
mutate in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterfacerpcc - the RPC controllerrequest - the mutate requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse scan(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest request)
throws com.google.protobuf.ServiceException
scan in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterfacecontroller - the RPC controllerrequest - the scan requestcom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse execRegionServerService(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest request)
throws com.google.protobuf.ServiceException
execRegionServerService in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterfacecom.google.protobuf.ServiceExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse updateConfiguration(com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest request)
throws com.google.protobuf.ServiceException
updateConfiguration in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterfacecom.google.protobuf.ServiceExceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.