@InterfaceAudience.Private public class RSRpcServices extends Object implements HBaseRPCErrorHandler, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface, PriorityFunction
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 |
---|---|
ClientProtos.BulkLoadHFileResponse |
bulkLoadHFile(com.google.protobuf.RpcController controller,
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.
|
AdminProtos.CloseRegionResponse |
closeRegion(com.google.protobuf.RpcController controller,
AdminProtos.CloseRegionRequest request)
Close a region on the region server.
|
AdminProtos.CompactRegionResponse |
compactRegion(com.google.protobuf.RpcController controller,
AdminProtos.CompactRegionRequest request)
Compact a region on the region server.
|
ClientProtos.CoprocessorServiceResponse |
execRegionServerService(com.google.protobuf.RpcController controller,
ClientProtos.CoprocessorServiceRequest request) |
ClientProtos.CoprocessorServiceResponse |
execService(com.google.protobuf.RpcController controller,
ClientProtos.CoprocessorServiceRequest request) |
AdminProtos.FlushRegionResponse |
flushRegion(com.google.protobuf.RpcController controller,
AdminProtos.FlushRegionRequest request)
Flush a region on the region server.
|
ClientProtos.GetResponse |
get(com.google.protobuf.RpcController controller,
ClientProtos.GetRequest request)
Get data from a table.
|
long |
getDeadline(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) |
AdminProtos.GetOnlineRegionResponse |
getOnlineRegion(com.google.protobuf.RpcController controller,
AdminProtos.GetOnlineRegionRequest request) |
PriorityFunction |
getPriority() |
int |
getPriority(RPCProtos.RequestHeader header,
com.google.protobuf.Message param)
Returns the 'priority type' of the specified request.
|
AdminProtos.GetRegionInfoResponse |
getRegionInfo(com.google.protobuf.RpcController controller,
AdminProtos.GetRegionInfoRequest request) |
AdminProtos.GetServerInfoResponse |
getServerInfo(com.google.protobuf.RpcController controller,
AdminProtos.GetServerInfoRequest request)
Get some information of the region server.
|
protected List<RpcServer.BlockingServiceAndInterface> |
getServices() |
InetSocketAddress |
getSocketAddress() |
AdminProtos.GetStoreFileResponse |
getStoreFile(com.google.protobuf.RpcController controller,
AdminProtos.GetStoreFileRequest request) |
AdminProtos.MergeRegionsResponse |
mergeRegions(com.google.protobuf.RpcController controller,
AdminProtos.MergeRegionsRequest request)
Merge regions on the region server.
|
ClientProtos.MultiResponse |
multi(com.google.protobuf.RpcController rpcc,
ClientProtos.MultiRequest request)
Execute multiple actions on a table: get, mutate, and/or execCoprocessor
|
ClientProtos.MutateResponse |
mutate(com.google.protobuf.RpcController rpcc,
ClientProtos.MutateRequest request)
Mutate data in a table.
|
AdminProtos.OpenRegionResponse |
openRegion(com.google.protobuf.RpcController controller,
AdminProtos.OpenRegionRequest request)
Open asynchronously a region or a set of regions on the region server.
|
AdminProtos.ReplicateWALEntryResponse |
replay(com.google.protobuf.RpcController controller,
AdminProtos.ReplicateWALEntryRequest request)
Replay the given changes when distributedLogReplay WAL edits from a failed RS.
|
AdminProtos.ReplicateWALEntryResponse |
replicateWALEntry(com.google.protobuf.RpcController controller,
AdminProtos.ReplicateWALEntryRequest request)
Replicate WAL entries on the region server.
|
AdminProtos.RollWALWriterResponse |
rollWALWriter(com.google.protobuf.RpcController controller,
AdminProtos.RollWALWriterRequest request)
Roll the WAL writer of the region server.
|
ClientProtos.ScanResponse |
scan(com.google.protobuf.RpcController controller,
ClientProtos.ScanRequest request)
Scan data in a table.
|
AdminProtos.SplitRegionResponse |
splitRegion(com.google.protobuf.RpcController controller,
AdminProtos.SplitRegionRequest request)
Split a region on the region server.
|
AdminProtos.StopServerResponse |
stopServer(com.google.protobuf.RpcController controller,
AdminProtos.StopServerRequest request)
Stop the region server.
|
AdminProtos.UpdateConfigurationResponse |
updateConfiguration(com.google.protobuf.RpcController controller,
AdminProtos.UpdateConfigurationRequest request) |
AdminProtos.UpdateFavoredNodesResponse |
updateFavoredNodes(com.google.protobuf.RpcController controller,
AdminProtos.UpdateFavoredNodesRequest request) |
AdminProtos.WarmupRegionResponse |
warmupRegion(com.google.protobuf.RpcController controller,
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
IOException
public static String getHostname(org.apache.hadoop.conf.Configuration conf, boolean isMaster) throws UnknownHostException
UnknownHostException
public PriorityFunction getPriority()
protected void checkOpen() throws IOException
IOException
protected List<RpcServer.BlockingServiceAndInterface> getServices()
public InetSocketAddress getSocketAddress()
public int getPriority(RPCProtos.RequestHeader header, com.google.protobuf.Message param)
PriorityFunction
getPriority
in interface PriorityFunction
public long getDeadline(RPCProtos.RequestHeader header, com.google.protobuf.Message param)
PriorityFunction
getDeadline
in interface PriorityFunction
public boolean checkOOME(Throwable e)
HBaseRPCErrorHandler
checkOOME
in interface HBaseRPCErrorHandler
e
- the throwablepublic AdminProtos.CloseRegionResponse closeRegion(com.google.protobuf.RpcController controller, AdminProtos.CloseRegionRequest request) throws com.google.protobuf.ServiceException
closeRegion
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.CompactRegionResponse compactRegion(com.google.protobuf.RpcController controller, AdminProtos.CompactRegionRequest request) throws com.google.protobuf.ServiceException
compactRegion
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.FlushRegionResponse flushRegion(com.google.protobuf.RpcController controller, AdminProtos.FlushRegionRequest request) throws com.google.protobuf.ServiceException
flushRegion
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.GetOnlineRegionResponse getOnlineRegion(com.google.protobuf.RpcController controller, AdminProtos.GetOnlineRegionRequest request) throws com.google.protobuf.ServiceException
getOnlineRegion
in interface AdminProtos.AdminService.BlockingInterface
com.google.protobuf.ServiceException
public AdminProtos.GetRegionInfoResponse getRegionInfo(com.google.protobuf.RpcController controller, AdminProtos.GetRegionInfoRequest request) throws com.google.protobuf.ServiceException
getRegionInfo
in interface AdminProtos.AdminService.BlockingInterface
com.google.protobuf.ServiceException
public AdminProtos.GetServerInfoResponse getServerInfo(com.google.protobuf.RpcController controller, AdminProtos.GetServerInfoRequest request) throws com.google.protobuf.ServiceException
getServerInfo
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.GetStoreFileResponse getStoreFile(com.google.protobuf.RpcController controller, AdminProtos.GetStoreFileRequest request) throws com.google.protobuf.ServiceException
getStoreFile
in interface AdminProtos.AdminService.BlockingInterface
com.google.protobuf.ServiceException
public AdminProtos.MergeRegionsResponse mergeRegions(com.google.protobuf.RpcController controller, AdminProtos.MergeRegionsRequest request) throws com.google.protobuf.ServiceException
mergeRegions
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.OpenRegionResponse openRegion(com.google.protobuf.RpcController controller, 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 AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.WarmupRegionResponse warmupRegion(com.google.protobuf.RpcController controller, AdminProtos.WarmupRegionRequest request) throws com.google.protobuf.ServiceException
warmupRegion
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.ReplicateWALEntryResponse replay(com.google.protobuf.RpcController controller, AdminProtos.ReplicateWALEntryRequest request) throws com.google.protobuf.ServiceException
replay
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.ReplicateWALEntryResponse replicateWALEntry(com.google.protobuf.RpcController controller, AdminProtos.ReplicateWALEntryRequest request) throws com.google.protobuf.ServiceException
replicateWALEntry
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.RollWALWriterResponse rollWALWriter(com.google.protobuf.RpcController controller, AdminProtos.RollWALWriterRequest request) throws com.google.protobuf.ServiceException
rollWALWriter
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.SplitRegionResponse splitRegion(com.google.protobuf.RpcController controller, AdminProtos.SplitRegionRequest request) throws com.google.protobuf.ServiceException
splitRegion
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.StopServerResponse stopServer(com.google.protobuf.RpcController controller, AdminProtos.StopServerRequest request) throws com.google.protobuf.ServiceException
stopServer
in interface AdminProtos.AdminService.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public AdminProtos.UpdateFavoredNodesResponse updateFavoredNodes(com.google.protobuf.RpcController controller, AdminProtos.UpdateFavoredNodesRequest request) throws com.google.protobuf.ServiceException
updateFavoredNodes
in interface AdminProtos.AdminService.BlockingInterface
com.google.protobuf.ServiceException
public ClientProtos.BulkLoadHFileResponse bulkLoadHFile(com.google.protobuf.RpcController controller, ClientProtos.BulkLoadHFileRequest request) throws com.google.protobuf.ServiceException
bulkLoadHFile
in interface ClientProtos.ClientService.BlockingInterface
IOException
- if failed unrecoverablycom.google.protobuf.ServiceException
public ClientProtos.CoprocessorServiceResponse execService(com.google.protobuf.RpcController controller, ClientProtos.CoprocessorServiceRequest request) throws com.google.protobuf.ServiceException
execService
in interface ClientProtos.ClientService.BlockingInterface
com.google.protobuf.ServiceException
public ClientProtos.GetResponse get(com.google.protobuf.RpcController controller, ClientProtos.GetRequest request) throws com.google.protobuf.ServiceException
get
in interface ClientProtos.ClientService.BlockingInterface
controller
- the RPC controllerrequest
- the get requestcom.google.protobuf.ServiceException
public ClientProtos.MultiResponse multi(com.google.protobuf.RpcController rpcc, ClientProtos.MultiRequest request) throws com.google.protobuf.ServiceException
multi
in interface ClientProtos.ClientService.BlockingInterface
rpcc
- the RPC controllerrequest
- the multi requestcom.google.protobuf.ServiceException
public ClientProtos.MutateResponse mutate(com.google.protobuf.RpcController rpcc, ClientProtos.MutateRequest request) throws com.google.protobuf.ServiceException
mutate
in interface ClientProtos.ClientService.BlockingInterface
rpcc
- the RPC controllerrequest
- the mutate requestcom.google.protobuf.ServiceException
public ClientProtos.ScanResponse scan(com.google.protobuf.RpcController controller, ClientProtos.ScanRequest request) throws com.google.protobuf.ServiceException
scan
in interface ClientProtos.ClientService.BlockingInterface
controller
- the RPC controllerrequest
- the scan requestcom.google.protobuf.ServiceException
public ClientProtos.CoprocessorServiceResponse execRegionServerService(com.google.protobuf.RpcController controller, ClientProtos.CoprocessorServiceRequest request) throws com.google.protobuf.ServiceException
execRegionServerService
in interface ClientProtos.ClientService.BlockingInterface
com.google.protobuf.ServiceException
public AdminProtos.UpdateConfigurationResponse updateConfiguration(com.google.protobuf.RpcController controller, AdminProtos.UpdateConfigurationRequest request) throws com.google.protobuf.ServiceException
updateConfiguration
in interface AdminProtos.AdminService.BlockingInterface
com.google.protobuf.ServiceException
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.