@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 | Class and Description |
---|---|
private static class |
RSRpcServices.RegionScannerHolder
Holder class which holds the RegionScanner and nextCallSeq together.
|
private class |
RSRpcServices.ScannerListener
Instantiated as a scanner lease.
|
Modifier and Type | Field and Description |
---|---|
private static long |
DEFAULT_REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA
Default value of
REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA |
(package private) InetSocketAddress |
isa |
protected static org.apache.commons.logging.Log |
LOG |
private long |
maxScannerResultSize |
private long |
minimumScanTimeLimitDelta
The minimum allowable delta to use for the scan limit
|
private PriorityFunction |
priority |
private static String |
REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA
Minimum allowable time limit delta (in milliseconds) that can be enforced during scans.
|
static String |
REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS
RPC scheduler to use for the region server.
|
private HRegionServer |
regionServer |
(package private) Counter |
requestCount |
(package private) RpcServerInterface |
rpcServer |
private int |
rpcTimeout
The RPC timeout period (milliseconds)
|
private ScannerIdGenerator |
scannerIdGenerator |
private int |
scannerLeaseTimeoutPeriod
The lease timeout period for client scanners (milliseconds).
|
private ConcurrentHashMap<String,RSRpcServices.RegionScannerHolder> |
scanners |
Constructor and Description |
---|
RSRpcServices(HRegionServer rs) |
Modifier and Type | Method and Description |
---|---|
private void |
addResult(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder builder,
Result result,
PayloadCarryingRpcController rpcc) |
private void |
addResults(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder builder,
List<Result> results,
com.google.protobuf.RpcController controller,
boolean isDefaultRegion) |
(package private) long |
addScanner(RegionScanner s,
Region r) |
(package private) Object |
addSize(RpcCallContext context,
Result r,
Object lastBlock)
Method to account for the size of retained cells and retained data blocks.
|
private Result |
append(Region region,
OperationQuota quota,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto m,
CellScanner cellScanner,
long nonceGroup)
Execute an append mutation.
|
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
|
private boolean |
checkAndRowMutate(Region region,
List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> actions,
CellScanner cellScanner,
byte[] row,
byte[] family,
byte[] qualifier,
CompareFilter.CompareOp compareOp,
ByteArrayComparable comparator)
Mutate a list of rows atomically.
|
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.
|
private void |
closeAllScanners() |
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.
|
private boolean |
closeScanner(Region region,
RegionScanner scanner,
String scannerName) |
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() |
private void |
doBatchOp(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
Region region,
OperationQuota quota,
List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> mutations,
CellScanner cells)
Execute a list of Put/Delete mutations.
|
private List<CellScannable> |
doNonAtomicRegionMutation(Region region,
OperationQuota quota,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction actions,
CellScanner cellScanner,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
List<CellScannable> cellsToReturn,
long nonceGroup)
Run through the regionMutation
rm and per Mutation, do the work, and then when
done, add an instance of a ClientProtos.ResultOrException that corresponds to each Mutation. |
private OperationStatus[] |
doReplayBatchOp(Region region,
List<WALSplitter.MutationReplay> mutations,
long replaySeqId)
Execute a list of Put/Delete mutations.
|
private void |
endNonceOperation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto mutation,
long nonceGroup,
boolean success)
Ends nonce operation for a mutation, if needed.
|
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) |
private com.google.protobuf.Message |
execServiceOnRegion(Region region,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall serviceCall) |
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.
|
private RegionServerQuotaManager |
getQuotaManager() |
(package private) 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) |
private static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException |
getResultOrException(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result r,
int index,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats stats) |
private static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException |
getResultOrException(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder builder,
int index) |
private static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException |
getResultOrException(Exception e,
int index) |
String |
getScanDetailsWithId(long scannerId) |
(package private) RegionScanner |
getScanner(long scannerId) |
(package private) long |
getScannerVirtualTime(long scannerId)
Get the vtime associated with the scanner.
|
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) |
(package private) WAL |
getWAL(Region region) |
private Result |
increment(Region region,
OperationQuota quota,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto mutation,
CellScanner cells,
long nonceGroup)
Execute an increment mutation.
|
private boolean |
isClientCellBlockSupport() |
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.
|
private org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats |
mutateRows(Region region,
List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> actions,
CellScanner cellScanner)
Mutate a list of rows atomically.
|
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.
|
private void |
skipCellsForMutation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action action,
CellScanner cellScanner) |
private void |
skipCellsForMutations(List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> actions,
CellScanner cellScanner) |
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.
|
(package private) void |
start() |
private long |
startNonceOperation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto mutation,
long nonceGroup)
Starts the nonce operation for a mutation, if needed.
|
(package private) void |
stop() |
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
private static final String REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA
private static final long DEFAULT_REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA
REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA
final Counter requestCount
final RpcServerInterface rpcServer
final InetSocketAddress isa
private final HRegionServer regionServer
private final long maxScannerResultSize
private final PriorityFunction priority
private ScannerIdGenerator scannerIdGenerator
private final ConcurrentHashMap<String,RSRpcServices.RegionScannerHolder> scanners
private final int scannerLeaseTimeoutPeriod
private final int rpcTimeout
private final long minimumScanTimeLimitDelta
public RSRpcServices(HRegionServer rs) throws IOException
IOException
private static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException getResultOrException(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result r, int index, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats stats)
private static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException getResultOrException(Exception e, int index)
private static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException getResultOrException(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder builder, int index)
private long startNonceOperation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto mutation, long nonceGroup) throws IOException, OperationConflictException
mutation
- Mutation.nonceGroup
- Nonce group from the request.IOException
OperationConflictException
private void endNonceOperation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto mutation, long nonceGroup, boolean success)
mutation
- Mutation.nonceGroup
- Nonce group from the request. Always 0 in initial implementation.success
- Whether the operation for this nonce has succeeded.private boolean isClientCellBlockSupport()
private void addResult(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder builder, Result result, PayloadCarryingRpcController rpcc)
private void addResults(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder builder, List<Result> results, com.google.protobuf.RpcController controller, boolean isDefaultRegion)
private org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats mutateRows(Region region, List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> actions, CellScanner cellScanner) throws IOException
region
- actions
- cellScanner
- if non-null, the mutation data -- the Cell content.IOException
private boolean checkAndRowMutate(Region region, List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> actions, CellScanner cellScanner, byte[] row, byte[] family, byte[] qualifier, CompareFilter.CompareOp compareOp, ByteArrayComparable comparator) throws IOException
region
- actions
- cellScanner
- if non-null, the mutation data -- the Cell content.row
- family
- qualifier
- compareOp
- comparator
- @throws IOExceptionIOException
private Result append(Region region, OperationQuota quota, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto m, CellScanner cellScanner, long nonceGroup) throws IOException
region
- m
- cellScanner
- IOException
private Result increment(Region region, OperationQuota quota, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cells, long nonceGroup) throws IOException
region
- mutation
- IOException
private List<CellScannable> doNonAtomicRegionMutation(Region region, OperationQuota quota, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction actions, CellScanner cellScanner, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder builder, List<CellScannable> cellsToReturn, long nonceGroup)
rm
and per Mutation, do the work, and then when
done, add an instance of a ClientProtos.ResultOrException
that corresponds to each Mutation.region
- actions
- cellScanner
- builder
- cellsToReturn
- Could be null. May be allocated in this method. This is what this
method returns as a 'result'.cellScanner
passedprivate void doBatchOp(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder builder, Region region, OperationQuota quota, List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> mutations, CellScanner cells)
builder
- region
- mutations
- private OperationStatus[] doReplayBatchOp(Region region, List<WALSplitter.MutationReplay> mutations, long replaySeqId) throws IOException
region
- mutations
- replaySeqId
- IOException
private void closeAllScanners()
public void onConfigurationChange(org.apache.hadoop.conf.Configuration newConf)
ConfigurationObserver
ConfigurationManager
object when the Configuration
object is reloaded from disk.onConfigurationChange
in interface ConfigurationObserver
protected PriorityFunction createPriority()
public static String getHostname(org.apache.hadoop.conf.Configuration conf, boolean isMaster) throws UnknownHostException
UnknownHostException
RegionScanner getScanner(long scannerId)
public String getScanDetailsWithId(long scannerId)
long getScannerVirtualTime(long scannerId)
long addScanner(RegionScanner s, Region r) throws Leases.LeaseStillHeldException
Leases.LeaseStillHeldException
Object addSize(RpcCallContext context, Result r, Object lastBlock)
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()
private RegionServerQuotaManager getQuotaManager()
void start()
void stop()
protected void checkOpen() throws IOException
IOException
protected 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)
PriorityFunction
getPriority
in interface PriorityFunction
public long getDeadline(org.apache.hadoop.hbase.protobuf.generated.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 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
com.google.protobuf.ServiceException
public 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.BlockingInterface
com.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
com.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
com.google.protobuf.ServiceException
public 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.BlockingInterface
com.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.BlockingInterface
com.google.protobuf.ServiceException
private com.google.protobuf.Message execServiceOnRegion(Region region, org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall serviceCall) throws IOException
IOException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the get requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
rpcc
- the RPC controllerrequest
- the multi requestcom.google.protobuf.ServiceException
private void skipCellsForMutations(List<org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action> actions, CellScanner cellScanner)
private void skipCellsForMutation(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action action, CellScanner cellScanner)
public 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.BlockingInterface
rpcc
- the RPC controllerrequest
- the mutate requestcom.google.protobuf.ServiceException
public 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.BlockingInterface
controller
- the RPC controllerrequest
- the scan requestcom.google.protobuf.ServiceException
private boolean closeScanner(Region region, RegionScanner scanner, String scannerName) throws IOException
IOException
public 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.BlockingInterface
com.google.protobuf.ServiceException
public 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.BlockingInterface
com.google.protobuf.ServiceException
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.