@InterfaceAudience.Private public interface ClusterConnection extends HConnection
HBASE_CLIENT_CONNECTION_IMPL
Modifier and Type | Method and Description |
---|---|
void |
cacheLocation(TableName tableName,
RegionLocations location) |
void |
clearCaches(ServerName sn)
Clear any caches that pertain to server name
sn . |
void |
clearRegionCache()
Allows flushing the region cache.
|
void |
clearRegionCache(TableName tableName)
Allows flushing the region cache of all locations that pertain to
tableName |
void |
deleteCachedRegionLocation(HRegionLocation location)
Deletes cached locations for the specific region.
|
AdminProtos.AdminService.BlockingInterface |
getAdmin(ServerName serverName)
Establishes a connection to the region server at the specified address.
|
org.apache.hadoop.hbase.client.AsyncProcess |
getAsyncProcess() |
ClientBackoffPolicy |
getBackoffPolicy() |
ClientProtos.ClientService.BlockingInterface |
getClient(ServerName serverName)
Establishes a connection to the region server at the specified address, and returns
a region client protocol.
|
ConnectionConfiguration |
getConnectionConfiguration() |
org.apache.hadoop.hbase.client.MasterKeepAliveConnection |
getKeepAliveMasterService()
Deprecated.
|
MasterProtos.MasterService.BlockingInterface |
getMaster()
Returns a
MasterKeepAliveConnection to the active master |
RpcRetryingCallerFactory |
getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
Returns a new RpcRetryingCallerFactory from the given
Configuration . |
NonceGenerator |
getNonceGenerator() |
HRegionLocation |
getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row
|
RpcControllerFactory |
getRpcControllerFactory() |
RpcRetryingCallerFactory |
getRpcRetryingCallerFactory() |
ServerStatisticTracker |
getStatisticsTracker() |
boolean |
hasCellBlockSupport() |
boolean |
isDeadServer(ServerName serverName)
Deprecated.
internal method, do not use thru HConnection
|
boolean |
isManaged() |
boolean |
isMasterRunning()
Deprecated.
this has been deprecated without a replacement
|
boolean |
isTableAvailable(TableName tableName,
byte[][] splitKeys)
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.
|
HRegionLocation |
locateRegion(byte[] regionName)
Gets the location of the region of regionName.
|
HRegionLocation |
locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in.
|
RegionLocations |
locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry) |
RegionLocations |
locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId) |
List<HRegionLocation> |
locateRegions(TableName tableName)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Gets the locations of all regions in the specified table, tableName.
|
HRegionLocation |
relocateRegion(TableName tableName,
byte[] row)
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)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
void |
updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location cache.
|
clearRegionCache, getAdmin, getAdmin, getConfiguration, getCurrentNrHRS, getHTableDescriptor, getHTableDescriptor, getHTableDescriptors, getHTableDescriptorsByTableName, getRegionCachePrefetch, getRegionCachePrefetch, getRegionLocation, getRegionLocator, getTable, getTable, getTable, getTable, getTable, getTable, getTableNames, isClosed, isTableAvailable, isTableAvailable, isTableAvailable, isTableDisabled, isTableDisabled, isTableEnabled, isTableEnabled, listTableNames, listTables, locateRegion, locateRegions, locateRegions, processBatch, processBatch, processBatchCallback, processBatchCallback, relocateRegion, setRegionCachePrefetch, setRegionCachePrefetch, updateCachedLocations, updateCachedLocations
close, getBufferedMutator, getBufferedMutator
@Deprecated boolean isMasterRunning() throws MasterNotRunningException, ZooKeeperConnectionException
isMasterRunning
in interface HConnection
MasterNotRunningException
ZooKeeperConnectionException
boolean isTableAvailable(TableName tableName, byte[][] splitKeys) throws IOException
isTableAvailable
in interface HConnection
tableName
- tableNamesplitKeys
- splitKeys used while creating tableIOException
- if a remote or network exception occursHRegionLocation locateRegion(TableName tableName, byte[] row) throws IOException
locateRegion
in interface HConnection
tableName
- name of the table row is inrow
- row key you're trying to find the region ofIOException
- if a remote or network exception occursvoid clearRegionCache()
clearRegionCache
in interface HConnection
void cacheLocation(TableName tableName, RegionLocations location)
void clearRegionCache(TableName tableName)
tableName
clearRegionCache
in interface HConnection
tableName
- Name of the table whose regions we are to remove from
cache.void deleteCachedRegionLocation(HRegionLocation location)
deleteCachedRegionLocation
in interface HConnection
location
- The location object for the region, to be purged from cache.HRegionLocation relocateRegion(TableName tableName, byte[] row) throws IOException
relocateRegion
in interface HConnection
tableName
- name of the table row is inrow
- row key you're trying to find the region ofIOException
- if a remote or network exception occursRegionLocations relocateRegion(TableName tableName, byte[] row, int replicaId) throws IOException
tableName
- 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 occursvoid updateCachedLocations(TableName tableName, byte[] regionName, byte[] rowkey, Object exception, ServerName source)
updateCachedLocations
in interface HConnection
tableName
- the table nameregionName
- the region namerowkey
- the rowexception
- the exception if any. Can be null.source
- the previous locationHRegionLocation locateRegion(byte[] regionName) throws IOException
locateRegion
in interface HConnection
regionName
- name of the region to locateIOException
- if a remote or network exception occursList<HRegionLocation> locateRegions(TableName tableName) throws IOException
locateRegions
in interface HConnection
tableName
- table to get regions ofIOException
List<HRegionLocation> locateRegions(TableName tableName, boolean useCache, boolean offlined) throws IOException
locateRegions
in interface HConnection
tableName
- 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.IOException
RegionLocations locateRegion(TableName tableName, byte[] row, boolean useCache, boolean retry) throws IOException
tableName
- table to get regions ofrow
- the rowuseCache
- Should we use the cache to retrieve the region information.retry
- do we retryIOException
RegionLocations locateRegion(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) throws IOException
tableName
- 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 regionIOException
MasterProtos.MasterService.BlockingInterface getMaster() throws IOException
MasterKeepAliveConnection
to the active mastergetMaster
in interface HConnection
IOException
AdminProtos.AdminService.BlockingInterface getAdmin(ServerName serverName) throws IOException
getAdmin
in interface HConnection
serverName
- IOException
- if a remote or network exception occursClientProtos.ClientService.BlockingInterface getClient(ServerName serverName) throws IOException
getClient
in interface HConnection
serverName
- IOException
- if a remote or network exception occursHRegionLocation getRegionLocation(TableName tableName, byte[] row, boolean reload) throws IOException
getRegionLocation
in interface HConnection
tableName
- table namerow
- Row to find.reload
- If true do not use cache, otherwise bypass.IOException
- if a remote or network exception occursvoid clearCaches(ServerName sn)
sn
.clearCaches
in interface HConnection
sn
- A server name@Deprecated org.apache.hadoop.hbase.client.MasterKeepAliveConnection getKeepAliveMasterService() throws MasterNotRunningException
getKeepAliveMasterService
in interface HConnection
MasterNotRunningException
@Deprecated boolean isDeadServer(ServerName serverName)
isDeadServer
in interface HConnection
serverName
- NonceGenerator getNonceGenerator()
getNonceGenerator
in interface HConnection
org.apache.hadoop.hbase.client.AsyncProcess getAsyncProcess()
RpcRetryingCallerFactory getNewRpcRetryingCallerFactory(org.apache.hadoop.conf.Configuration conf)
Configuration
.
This RpcRetryingCallerFactory lets the users create RpcRetryingCaller
s which can be
intercepted with the configured RetryingCallerInterceptor
conf
- RpcRetryingCallerFactory getRpcRetryingCallerFactory()
RpcControllerFactory getRpcControllerFactory()
ConnectionConfiguration getConnectionConfiguration()
boolean isManaged()
ServerStatisticTracker getStatisticsTracker()
ClientBackoffPolicy getBackoffPolicy()
boolean hasCellBlockSupport()
Codec
and so
supports cell blocks.Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.