@InterfaceAudience.Private abstract class CancellableRegionServerCallable<T> extends ClientServiceCallable<T> implements Cancellable
Modifier and Type | Field and Description |
---|---|
private int |
rpcTimeout |
private RetryingTimeTracker |
tracker |
location, rpcController, stub
Constructor and Description |
---|
CancellableRegionServerCallable(Connection connection,
TableName tableName,
byte[] row,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int rpcTimeout,
RetryingTimeTracker tracker,
int priority) |
Modifier and Type | Method and Description |
---|---|
T |
call(int operationTimeout)
Override that changes call Exception from
Exception to IOException . |
void |
cancel() |
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileResponse |
doBulkLoadHFile(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request) |
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadResponse |
doCleanupBulkLoad(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request) |
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse |
doMulti(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request) |
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadResponse |
doPrepareBulkLoad(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request) |
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse |
doScan(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request) |
boolean |
isCancelled() |
void |
prepare(boolean reload)
Prepare by setting up any connections to servers, etc., ahead of call invocation.
|
protected void |
setStubByServiceName(ServerName serviceName)
Set the RCP client stub
|
doGet, doMutate
getConnection, getExceptionMessageAdditionalDetail, getHRegionInfo, getLocation, getPriority, getRow, getRpcController, getRpcControllerCellScanner, getStub, getTableName, rpcCall, setLocation, setRpcControllerCellScanner, setStub, sleep, throwable
private final RetryingTimeTracker tracker
private final int rpcTimeout
CancellableRegionServerCallable(Connection connection, TableName tableName, byte[] row, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int rpcTimeout, RetryingTimeTracker tracker, int priority)
public T call(int operationTimeout) throws IOException
RegionServerCallable
Exception
to IOException
.
Also does set up of the rpcController.call
in interface RetryingCallable<T>
call
in class RegionServerCallable<T,org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface>
operationTimeout
- - the time available for this call. 0 for infinite.IOException
public void prepare(boolean reload) throws IOException
RetryingCallable
prepare
in interface RetryingCallable<T>
prepare
in class RegionServerCallable<T,org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface>
reload
- Set this to true if need to requery locationsIOException
- eprotected void setStubByServiceName(ServerName serviceName) throws IOException
RegionServerCallable
setStubByServiceName
in class ClientServiceCallable<T>
serviceName
- to get the rpc stub forIOException
- When client could not be createdpublic void cancel()
cancel
in interface Cancellable
public boolean isCancelled()
isCancelled
in interface Cancellable
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse doMulti(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse doScan(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadResponse doPrepareBulkLoad(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileResponse doBulkLoadHFile(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
protected org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadResponse doCleanupBulkLoad(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.