static class TestClientNoCluster.RpcTimeoutConnection extends Object
Modifier and Type | Class and Description |
---|---|
(package private) static class |
org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState |
(package private) static class |
org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker |
Modifier and Type | Field and Description |
---|---|
protected String |
clusterId |
(package private) org.apache.hadoop.hbase.client.ClusterStatusListener |
clusterStatusListener |
(package private) org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState |
masterServiceState |
static String |
RETRIES_BY_SERVER_KEY |
(package private) int |
rpcTimeout |
(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
stub |
protected org.apache.hadoop.hbase.security.User |
user |
Constructor and Description |
---|
RpcTimeoutConnection(org.apache.hadoop.conf.Configuration conf,
ExecutorService pool,
org.apache.hadoop.hbase.security.User user) |
Modifier and Type | Method and Description |
---|---|
void |
abort(String arg0,
Throwable arg1) |
void |
cacheLocation(org.apache.hadoop.hbase.TableName arg0,
org.apache.hadoop.hbase.RegionLocations arg1) |
void |
clearCaches(org.apache.hadoop.hbase.ServerName arg0) |
void |
clearRegionCache() |
void |
clearRegionCache(org.apache.hadoop.hbase.TableName arg0) |
void |
clearRegionCache(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1) |
void |
close() |
void |
deleteCachedRegionLocation(org.apache.hadoop.hbase.HRegionLocation arg0) |
protected void |
finalize() |
org.apache.hadoop.hbase.client.Admin |
getAdmin() |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
getAdmin(org.apache.hadoop.hbase.ServerName arg0) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
getAdminForMaster() |
org.apache.hadoop.hbase.client.AsyncProcess |
getAsyncProcess() |
org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy |
getBackoffPolicy() |
org.apache.hadoop.hbase.client.BufferedMutator |
getBufferedMutator(org.apache.hadoop.hbase.client.BufferedMutatorParams arg0) |
org.apache.hadoop.hbase.client.BufferedMutator |
getBufferedMutator(org.apache.hadoop.hbase.TableName arg0) |
(package private) org.apache.hadoop.hbase.RegionLocations |
getCachedLocation(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
getClient(org.apache.hadoop.hbase.ServerName sn) |
org.apache.hadoop.conf.Configuration |
getConfiguration() |
org.apache.hadoop.hbase.client.ConnectionConfiguration |
getConnectionConfiguration() |
org.apache.hadoop.hbase.client.MetricsConnection |
getConnectionMetrics() |
protected ExecutorService |
getCurrentBatchPool() |
protected ExecutorService |
getCurrentMetaLookupPool() |
int |
getCurrentNrHRS() |
org.apache.hadoop.hbase.client.Hbck |
getHbck() |
org.apache.hadoop.hbase.client.Hbck |
getHbck(org.apache.hadoop.hbase.ServerName arg0) |
org.apache.hadoop.hbase.client.MasterKeepAliveConnection |
getMaster() |
org.apache.hadoop.hbase.client.RpcRetryingCallerFactory |
getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration arg0) |
org.apache.hadoop.hbase.client.NonceGenerator |
getNonceGenerator() |
(package private) int |
getNumberOfCachedRegionLocations(org.apache.hadoop.hbase.TableName arg0) |
org.apache.hadoop.hbase.HRegionLocation |
getRegionLocation(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1,
boolean arg2) |
org.apache.hadoop.hbase.client.RegionLocator |
getRegionLocator(org.apache.hadoop.hbase.TableName arg0) |
(package private) org.apache.hadoop.hbase.ipc.RpcClient |
getRpcClient() |
org.apache.hadoop.hbase.ipc.RpcControllerFactory |
getRpcControllerFactory() |
org.apache.hadoop.hbase.client.RpcRetryingCallerFactory |
getRpcRetryingCallerFactory() |
org.apache.hadoop.hbase.client.ServerStatisticTracker |
getStatisticsTracker() |
org.apache.hadoop.hbase.client.Table |
getTable(org.apache.hadoop.hbase.TableName arg0) |
org.apache.hadoop.hbase.client.TableBuilder |
getTableBuilder(org.apache.hadoop.hbase.TableName arg0,
ExecutorService arg1) |
org.apache.hadoop.hbase.client.TableState |
getTableState(org.apache.hadoop.hbase.TableName arg0) |
boolean |
hasCellBlockSupport() |
(package private) static org.apache.hadoop.hbase.client.NonceGenerator |
injectNonceGeneratorForTesting(org.apache.hadoop.hbase.client.ClusterConnection arg0,
org.apache.hadoop.hbase.client.NonceGenerator arg1) |
boolean |
isAborted() |
boolean |
isClosed() |
boolean |
isMasterRunning()
Deprecated.
|
boolean |
isTableAvailable(org.apache.hadoop.hbase.TableName arg0,
byte[][] arg1) |
boolean |
isTableDisabled(org.apache.hadoop.hbase.TableName arg0) |
boolean |
isTableEnabled(org.apache.hadoop.hbase.TableName arg0) |
org.apache.hadoop.hbase.HRegionLocation |
locateRegion(byte[] arg0) |
org.apache.hadoop.hbase.HRegionLocation |
locateRegion(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1) |
org.apache.hadoop.hbase.RegionLocations |
locateRegion(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1,
boolean arg2,
boolean arg3) |
org.apache.hadoop.hbase.RegionLocations |
locateRegion(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1,
boolean arg2,
boolean arg3,
int arg4) |
List<org.apache.hadoop.hbase.HRegionLocation> |
locateRegions(org.apache.hadoop.hbase.TableName arg0) |
List<org.apache.hadoop.hbase.HRegionLocation> |
locateRegions(org.apache.hadoop.hbase.TableName arg0,
boolean arg1,
boolean arg2) |
(package private) void |
releaseMaster(org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState arg0) |
org.apache.hadoop.hbase.HRegionLocation |
relocateRegion(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1) |
org.apache.hadoop.hbase.RegionLocations |
relocateRegion(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1,
int arg2) |
protected void |
retrieveClusterId() |
(package private) void |
setUseMetaReplicas(boolean arg0) |
String |
toString() |
(package private) void |
updateCachedLocation(org.apache.hadoop.hbase.client.RegionInfo arg0,
org.apache.hadoop.hbase.ServerName arg1,
org.apache.hadoop.hbase.ServerName arg2,
long arg3) |
void |
updateCachedLocations(org.apache.hadoop.hbase.TableName arg0,
byte[] arg1,
byte[] arg2,
Object arg3,
org.apache.hadoop.hbase.ServerName arg4) |
final org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface stub
public static final String RETRIES_BY_SERVER_KEY
final int rpcTimeout
org.apache.hadoop.hbase.client.ClusterStatusListener clusterStatusListener
protected org.apache.hadoop.hbase.security.User user
final org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState masterServiceState
RpcTimeoutConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user) throws IOException
IOException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(org.apache.hadoop.hbase.ServerName sn) throws IOException
getClient
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
void setUseMetaReplicas(boolean arg0)
static org.apache.hadoop.hbase.client.NonceGenerator injectNonceGeneratorForTesting(org.apache.hadoop.hbase.client.ClusterConnection arg0, org.apache.hadoop.hbase.client.NonceGenerator arg1)
public org.apache.hadoop.hbase.client.Table getTable(org.apache.hadoop.hbase.TableName arg0) throws IOException
getTable
in interface org.apache.hadoop.hbase.client.Connection
IOException
public org.apache.hadoop.hbase.client.TableBuilder getTableBuilder(org.apache.hadoop.hbase.TableName arg0, ExecutorService arg1)
getTableBuilder
in interface org.apache.hadoop.hbase.client.Connection
public org.apache.hadoop.hbase.client.BufferedMutator getBufferedMutator(org.apache.hadoop.hbase.client.BufferedMutatorParams arg0)
getBufferedMutator
in interface org.apache.hadoop.hbase.client.Connection
public org.apache.hadoop.hbase.client.BufferedMutator getBufferedMutator(org.apache.hadoop.hbase.TableName arg0)
getBufferedMutator
in interface org.apache.hadoop.hbase.client.Connection
public org.apache.hadoop.hbase.client.RegionLocator getRegionLocator(org.apache.hadoop.hbase.TableName arg0) throws IOException
getRegionLocator
in interface org.apache.hadoop.hbase.client.Connection
IOException
public org.apache.hadoop.hbase.client.Admin getAdmin() throws IOException
getAdmin
in interface org.apache.hadoop.hbase.client.Connection
IOException
public org.apache.hadoop.hbase.client.Hbck getHbck() throws IOException
getHbck
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.client.Hbck getHbck(org.apache.hadoop.hbase.ServerName arg0) throws IOException
getHbck
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.client.MetricsConnection getConnectionMetrics()
getConnectionMetrics
in interface org.apache.hadoop.hbase.client.ClusterConnection
protected ExecutorService getCurrentMetaLookupPool()
protected ExecutorService getCurrentBatchPool()
org.apache.hadoop.hbase.ipc.RpcClient getRpcClient()
protected void retrieveClusterId()
public org.apache.hadoop.conf.Configuration getConfiguration()
getConfiguration
in interface org.apache.hadoop.hbase.client.Connection
@Deprecated public boolean isMasterRunning() throws org.apache.hadoop.hbase.MasterNotRunningException, org.apache.hadoop.hbase.ZooKeeperConnectionException
isMasterRunning
in interface org.apache.hadoop.hbase.client.ClusterConnection
org.apache.hadoop.hbase.MasterNotRunningException
org.apache.hadoop.hbase.ZooKeeperConnectionException
public org.apache.hadoop.hbase.HRegionLocation getRegionLocation(org.apache.hadoop.hbase.TableName arg0, byte[] arg1, boolean arg2) throws IOException
getRegionLocation
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public boolean isTableEnabled(org.apache.hadoop.hbase.TableName arg0) throws IOException
isTableEnabled
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public boolean isTableDisabled(org.apache.hadoop.hbase.TableName arg0) throws IOException
isTableDisabled
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public boolean isTableAvailable(org.apache.hadoop.hbase.TableName arg0, @Nullable byte[][] arg1) throws IOException
isTableAvailable
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.HRegionLocation locateRegion(byte[] arg0) throws IOException
locateRegion
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public List<org.apache.hadoop.hbase.HRegionLocation> locateRegions(org.apache.hadoop.hbase.TableName arg0) throws IOException
locateRegions
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public List<org.apache.hadoop.hbase.HRegionLocation> locateRegions(org.apache.hadoop.hbase.TableName arg0, boolean arg1, boolean arg2) throws IOException
locateRegions
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.HRegionLocation locateRegion(org.apache.hadoop.hbase.TableName arg0, byte[] arg1) throws IOException
locateRegion
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.HRegionLocation relocateRegion(org.apache.hadoop.hbase.TableName arg0, byte[] arg1) throws IOException
relocateRegion
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.RegionLocations relocateRegion(org.apache.hadoop.hbase.TableName arg0, byte[] arg1, int arg2) throws IOException
relocateRegion
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.RegionLocations locateRegion(org.apache.hadoop.hbase.TableName arg0, byte[] arg1, boolean arg2, boolean arg3) throws IOException
locateRegion
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.RegionLocations locateRegion(org.apache.hadoop.hbase.TableName arg0, byte[] arg1, boolean arg2, boolean arg3, int arg4) throws IOException
locateRegion
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public void cacheLocation(org.apache.hadoop.hbase.TableName arg0, org.apache.hadoop.hbase.RegionLocations arg1)
cacheLocation
in interface org.apache.hadoop.hbase.client.ClusterConnection
org.apache.hadoop.hbase.RegionLocations getCachedLocation(org.apache.hadoop.hbase.TableName arg0, byte[] arg1)
public void clearRegionCache(org.apache.hadoop.hbase.TableName arg0, byte[] arg1)
public void clearCaches(org.apache.hadoop.hbase.ServerName arg0)
clearCaches
in interface org.apache.hadoop.hbase.client.ClusterConnection
public void clearRegionCache()
clearRegionCache
in interface org.apache.hadoop.hbase.client.ClusterConnection
public void clearRegionCache(org.apache.hadoop.hbase.TableName arg0)
clearRegionCache
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdminForMaster() throws IOException
getAdminForMaster
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(org.apache.hadoop.hbase.ServerName arg0) throws IOException
getAdmin
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.client.MasterKeepAliveConnection getMaster() throws IOException
getMaster
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
void releaseMaster(org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState arg0)
void updateCachedLocation(org.apache.hadoop.hbase.client.RegionInfo arg0, org.apache.hadoop.hbase.ServerName arg1, org.apache.hadoop.hbase.ServerName arg2, long arg3)
public void deleteCachedRegionLocation(org.apache.hadoop.hbase.HRegionLocation arg0)
deleteCachedRegionLocation
in interface org.apache.hadoop.hbase.client.ClusterConnection
public void updateCachedLocations(org.apache.hadoop.hbase.TableName arg0, byte[] arg1, byte[] arg2, Object arg3, org.apache.hadoop.hbase.ServerName arg4)
updateCachedLocations
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.client.AsyncProcess getAsyncProcess()
getAsyncProcess
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.client.ServerStatisticTracker getStatisticsTracker()
getStatisticsTracker
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy getBackoffPolicy()
getBackoffPolicy
in interface org.apache.hadoop.hbase.client.ClusterConnection
int getNumberOfCachedRegionLocations(org.apache.hadoop.hbase.TableName arg0)
public void abort(String arg0, Throwable arg1)
abort
in interface org.apache.hadoop.hbase.Abortable
public boolean isClosed()
isClosed
in interface org.apache.hadoop.hbase.client.Connection
public boolean isAborted()
isAborted
in interface org.apache.hadoop.hbase.Abortable
public int getCurrentNrHRS() throws IOException
getCurrentNrHRS
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public void close()
close
in interface Closeable
close
in interface AutoCloseable
close
in interface org.apache.hadoop.hbase.client.Connection
public org.apache.hadoop.hbase.client.NonceGenerator getNonceGenerator()
getNonceGenerator
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.client.TableState getTableState(org.apache.hadoop.hbase.TableName arg0) throws IOException
getTableState
in interface org.apache.hadoop.hbase.client.ClusterConnection
IOException
public org.apache.hadoop.hbase.client.RpcRetryingCallerFactory getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration arg0)
getNewRpcRetryingCallerFactory
in interface org.apache.hadoop.hbase.client.ClusterConnection
public boolean hasCellBlockSupport()
hasCellBlockSupport
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.client.ConnectionConfiguration getConnectionConfiguration()
getConnectionConfiguration
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.client.RpcRetryingCallerFactory getRpcRetryingCallerFactory()
getRpcRetryingCallerFactory
in interface org.apache.hadoop.hbase.client.ClusterConnection
public org.apache.hadoop.hbase.ipc.RpcControllerFactory getRpcControllerFactory()
getRpcControllerFactory
in interface org.apache.hadoop.hbase.client.ClusterConnection
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.