|
||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||
java.lang.Objectorg.apache.hadoop.hbase.client.HConnectionManager.HConnectionImplementation
@InterfaceAudience.Private public static class HConnectionManager.HConnectionImplementation
Encapsulates connection to zookeeper and regionservers.
| Field Summary | |
|---|---|
protected String |
clusterId
|
| Fields inherited from interface org.apache.hadoop.hbase.client.HConnection |
|---|
HBASE_CLIENT_CONNECTION_IMPL |
| Constructor Summary | |
|---|---|
protected |
HConnectionManager.HConnectionImplementation(org.apache.hadoop.conf.Configuration conf)
For tests. |
| Method Summary | ||
|---|---|---|
void |
abort(String msg,
Throwable t)
Abort the server or client. |
|
void |
clearCaches(ServerName serverName)
Clear any caches that pertain to server name sn. |
|
void |
clearRegionCache()
Allows flushing the region cache. |
|
void |
clearRegionCache(byte[] tableName)
|
|
void |
clearRegionCache(TableName tableName)
Allows flushing the region cache of all locations that pertain to tableName |
|
void |
close()
|
|
protected
|
createAsyncProcess(TableName tableName,
ExecutorService pool,
org.apache.hadoop.hbase.client.AsyncProcess.AsyncProcessCallback<R> callback,
org.apache.hadoop.conf.Configuration conf)
|
|
void |
deleteCachedRegionLocation(HRegionLocation location)
Deletes cached locations for the specific region. |
|
protected void |
finalize()
Close the connection for good, regardless of what the current value of refCount is. |
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
getAdmin(ServerName serverName)
Establishes a connection to the region server at the specified address. |
|
org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
getAdmin(ServerName serverName,
boolean master)
Establishes a connection to the region server at the specified address. |
|
ClientBackoffPolicy |
getBackoffPolicy()
|
|
org.apache.hadoop.hbase.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. |
|
org.apache.hadoop.conf.Configuration |
getConfiguration()
|
|
protected ExecutorService |
getCurrentBatchPool()
|
|
int |
getCurrentNrHRS()
|
|
HTableDescriptor |
getHTableDescriptor(byte[] tableName)
|
|
HTableDescriptor |
getHTableDescriptor(TableName tableName)
Connects to the master to get the table descriptor. |
|
HTableDescriptor[] |
getHTableDescriptors(List<String> names)
|
|
HTableDescriptor[] |
getHTableDescriptorsByTableName(List<TableName> tableNames)
|
|
org.apache.hadoop.hbase.client.MasterKeepAliveConnection |
getKeepAliveMasterService()
This function allows HBaseAdmin and potentially others to get a shared MasterService connection. |
|
org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface |
getMaster()
Returns a MasterKeepAliveConnection to the active master |
|
NonceGenerator |
getNonceGenerator()
|
|
boolean |
getRegionCachePrefetch(byte[] tableName)
|
|
boolean |
getRegionCachePrefetch(TableName tableName)
Check whether region cache prefetch is enabled or not. |
|
HRegionLocation |
getRegionLocation(byte[] tableName,
byte[] row,
boolean reload)
|
|
HRegionLocation |
getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row |
|
ServerStatisticTracker |
getStatisticsTracker()
|
|
HTableInterface |
getTable(byte[] tableName)
Retrieve an HTableInterface implementation for access to a table. |
|
HTableInterface |
getTable(byte[] tableName,
ExecutorService pool)
Retrieve an HTableInterface implementation for access to a table. |
|
HTableInterface |
getTable(String tableName)
Retrieve an HTableInterface implementation for access to a table. |
|
HTableInterface |
getTable(String tableName,
ExecutorService pool)
Retrieve an HTableInterface implementation for access to a table. |
|
HTableInterface |
getTable(TableName tableName)
Retrieve an HTableInterface implementation for access to a table. |
|
HTableInterface |
getTable(TableName tableName,
ExecutorService pool)
Retrieve an HTableInterface implementation for access to a table. |
|
String[] |
getTableNames()
|
|
boolean |
isAborted()
Check if the server or client was aborted. |
|
boolean |
isClosed()
|
|
boolean |
isDeadServer(ServerName sn)
|
|
boolean |
isMasterRunning()
|
|
boolean |
isTableAvailable(byte[] tableName)
|
|
boolean |
isTableAvailable(byte[] tableName,
byte[][] splitKeys)
|
|
boolean |
isTableAvailable(TableName tableName)
|
|
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. |
|
boolean |
isTableDisabled(byte[] tableName)
|
|
boolean |
isTableDisabled(TableName tableName)
|
|
boolean |
isTableEnabled(byte[] tableName)
|
|
boolean |
isTableEnabled(TableName tableName)
A table that isTableEnabled == false and isTableDisabled == false is possible. |
|
TableName[] |
listTableNames()
|
|
HTableDescriptor[] |
listTables()
List all the userspace tables. |
|
HRegionLocation |
locateRegion(byte[] regionName)
Gets the location of the region of regionName. |
|
HRegionLocation |
locateRegion(byte[] tableName,
byte[] row)
|
|
HRegionLocation |
locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row lives in. |
|
List<HRegionLocation> |
locateRegions(byte[] tableName)
|
|
List<HRegionLocation> |
locateRegions(byte[] tableName,
boolean useCache,
boolean offlined)
|
|
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. |
|
void |
processBatch(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results)
Deprecated. |
|
void |
processBatch(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated. |
|
|
processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated. |
|
|
processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated. since 0.96 - Use HTable.processBatchCallback(java.util.List extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback instead |
|
HRegionLocation |
relocateRegion(byte[] tableName,
byte[] row)
|
|
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. |
|
void |
setRegionCachePrefetch(byte[] tableName,
boolean enable)
|
|
void |
setRegionCachePrefetch(TableName tableName,
boolean enable)
Enable or disable region cache prefetch for the table. |
|
String |
toString()
An identifier that will remain the same for a given connection. |
|
void |
updateCachedLocations(byte[] tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
|
|
void |
updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Update the location with the new value (if the exception is a RegionMovedException) or delete it from the cache. |
|
| Methods inherited from class java.lang.Object |
|---|
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait |
| Field Detail |
|---|
protected String clusterId
| Constructor Detail |
|---|
protected HConnectionManager.HConnectionImplementation(org.apache.hadoop.conf.Configuration conf)
| Method Detail |
|---|
public HTableInterface getTable(String tableName)
throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).
Since 0.98.1 this method no longer checks table existence. An exception will be thrown if the table does not exist only when the first operation is attempted.
getTable in interface HConnectionIOException
public HTableInterface getTable(byte[] tableName)
throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).
Since 0.98.1 this method no longer checks table existence. An exception will be thrown if the table does not exist only when the first operation is attempted.
getTable in interface HConnectionIOException
public HTableInterface getTable(TableName tableName)
throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).
Since 0.98.1 this method no longer checks table existence. An exception will be thrown if the table does not exist only when the first operation is attempted.
getTable in interface HConnectionIOException
public HTableInterface getTable(String tableName,
ExecutorService pool)
throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).
Since 0.98.1 this method no longer checks table existence. An exception will be thrown if the table does not exist only when the first operation is attempted.
getTable in interface HConnectionpool - The thread pool to use for batch operations, null to use a default pool.
IOException
public HTableInterface getTable(byte[] tableName,
ExecutorService pool)
throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).
Since 0.98.1 this method no longer checks table existence. An exception will be thrown if the table does not exist only when the first operation is attempted.
getTable in interface HConnectionpool - The thread pool to use for batch operations, null to use a default pool.
IOException
public HTableInterface getTable(TableName tableName,
ExecutorService pool)
throws IOException
HConnectionHConnectionManager.createConnection(Configuration)).
Since 0.98.1 this method no longer checks table existence. An exception will be thrown if the table does not exist only when the first operation is attempted.
getTable in interface HConnectionpool - The thread pool to use for batch operations, null to use a default pool.
IOExceptionprotected ExecutorService getCurrentBatchPool()
public String toString()
toString in class Objectpublic org.apache.hadoop.conf.Configuration getConfiguration()
getConfiguration in interface HConnection
public boolean isMasterRunning()
throws MasterNotRunningException,
ZooKeeperConnectionException
isMasterRunning in interface HConnectionMasterNotRunningException - - if the master is not running
ZooKeeperConnectionException
public HRegionLocation getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
throws IOException
HConnection
getRegionLocation in interface HConnectiontableName - table namerow - Row to find.reload - If true do not use cache, otherwise bypass.
IOException - if a remote or network exception occurs
public HRegionLocation getRegionLocation(byte[] tableName,
byte[] row,
boolean reload)
throws IOException
getRegionLocation in interface HConnectionIOException
public boolean isTableEnabled(TableName tableName)
throws IOException
HConnection
isTableEnabled in interface HConnectiontableName - table name
IOException - if a remote or network exception occurs
public boolean isTableEnabled(byte[] tableName)
throws IOException
isTableEnabled in interface HConnectionIOException
public boolean isTableDisabled(TableName tableName)
throws IOException
isTableDisabled in interface HConnectiontableName - table name
IOException - if a remote or network exception occurs
public boolean isTableDisabled(byte[] tableName)
throws IOException
isTableDisabled in interface HConnectionIOException
public boolean isTableAvailable(TableName tableName)
throws IOException
isTableAvailable in interface HConnectiontableName - table name
IOException - if a remote or network exception occurs
public boolean isTableAvailable(byte[] tableName)
throws IOException
isTableAvailable in interface HConnectionIOException
public boolean isTableAvailable(TableName tableName,
byte[][] splitKeys)
throws IOException
HConnection
isTableAvailable in interface HConnectiontableName - tableNamesplitKeys - splitKeys used while creating table
IOException - if a remote or network exception occurs
public boolean isTableAvailable(byte[] tableName,
byte[][] splitKeys)
throws IOException
isTableAvailable in interface HConnectionIOException
public HRegionLocation locateRegion(byte[] regionName)
throws IOException
HConnection
locateRegion in interface HConnectionregionName - name of the region to locate
IOException - if a remote or network exception occurspublic boolean isDeadServer(ServerName sn)
isDeadServer in interface HConnection
public List<HRegionLocation> locateRegions(TableName tableName)
throws IOException
HConnection
locateRegions in interface HConnectiontableName - table to get regions of
IOException
public List<HRegionLocation> locateRegions(byte[] tableName)
throws IOException
locateRegions in interface HConnectionIOException
public List<HRegionLocation> locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
throws IOException
HConnection
locateRegions 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.
IOException
public List<HRegionLocation> locateRegions(byte[] tableName,
boolean useCache,
boolean offlined)
throws IOException
locateRegions in interface HConnectionIOException
public HRegionLocation locateRegion(TableName tableName,
byte[] row)
throws IOException
HConnection
locateRegion in interface HConnectiontableName - name of the table row is inrow - row key you're trying to find the region of
IOException - if a remote or network exception occurs
public HRegionLocation locateRegion(byte[] tableName,
byte[] row)
throws IOException
locateRegion in interface HConnectionIOException
public HRegionLocation relocateRegion(TableName tableName,
byte[] row)
throws IOException
HConnection
relocateRegion in interface HConnectiontableName - name of the table row is inrow - row key you're trying to find the region of
IOException - if a remote or network exception occurs
public HRegionLocation relocateRegion(byte[] tableName,
byte[] row)
throws IOException
relocateRegion in interface HConnectionIOExceptionpublic void clearCaches(ServerName serverName)
HConnectionsn.
clearCaches in interface HConnectionserverName - A server namepublic void clearRegionCache()
HConnection
clearRegionCache in interface HConnectionpublic void clearRegionCache(TableName tableName)
HConnectiontableName
clearRegionCache in interface HConnectiontableName - Name of the table whose regions we are to remove from
cache.public void clearRegionCache(byte[] tableName)
clearRegionCache in interface HConnection
public org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(ServerName serverName)
throws IOException
HConnection
getAdmin in interface HConnectionIOException - if a remote or network exception occurs
public org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface getAdmin(ServerName serverName,
boolean master)
throws IOException
HConnection
getAdmin in interface HConnectionmaster - do we check if master is alive
IOException - if a remote or network exception occurs
public org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface getClient(ServerName sn)
throws IOException
HConnection
getClient in interface HConnectionIOException - if a remote or network exception occurs
public org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface getMaster()
throws MasterNotRunningException
HConnectionMasterKeepAliveConnection to the active master
getMaster in interface HConnectionMasterNotRunningException
public org.apache.hadoop.hbase.client.MasterKeepAliveConnection getKeepAliveMasterService()
throws MasterNotRunningException
HConnection
getKeepAliveMasterService in interface HConnectionMasterNotRunningExceptionpublic void deleteCachedRegionLocation(HRegionLocation location)
HConnection
deleteCachedRegionLocation in interface HConnectionlocation - The location object for the region, to be purged from cache.
public void updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
updateCachedLocations in interface HConnectionexception - an object (to simplify user code) on which we will try to find a nested
or wrapped or both RegionMovedExceptionsource - server that is the source of the location update.tableName - the table namerowkey - the row
public void updateCachedLocations(byte[] tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
updateCachedLocations in interface HConnection
@Deprecated
public void processBatch(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results)
throws IOException,
InterruptedException
HConnection
processBatch in interface HConnectionlist - 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.
InterruptedException
@Deprecated
public void processBatch(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results)
throws IOException,
InterruptedException
processBatch in interface HConnectionIOException
InterruptedException
@Deprecated
public <R> void processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
throws IOException,
InterruptedException
HTable.processBatchCallback(java.util.List extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead
processBatchCallback in interface HConnectionIOException
InterruptedException
@Deprecated
public <R> void processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
throws IOException,
InterruptedException
processBatchCallback in interface HConnectionIOException
InterruptedException
protected <R> org.apache.hadoop.hbase.client.AsyncProcess createAsyncProcess(TableName tableName,
ExecutorService pool,
org.apache.hadoop.hbase.client.AsyncProcess.AsyncProcessCallback<R> callback,
org.apache.hadoop.conf.Configuration conf)
public ServerStatisticTracker getStatisticsTracker()
getStatisticsTracker in interface HConnectionpublic ClientBackoffPolicy getBackoffPolicy()
getBackoffPolicy in interface HConnection
public void setRegionCachePrefetch(TableName tableName,
boolean enable)
HConnection
setRegionCachePrefetch in interface HConnectiontableName - name of table to configure.enable - Set to true to enable region cache prefetch.
public void setRegionCachePrefetch(byte[] tableName,
boolean enable)
setRegionCachePrefetch in interface HConnectionpublic boolean getRegionCachePrefetch(TableName tableName)
HConnection
getRegionCachePrefetch in interface HConnectiontableName - name of table to check
public boolean getRegionCachePrefetch(byte[] tableName)
getRegionCachePrefetch in interface HConnection
public void abort(String msg,
Throwable t)
Abortable
abort in interface Abortablemsg - Why we're aborting.t - Throwable that caused abort. Can be null.public boolean isClosed()
isClosed in interface HConnectionpublic boolean isAborted()
Abortable
isAborted in interface Abortable
public int getCurrentNrHRS()
throws IOException
getCurrentNrHRS in interface HConnectionIOException - if a remote or network exception occurspublic void close()
close in interface Closeable
protected void finalize()
throws Throwable
refCount is. Ideally, refCount should be zero at this
point, which would be the case if all of its consumers close the
connection. However, on the off chance that someone is unable to close
the connection, perhaps because it bailed out prematurely, the method
below will ensure that this HConnection instance is cleaned up.
Caveat: The JVM may take an unknown amount of time to call finalize on an
unreachable object, so our hope is that every consumer cleans up after
itself, like any good citizen.
finalize in class ObjectThrowable
public HTableDescriptor[] listTables()
throws IOException
HConnection
listTables in interface HConnectionIOException - if a remote or network exception occurs
public String[] getTableNames()
throws IOException
getTableNames in interface HConnectionIOException
public TableName[] listTableNames()
throws IOException
listTableNames in interface HConnectionIOException
public HTableDescriptor[] getHTableDescriptorsByTableName(List<TableName> tableNames)
throws IOException
getHTableDescriptorsByTableName in interface HConnectiontableNames - List of table names
IOException - if a remote or network exception occurs
public HTableDescriptor[] getHTableDescriptors(List<String> names)
throws IOException
getHTableDescriptors in interface HConnectionIOExceptionpublic NonceGenerator getNonceGenerator()
getNonceGenerator in interface HConnection
public HTableDescriptor getHTableDescriptor(TableName tableName)
throws IOException
getHTableDescriptor in interface HConnectiontableName - table name
IOException - if the connection to master fails or if the table
is not found.
public HTableDescriptor getHTableDescriptor(byte[] tableName)
throws IOException
getHTableDescriptor in interface HConnectionIOException
|
||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||