Uses of Interface
org.apache.hadoop.hbase.client.HConnection

Packages that use HConnection
org.apache.hadoop.hbase.catalog   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.ipc   
org.apache.hadoop.hbase.security.token   
 

Uses of HConnection in org.apache.hadoop.hbase.catalog
 

Methods in org.apache.hadoop.hbase.catalog that return HConnection
 HConnection CatalogTracker.getConnection()
           
 

Constructors in org.apache.hadoop.hbase.catalog with parameters of type HConnection
CatalogTracker(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, HConnection connection, Abortable abortable)
           
 

Uses of HConnection in org.apache.hadoop.hbase.client
 

Subinterfaces of HConnection in org.apache.hadoop.hbase.client
 interface StatisticsHConnection
          A server statistics tracking aware HConnection.
 

Classes in org.apache.hadoop.hbase.client that implement HConnection
static class HConnectionManager.HConnectionImplementation
          Encapsulates connection to zookeeper and regionservers.
 

Fields in org.apache.hadoop.hbase.client declared as HConnection
protected  HConnection RegionServerCallable.connection
           
protected  HConnection HTable.connection
           
 

Methods in org.apache.hadoop.hbase.client that return HConnection
static HConnection HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf)
          Create a new HConnection instance using the passed conf instance.
static HConnection HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool)
          Create a new HConnection instance using the passed conf instance.
static HConnection HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, User user)
          Create a new HConnection instance using the passed conf instance.
static HConnection HConnectionManager.createConnection(org.apache.hadoop.conf.Configuration conf, User user)
          Create a new HConnection instance using the passed conf instance.
 HConnection HTable.getConnection()
          Deprecated. This method will be changed from public to package protected.
protected  HConnection ClientScanner.getConnection()
           
 HConnection HBaseAdmin.getConnection()
           
static HConnection HConnectionManager.getConnection(org.apache.hadoop.conf.Configuration conf)
          Deprecated. 
 

Methods in org.apache.hadoop.hbase.client with parameters of type HConnection
static NavigableMap<HRegionInfo,ServerName> MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf, HConnection connection, TableName tableName, boolean offlined)
          Lists all of the table regions currently in META.
abstract  T HConnectable.connect(HConnection connection)
           
static void HConnectionManager.deleteStaleConnection(HConnection connection)
          Deprecated.  
 RegionServerCallable<Result[]> ClientSmallScanner.SmallScannerCallableFactory.getCallable(Scan sc, HConnection connection, TableName tableName, ScanMetrics scanMetrics, byte[] localStartKey, int cacheNum, RpcControllerFactory rpcControllerFactory)
           
static NonceGenerator HConnectionManager.injectNonceGeneratorForTesting(HConnection conn, NonceGenerator cnm)
           
static void MetaScanner.metaScan(org.apache.hadoop.conf.Configuration configuration, HConnection connection, MetaScanner.MetaScannerVisitor visitor, TableName userTableName)
          Scans the meta table and calls a visitor on each RowResult.
static void MetaScanner.metaScan(org.apache.hadoop.conf.Configuration configuration, HConnection connection, MetaScanner.MetaScannerVisitor visitor, TableName tableName, byte[] row, int rowLimit, TableName metaTableName)
          Scans the meta table and calls a visitor on each RowResult.
 

Constructors in org.apache.hadoop.hbase.client with parameters of type HConnection
ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, byte[] tableName, HConnection connection)
          Deprecated. Use ClientScanner.ClientScanner(Configuration, Scan, TableName, HConnection)
ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection)
          Create a new ClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection, RpcRetryingCallerFactory rpcFactory)
          Deprecated. Use ClientScanner.ClientScanner(Configuration, Scan, TableName, HConnection, RpcRetryingCallerFactory, RpcControllerFactory) instead
ClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory)
          Create a new ClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
ClientSmallReversedScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection)
          Create a new ReversibleClientScanner for the specified table Note that the passed Scan's start row maybe changed.
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection)
          Create a new ClientSmallScanner for the specified table.
ClientSmallScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory controllerFactory)
          Create a new ShortClientScanner for the specified table Note that the passed Scan's start row maybe changed changed.
HBaseAdmin(HConnection connection)
          Constructor for externally managed HConnections.
HTable(byte[] tableName, HConnection connection, ExecutorService pool)
          Creates an object to access a HBase table.
HTable(TableName tableName, HConnection connection)
          Creates an object to access a HBase table.
HTable(TableName tableName, HConnection connection, ExecutorService pool)
          Creates an object to access a HBase table.
HTable(TableName tableName, HConnection connection, TableConfiguration tableConfig, RpcRetryingCallerFactory rpcCallerFactory, RpcControllerFactory rpcControllerFactory, ExecutorService pool)
          Creates an object to access a HBase table.
RegionServerCallable(HConnection connection, TableName tableName, byte[] row)
           
ReversedClientScanner(org.apache.hadoop.conf.Configuration conf, Scan scan, TableName tableName, HConnection connection)
          Create a new ReversibleClientScanner for the specified table Note that the passed Scan's start row maybe changed.
ReversedScannerCallable(HConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, byte[] locateStartRow)
          Deprecated. 
ReversedScannerCallable(HConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, byte[] locateStartRow, PayloadCarryingRpcController rpcFactory)
           
ScannerCallable(HConnection connection, byte[] tableName, Scan scan, ScanMetrics scanMetrics)
          Deprecated. Use ScannerCallable.ScannerCallable(HConnection, TableName, Scan, ScanMetrics, PayloadCarryingRpcController)
ScannerCallable(HConnection connection, TableName tableName, Scan scan, ScanMetrics scanMetrics, PayloadCarryingRpcController controller)
           
 

Uses of HConnection in org.apache.hadoop.hbase.ipc
 

Constructors in org.apache.hadoop.hbase.ipc with parameters of type HConnection
MasterCoprocessorRpcChannel(HConnection conn)
           
RegionCoprocessorRpcChannel(HConnection conn, TableName table, byte[] row, RpcRetryingCallerFactory rpcFactory, RpcControllerFactory rpcControllerFactory)
           
RegionServerCoprocessorRpcChannel(HConnection conn, ServerName serverName)
           
 

Uses of HConnection in org.apache.hadoop.hbase.security.token
 

Methods in org.apache.hadoop.hbase.security.token with parameters of type HConnection
static void TokenUtil.addTokenForJob(HConnection conn, org.apache.hadoop.mapred.JobConf job, User user)
          Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
static void TokenUtil.addTokenForJob(HConnection conn, User user, org.apache.hadoop.mapreduce.Job job)
          Checks for an authentication token for the given user, obtaining a new token if necessary, and adds it to the credentials for the given map reduce job.
static boolean TokenUtil.addTokenIfMissing(HConnection conn, User user)
          Checks if an authentication tokens exists for the connected cluster, obtaining one if needed and adding it to the user's credentials.
static void TokenUtil.obtainAndCacheToken(HConnection conn, User user)
          Obtain an authentication token for the given user and add it to the user's credentials.
static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier> TokenUtil.obtainToken(HConnection conn)
          Obtain and return an authentication token for the current user.
static org.apache.hadoop.security.token.Token<AuthenticationTokenIdentifier> TokenUtil.obtainToken(HConnection conn, User user)
          Obtain and return an authentication token for the current user.
static void TokenUtil.obtainTokenForJob(HConnection conn, org.apache.hadoop.mapred.JobConf job, User user)
          Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
static void TokenUtil.obtainTokenForJob(HConnection conn, User user, org.apache.hadoop.mapreduce.Job job)
          Obtain an authentication token on behalf of the given user and add it to the credentials for the given map reduce job.
 



Copyright © 2007-2015 The Apache Software Foundation. All Rights Reserved.