@InterfaceAudience.Private @InterfaceStability.Evolving public class CoprocessorHConnection extends ConnectionManager.HConnectionImplementation
You should not use this class from any client - its an internal class meant for use by the coprocessor framework.
ConnectionManager.HConnectionImplementation.MasterServiceState, ConnectionManager.HConnectionImplementation.MasterServiceStubMaker, ConnectionManager.HConnectionImplementation.StubMaker
Modifier and Type | Field and Description |
---|---|
private static NonceGenerator |
NO_NONCE_GEN |
private HRegionServer |
server |
private ServerName |
serverName |
clusterId, clusterStatusListener, LOG, masterServiceState, registry, rpcTimeout, user
HBASE_CLIENT_CONNECTION_IMPL
Constructor and Description |
---|
CoprocessorHConnection(ClusterConnection delegate,
HRegionServer server)
Deprecated.
delegate is not used
|
CoprocessorHConnection(org.apache.hadoop.conf.Configuration conf,
HRegionServer server)
Constructor that accepts custom configuration
|
CoprocessorHConnection(HRegionServer server)
Constructor that uses server configuration
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
getClient(ServerName serverName)
Establishes a connection to the region server at the specified address, and returns
a region client protocol.
|
static ClusterConnection |
getConnectionForEnvironment(CoprocessorEnvironment env)
Create an unmanaged
HConnection based on the environment in which we are running the
coprocessor. |
NonceGenerator |
getNonceGenerator() |
abort, cacheLocation, clearCaches, clearRegionCache, clearRegionCache, clearRegionCache, clearRegionCache, close, createAsyncProcess, decCount, deleteCachedRegionLocation, finalize, getAdmin, getAdmin, getAdmin, getAsyncProcess, getBackoffPolicy, getBufferedMutator, getBufferedMutator, getCachedLocation, getConfiguration, getConnectionConfiguration, getConnectionMetrics, getCurrentBatchPool, getCurrentMetaLookupPool, getCurrentNrHRS, getHTableDescriptor, getHTableDescriptor, getHTableDescriptors, getHTableDescriptorsByTableName, getKeepAliveMasterService, getKeepAliveZooKeeperWatcher, getMaster, getNewRpcRetryingCallerFactory, getNumberOfCachedRegionLocations, getRegionCachePrefetch, getRegionCachePrefetch, getRegionLocation, getRegionLocation, getRegionLocator, getRpcClient, getRpcControllerFactory, getRpcRetryingCallerFactory, getStatisticsTracker, getStubKey, getTable, getTable, getTable, getTable, getTable, getTable, getTableNames, hasCellBlockSupport, incCount, internalClose, isAborted, isClosed, isDeadServer, isManaged, isMasterRunning, isTableAvailable, isTableAvailable, isTableAvailable, isTableAvailable, isTableDisabled, isTableDisabled, isTableEnabled, isTableEnabled, isZeroReference, listTableNames, listTables, locateRegion, locateRegion, locateRegion, locateRegion, locateRegion, locateRegions, locateRegions, locateRegions, locateRegions, processBatch, processBatch, processBatchCallback, processBatchCallback, releaseMaster, releaseZooKeeperWatcher, relocateRegion, relocateRegion, relocateRegion, retrieveClusterId, setRegionCachePrefetch, setRegionCachePrefetch, toString, updateCachedLocation, updateCachedLocations, updateCachedLocations, updateCachedLocations
private static final NonceGenerator NO_NONCE_GEN
private final ServerName serverName
private final HRegionServer server
@Deprecated public CoprocessorHConnection(ClusterConnection delegate, HRegionServer server) throws IOException
delegate
- server
- IOException
- if we cannot create the connectionpublic CoprocessorHConnection(HRegionServer server) throws IOException
server
- IOException
- if we cannot create the connectionpublic CoprocessorHConnection(org.apache.hadoop.conf.Configuration conf, HRegionServer server) throws IOException
conf
- server
- IOException
- if we cannot create the connectionpublic static ClusterConnection getConnectionForEnvironment(CoprocessorEnvironment env) throws IOException
HConnection
based on the environment in which we are running the
coprocessor. The HConnection
must be externally cleaned up (we bypass the usual HTable
cleanup mechanisms since we own everything).env
- environment hosting the HConnection
HConnection
.IOException
- if we cannot create the connectionpublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(ServerName serverName) throws IOException
ClusterConnection
getClient
in interface ClusterConnection
getClient
in interface HConnection
getClient
in class ConnectionManager.HConnectionImplementation
IOException
- if a remote or network exception occurspublic NonceGenerator getNonceGenerator()
getNonceGenerator
in interface ClusterConnection
getNonceGenerator
in interface HConnection
getNonceGenerator
in class ConnectionManager.HConnectionImplementation
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.