@InterfaceAudience.Private @Deprecated abstract class ConnectionAdapter extends Object implements ClusterConnection
HConnection instance.
A convenience to override when customizing method implementations.for case where we make
Connections skip RPC if request is to local server.| Modifier and Type | Field and Description |
|---|---|
private ClusterConnection |
wrappedConnection
Deprecated.
|
HBASE_CLIENT_CONNECTION_IMPL| Constructor and Description |
|---|
ConnectionAdapter(Connection c)
Deprecated.
|
| Modifier and Type | Method and Description |
|---|---|
void |
abort(String why,
Throwable e)
Deprecated.
Abort the server or client.
|
void |
cacheLocation(TableName tableName,
RegionLocations location)
Deprecated.
|
void |
clearCaches(ServerName sn)
Deprecated.
Clear any caches that pertain to server name
sn. |
void |
clearRegionCache()
Deprecated.
Allows flushing the region cache.
|
void |
clearRegionCache(byte[] tableName)
Deprecated.
|
void |
clearRegionCache(TableName tableName)
Deprecated.
Allows flushing the region cache of all locations that pertain to
tableName |
void |
close()
Deprecated.
|
void |
deleteCachedRegionLocation(HRegionLocation location)
Deprecated.
Deletes cached locations for the specific region.
|
Admin |
getAdmin()
Deprecated.
Retrieve an Admin implementation to administer an HBase cluster.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
getAdmin(ServerName serverName)
Deprecated.
Establishes a connection to the region server at the specified address.
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
getAdmin(ServerName serverName,
boolean getMaster)
Deprecated.
Establishes a connection to the region server at the specified address.
|
AsyncProcess |
getAsyncProcess()
Deprecated.
|
ClientBackoffPolicy |
getBackoffPolicy()
Deprecated.
|
BufferedMutator |
getBufferedMutator(BufferedMutatorParams params)
Deprecated.
Retrieve a
BufferedMutator for performing client-side buffering of writes. |
BufferedMutator |
getBufferedMutator(TableName tableName)
Deprecated.
Retrieve a
BufferedMutator for performing client-side buffering of writes. |
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
getClient(ServerName serverName)
Deprecated.
Establishes a connection to the region server at the specified address, and returns
a region client protocol.
|
org.apache.hadoop.conf.Configuration |
getConfiguration()
Deprecated.
|
ConnectionConfiguration |
getConnectionConfiguration()
Deprecated.
|
MetricsConnection |
getConnectionMetrics()
Deprecated.
|
int |
getCurrentNrHRS()
Deprecated.
|
HTableDescriptor |
getHTableDescriptor(byte[] tableName)
Deprecated.
|
HTableDescriptor |
getHTableDescriptor(TableName tableName)
Deprecated.
|
HTableDescriptor[] |
getHTableDescriptors(List<String> tableNames)
Deprecated.
|
HTableDescriptor[] |
getHTableDescriptorsByTableName(List<TableName> tableNames)
Deprecated.
|
MasterKeepAliveConnection |
getKeepAliveMasterService()
Deprecated.
This function allows HBaseAdmin and potentially others to get a shared MasterService
connection.
|
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface |
getMaster()
Deprecated.
Returns a
MasterKeepAliveConnection to the active master |
RpcRetryingCallerFactory |
getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
Deprecated.
Returns a new RpcRetryingCallerFactory from the given
Configuration. |
NonceGenerator |
getNonceGenerator()
Deprecated.
|
boolean |
getRegionCachePrefetch(byte[] tableName)
Deprecated.
|
boolean |
getRegionCachePrefetch(TableName tableName)
Deprecated.
|
HRegionLocation |
getRegionLocation(byte[] tableName,
byte[] row,
boolean reload)
Deprecated.
|
HRegionLocation |
getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Deprecated.
Find region location hosting passed row
|
RegionLocator |
getRegionLocator(TableName tableName)
Deprecated.
Retrieve a RegionLocator implementation to inspect region information on a table.
|
RpcControllerFactory |
getRpcControllerFactory()
Deprecated.
|
RpcRetryingCallerFactory |
getRpcRetryingCallerFactory()
Deprecated.
|
ServerStatisticTracker |
getStatisticsTracker()
Deprecated.
|
HTableInterface |
getTable(byte[] tableName)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
HTableInterface |
getTable(byte[] tableName,
ExecutorService pool)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
HTableInterface |
getTable(String tableName)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
HTableInterface |
getTable(String tableName,
ExecutorService pool)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
HTableInterface |
getTable(TableName tableName)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
HTableInterface |
getTable(TableName tableName,
ExecutorService pool)
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
|
String[] |
getTableNames()
Deprecated.
|
boolean |
hasCellBlockSupport()
Deprecated.
|
boolean |
isAborted()
Deprecated.
Check if the server or client was aborted.
|
boolean |
isClosed()
Deprecated.
Returns whether the connection is closed or not.
|
boolean |
isDeadServer(ServerName serverName)
Deprecated.
|
boolean |
isManaged()
Deprecated.
|
boolean |
isMasterRunning()
Deprecated.
|
boolean |
isTableAvailable(byte[] tableName)
Deprecated.
|
boolean |
isTableAvailable(byte[] tableName,
byte[][] splitKeys)
Deprecated.
|
boolean |
isTableAvailable(TableName tableName)
Deprecated.
|
boolean |
isTableAvailable(TableName tableName,
byte[][] splitKeys)
Deprecated.
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
|
boolean |
isTableDisabled(byte[] tableName)
Deprecated.
|
boolean |
isTableDisabled(TableName tableName)
Deprecated.
|
boolean |
isTableEnabled(byte[] tableName)
Deprecated.
|
boolean |
isTableEnabled(TableName tableName)
Deprecated.
A table that isTableEnabled == false and isTableDisabled == false
is possible.
|
TableName[] |
listTableNames()
Deprecated.
|
HTableDescriptor[] |
listTables()
Deprecated.
List all the userspace tables.
|
HRegionLocation |
locateRegion(byte[] regionName)
Deprecated.
Gets the location of the region of regionName.
|
HRegionLocation |
locateRegion(byte[] tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
locateRegion(TableName tableName,
byte[] row)
Deprecated.
Find the location of the region of tableName that row
lives in.
|
RegionLocations |
locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry)
Deprecated.
|
RegionLocations |
locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId)
Deprecated.
|
List<HRegionLocation> |
locateRegions(byte[] tableName)
Deprecated.
|
List<HRegionLocation> |
locateRegions(byte[] tableName,
boolean useCache,
boolean offlined)
Deprecated.
|
List<HRegionLocation> |
locateRegions(TableName tableName)
Deprecated.
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Deprecated.
Gets the locations of all regions in the specified table, tableName.
|
void |
processBatch(List<? extends Row> actions,
byte[] tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
processBatch(List<? extends Row> actions,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
Process a mixed batch of Get, Put and Delete actions.
|
<R> void |
processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
Parameterized batch processing, allowing varying return types for different
Row implementations. |
HRegionLocation |
relocateRegion(byte[] tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
relocateRegion(TableName tableName,
byte[] row)
Deprecated.
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
RegionLocations |
relocateRegion(TableName tableName,
byte[] row,
int replicaId)
Deprecated.
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
void |
setRegionCachePrefetch(byte[] tableName,
boolean enable)
Deprecated.
|
void |
setRegionCachePrefetch(TableName tableName,
boolean enable)
Deprecated.
|
void |
updateCachedLocations(byte[] tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Deprecated.
|
void |
updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Deprecated.
Update the location cache.
|
void |
updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Deprecated.
|
private final ClusterConnection wrappedConnection
public ConnectionAdapter(Connection c)
public void abort(String why, Throwable e)
Abortablepublic boolean isAborted()
Abortablepublic void close()
throws IOException
close in interface Closeableclose in interface AutoCloseableclose in interface ConnectionIOExceptionpublic org.apache.hadoop.conf.Configuration getConfiguration()
getConfiguration in interface ConnectiongetConfiguration in interface HConnectionpublic HTableInterface getTable(String tableName) throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).getTable in interface HConnectionIOExceptionpublic HTableInterface getTable(byte[] tableName) throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).getTable in interface HConnectionIOExceptionpublic HTableInterface getTable(TableName tableName) throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).getTable in interface ConnectiongetTable in interface HConnectiontableName - the name of the tableIOExceptionpublic HTableInterface getTable(String tableName, ExecutorService pool) throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).getTable in interface HConnectionpool - The thread pool to use for batch operations, null to use a default pool.IOExceptionpublic HTableInterface getTable(byte[] tableName, ExecutorService pool) throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).getTable in interface HConnectionpool - The thread pool to use for batch operations, null to use a default pool.IOExceptionpublic HTableInterface getTable(TableName tableName, ExecutorService pool) throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).getTable in interface ConnectiongetTable in interface HConnectiontableName - the name of the tablepool - The thread pool to use for batch operations, null to use a default pool.IOExceptionpublic BufferedMutator getBufferedMutator(BufferedMutatorParams params) throws IOException
ConnectionBufferedMutator for performing client-side buffering of writes. The
BufferedMutator returned by this method is thread-safe. This object can be used for
long lived table operations. The caller is responsible for calling
BufferedMutator.close() on the returned BufferedMutator instance.getBufferedMutator in interface Connectionparams - details on how to instantiate the BufferedMutator.BufferedMutator for the supplied tableName.IOExceptionpublic BufferedMutator getBufferedMutator(TableName tableName) throws IOException
Connection
Retrieve a BufferedMutator for performing client-side buffering of writes. The
BufferedMutator returned by this method is thread-safe. This BufferedMutator will
use the Connection's ExecutorService. This object can be used for long lived operations.
The caller is responsible for calling BufferedMutator.close() on
the returned BufferedMutator instance.
This accessor will use the connection's ExecutorService and will throw an exception in the main thread when an asynchronous exception occurs.
getBufferedMutator in interface ConnectiontableName - the name of the tableBufferedMutator for the supplied tableName.IOExceptionpublic RegionLocator getRegionLocator(TableName tableName) throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).getRegionLocator in interface ConnectiongetRegionLocator in interface HConnectiontableName - Name of the table who's region is to be examinedIOExceptionpublic Admin getAdmin() throws IOException
HConnectiongetAdmin in interface ConnectiongetAdmin in interface HConnectionIOExceptionpublic MetricsConnection getConnectionMetrics()
getConnectionMetrics in interface ClusterConnectionpublic boolean isMasterRunning()
throws MasterNotRunningException,
ZooKeeperConnectionException
isMasterRunning in interface ClusterConnectionisMasterRunning in interface HConnectionMasterNotRunningExceptionZooKeeperConnectionExceptionpublic boolean isTableEnabled(TableName tableName) throws IOException
HConnectionisTableEnabled in interface HConnectiontableName - table nameIOException - if a remote or network exception occurspublic boolean isTableEnabled(byte[] tableName)
throws IOException
isTableEnabled in interface HConnectionIOExceptionpublic boolean isTableDisabled(TableName tableName) throws IOException
isTableDisabled in interface HConnectiontableName - table nameIOException - if a remote or network exception occurspublic boolean isTableDisabled(byte[] tableName)
throws IOException
isTableDisabled in interface HConnectionIOExceptionpublic boolean isTableAvailable(TableName tableName) throws IOException
isTableAvailable in interface HConnectiontableName - table nameIOException - if a remote or network exception occurspublic boolean isTableAvailable(byte[] tableName)
throws IOException
isTableAvailable in interface HConnectionIOExceptionpublic boolean isTableAvailable(TableName tableName, byte[][] splitKeys) throws IOException
ClusterConnectionisTableAvailable in interface ClusterConnectionisTableAvailable in interface HConnectiontableName - tableNamesplitKeys - splitKeys used while creating tableIOException - if a remote or network exception occurspublic boolean isTableAvailable(byte[] tableName,
byte[][] splitKeys)
throws IOException
isTableAvailable in interface HConnectionIOExceptionpublic HTableDescriptor[] listTables() throws IOException
HConnectionlistTables in interface HConnectionIOException - if a remote or network exception occurspublic String[] getTableNames() throws IOException
getTableNames in interface HConnectionIOExceptionpublic TableName[] listTableNames() throws IOException
listTableNames in interface HConnectionIOExceptionpublic HTableDescriptor getHTableDescriptor(TableName tableName) throws IOException
getHTableDescriptor in interface HConnectiontableName - table nameIOException - if a remote or network exception occurspublic HTableDescriptor getHTableDescriptor(byte[] tableName) throws IOException
getHTableDescriptor in interface HConnectionIOExceptionpublic HRegionLocation locateRegion(TableName tableName, byte[] row) throws IOException
ClusterConnectionlocateRegion in interface ClusterConnectionlocateRegion in interface HConnectiontableName - name of the table row is inrow - row key you're trying to find the region ofIOException - if a remote or network exception occurspublic HRegionLocation locateRegion(byte[] tableName, byte[] row) throws IOException
locateRegion in interface HConnectionIOExceptionpublic RegionLocations locateRegion(TableName tableName, byte[] row, boolean useCache, boolean retry) throws IOException
locateRegion in interface ClusterConnectiontableName - table to get regions ofrow - the rowuseCache - Should we use the cache to retrieve the region information.retry - do we retryIOExceptionpublic void clearRegionCache()
ClusterConnectionclearRegionCache in interface ClusterConnectionclearRegionCache in interface HConnectionpublic void clearRegionCache(TableName tableName)
ClusterConnectiontableNameclearRegionCache in interface ClusterConnectionclearRegionCache in interface HConnectiontableName - Name of the table whose regions we are to remove from
cache.public void clearRegionCache(byte[] tableName)
clearRegionCache in interface HConnectionpublic void cacheLocation(TableName tableName, RegionLocations location)
cacheLocation in interface ClusterConnectionpublic void deleteCachedRegionLocation(HRegionLocation location)
ClusterConnectiondeleteCachedRegionLocation in interface ClusterConnectiondeleteCachedRegionLocation in interface HConnectionlocation - The location object for the region, to be purged from cache.public HRegionLocation relocateRegion(TableName tableName, byte[] row) throws IOException
ClusterConnectionrelocateRegion in interface ClusterConnectionrelocateRegion in interface HConnectiontableName - name of the table row is inrow - row key you're trying to find the region ofIOException - if a remote or network exception occurspublic HRegionLocation relocateRegion(byte[] tableName, byte[] row) throws IOException
relocateRegion in interface HConnectionIOExceptionpublic void updateCachedLocations(TableName tableName, byte[] rowkey, Object exception, HRegionLocation source)
updateCachedLocations in interface HConnectionpublic void updateCachedLocations(TableName tableName, byte[] regionName, byte[] rowkey, Object exception, ServerName source)
ClusterConnectionupdateCachedLocations in interface ClusterConnectionupdateCachedLocations in interface HConnectiontableName - the table nameregionName - the region namerowkey - the rowexception - the exception if any. Can be null.source - the previous locationpublic void updateCachedLocations(byte[] tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
updateCachedLocations in interface HConnectionpublic HRegionLocation locateRegion(byte[] regionName) throws IOException
ClusterConnectionlocateRegion in interface ClusterConnectionlocateRegion in interface HConnectionregionName - name of the region to locateIOException - if a remote or network exception occurspublic List<HRegionLocation> locateRegions(TableName tableName) throws IOException
ClusterConnectionlocateRegions in interface ClusterConnectionlocateRegions in interface HConnectiontableName - table to get regions ofIOExceptionpublic List<HRegionLocation> locateRegions(byte[] tableName) throws IOException
locateRegions in interface HConnectionIOExceptionpublic List<HRegionLocation> locateRegions(TableName tableName, boolean useCache, boolean offlined) throws IOException
ClusterConnectionlocateRegions in interface ClusterConnectionlocateRegions in interface HConnectiontableName - table to get regions ofuseCache - Should we use the cache to retrieve the region information.offlined - True if we are to include offlined regions, false and we'll leave out offlined
regions from returned list.IOExceptionpublic List<HRegionLocation> locateRegions(byte[] tableName, boolean useCache, boolean offlined) throws IOException
locateRegions in interface HConnectionIOExceptionpublic RegionLocations locateRegion(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) throws IOException
locateRegion in interface ClusterConnectiontableName - table to get regions ofrow - the rowuseCache - Should we use the cache to retrieve the region information.retry - do we retryreplicaId - the replicaId for the regionIOExceptionpublic RegionLocations relocateRegion(TableName tableName, byte[] row, int replicaId) throws IOException
ClusterConnectionrelocateRegion in interface ClusterConnectiontableName - name of the table row is inrow - row key you're trying to find the region ofreplicaId - the replicaId of the regionIOException - if a remote or network exception occurspublic org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface getMaster()
throws IOException
ClusterConnectionMasterKeepAliveConnection to the active mastergetMaster in interface ClusterConnectiongetMaster in interface HConnectionIOExceptionpublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(ServerName serverName) throws IOException
ClusterConnectiongetAdmin in interface ClusterConnectiongetAdmin in interface HConnectionIOException - if a remote or network exception occurspublic org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(ServerName serverName) throws IOException
ClusterConnectiongetClient in interface ClusterConnectiongetClient in interface HConnectionIOException - if a remote or network exception occurspublic org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(ServerName serverName, boolean getMaster) throws IOException
HConnectiongetAdmin in interface HConnectiongetMaster - do we check if master is aliveIOException - if a remote or network exception occurspublic HRegionLocation getRegionLocation(TableName tableName, byte[] row, boolean reload) throws IOException
ClusterConnectiongetRegionLocation in interface ClusterConnectiongetRegionLocation in interface HConnectiontableName - table namerow - Row to find.reload - If true do not use cache, otherwise bypass.IOException - if a remote or network exception occurspublic HRegionLocation getRegionLocation(byte[] tableName, byte[] row, boolean reload) throws IOException
getRegionLocation in interface HConnectionIOExceptionpublic void processBatch(List<? extends Row> actions, TableName tableName, ExecutorService pool, Object[] results) throws IOException, InterruptedException
HConnectionprocessBatch in interface HConnectionactions - The collection of actions.tableName - Name of the hbase tablepool - thread pool for parallel executionresults - An empty array, same size as list. If an exception is thrown,
you can test here for partial results, and to determine which actions
processed successfully.IOException - if there are problems talking to META. Per-item
exceptions are stored in the results array.InterruptedExceptionpublic void processBatch(List<? extends Row> actions, byte[] tableName, ExecutorService pool, Object[] results) throws IOException, InterruptedException
processBatch in interface HConnectionIOExceptionInterruptedExceptionpublic <R> void processBatchCallback(List<? extends Row> list, TableName tableName, ExecutorService pool, Object[] results, Batch.Callback<R> callback) throws IOException, InterruptedException
HConnectionRow implementations.processBatchCallback in interface HConnectionIOExceptionInterruptedExceptionpublic <R> void processBatchCallback(List<? extends Row> list, byte[] tableName, ExecutorService pool, Object[] results, Batch.Callback<R> callback) throws IOException, InterruptedException
processBatchCallback in interface HConnectionIOExceptionInterruptedExceptionpublic void setRegionCachePrefetch(TableName tableName, boolean enable)
setRegionCachePrefetch in interface HConnectionpublic void setRegionCachePrefetch(byte[] tableName,
boolean enable)
setRegionCachePrefetch in interface HConnectionpublic boolean getRegionCachePrefetch(TableName tableName)
getRegionCachePrefetch in interface HConnectionpublic boolean getRegionCachePrefetch(byte[] tableName)
getRegionCachePrefetch in interface HConnectionpublic int getCurrentNrHRS()
throws IOException
getCurrentNrHRS in interface HConnectionIOException - if a remote or network exception occurspublic HTableDescriptor[] getHTableDescriptorsByTableName(List<TableName> tableNames) throws IOException
getHTableDescriptorsByTableName in interface HConnectiontableNames - List of table namesIOException - if a remote or network exception occurspublic HTableDescriptor[] getHTableDescriptors(List<String> tableNames) throws IOException
getHTableDescriptors in interface HConnectionIOExceptionpublic boolean isClosed()
ConnectionisClosed in interface ConnectionisClosed in interface HConnectionpublic void clearCaches(ServerName sn)
ClusterConnectionsn.clearCaches in interface ClusterConnectionclearCaches in interface HConnectionsn - A server namepublic MasterKeepAliveConnection getKeepAliveMasterService() throws MasterNotRunningException
ClusterConnectiongetKeepAliveMasterService in interface ClusterConnectiongetKeepAliveMasterService in interface HConnectionMasterNotRunningExceptionpublic boolean isDeadServer(ServerName serverName)
isDeadServer in interface ClusterConnectionisDeadServer in interface HConnectionpublic NonceGenerator getNonceGenerator()
getNonceGenerator in interface ClusterConnectiongetNonceGenerator in interface HConnectionpublic AsyncProcess getAsyncProcess()
getAsyncProcess in interface ClusterConnectionpublic RpcRetryingCallerFactory getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
ClusterConnectionConfiguration.
This RpcRetryingCallerFactory lets the users create RpcRetryingCallers which can be
intercepted with the configured RetryingCallerInterceptorgetNewRpcRetryingCallerFactory in interface ClusterConnectionpublic boolean isManaged()
isManaged in interface ClusterConnectionpublic ServerStatisticTracker getStatisticsTracker()
getStatisticsTracker in interface ClusterConnectionpublic ClientBackoffPolicy getBackoffPolicy()
getBackoffPolicy in interface ClusterConnectionpublic boolean hasCellBlockSupport()
hasCellBlockSupport in interface ClusterConnectionCodec and so
supports cell blocks.public ConnectionConfiguration getConnectionConfiguration()
getConnectionConfiguration in interface ClusterConnectionpublic RpcRetryingCallerFactory getRpcRetryingCallerFactory()
getRpcRetryingCallerFactory in interface ClusterConnectionpublic RpcControllerFactory getRpcControllerFactory()
getRpcControllerFactory in interface ClusterConnectionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.