public static final class ServerConnectionUtils.ShortCircuitingClusterConnection extends ConnectionImplementation
ConnectionImplementation.MasterServiceState, ConnectionImplementation.ServerErrorTracker
Modifier and Type | Field and Description |
---|---|
private org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
localClientServiceBlockingInterfaceWrapper |
private org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
localHostAdmin |
private org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
localHostClient |
private ServerName |
serverName |
clusterId, clusterStatusListener, masterServiceState, RETRIES_BY_SERVER_KEY, rpcTimeout, user
HBASE_CLIENT_CONNECTION_IMPL
Modifier | Constructor and Description |
---|---|
private |
ShortCircuitingClusterConnection(org.apache.hadoop.conf.Configuration conf,
User user,
ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client,
ConnectionRegistry registry) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
getAdmin(ServerName sn)
Establishes a connection to the region server at the specified address.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
getClient(ServerName sn)
Establishes a connection to the region server at the specified address, and returns a region
client protocol.
|
MasterKeepAliveConnection |
getMaster()
Returns a
MasterKeepAliveConnection to the active master |
abort, cacheLocation, clearCaches, clearRegionCache, clearRegionCache, clearRegionLocationCache, close, deleteCachedRegionLocation, finalize, getAdmin, getAdminForMaster, getAsyncProcess, getBackoffPolicy, getBufferedMutator, getBufferedMutator, getCachedLocation, getChoreService, getClusterId, getConfiguration, getConnectionConfiguration, getConnectionMetrics, getConnectionRegistry, getCurrentBatchPool, getCurrentMetaLookupPool, getHbck, getHbck, getNewRpcRetryingCallerFactory, getNonceGenerator, getNumberOfCachedRegionLocations, getRegionLocation, getRegionLocator, getRpcClient, getRpcControllerFactory, getRpcRetryingCallerFactory, getStatisticsTracker, getTable, getTableBuilder, getTableState, getUser, hasCellBlockSupport, injectNonceGeneratorForTesting, isAborted, isClosed, isMasterRunning, isTableAvailable, isTableDisabled, isTableEnabled, locateRegion, locateRegion, locateRegion, locateRegion, locateRegions, locateRegions, releaseMaster, relocateRegion, relocateRegion, retrieveClusterId, takeUserRegionLock, toString, updateCachedLocation, updateCachedLocations
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
clearRegionCache
getTable
private final ServerName serverName
private final org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface localHostAdmin
private final org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface localHostClient
private final org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface localClientServiceBlockingInterfaceWrapper
private ShortCircuitingClusterConnection(org.apache.hadoop.conf.Configuration conf, User user, ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, ConnectionRegistry registry) throws IOException
IOException
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(ServerName sn) throws IOException
ClusterConnection
getAdmin
in interface ClusterConnection
getAdmin
in class ConnectionImplementation
sn
- the region server to connect toIOException
- if a remote or network exception occurspublic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(ServerName sn) throws IOException
ClusterConnection
getClient
in interface ClusterConnection
getClient
in class ConnectionImplementation
sn
- the region server to connect toIOException
- if a remote or network exception occurspublic MasterKeepAliveConnection getMaster() throws IOException
ClusterConnection
MasterKeepAliveConnection
to the active mastergetMaster
in interface ClusterConnection
getMaster
in class ConnectionImplementation
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.