| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.mapred | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.thrift2 | Provides an HBase Thrift
service. | 
| org.apache.hadoop.hbase.thrift2.client | |
| org.apache.hadoop.hbase.tool | |
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Method and Description | 
|---|---|
| RegionLocator | SharedConnection. getRegionLocator(TableName tableName) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HRegionLocatorAn implementation of  RegionLocator. | 
| Modifier and Type | Method and Description | 
|---|---|
| RegionLocator | HTable. getRegionLocator() | 
| RegionLocator | Table. getRegionLocator()Gets the  RegionLocatorfor this table. | 
| RegionLocator | ConnectionImplementation. getRegionLocator(TableName tableName) | 
| RegionLocator | Connection. getRegionLocator(TableName tableName)Retrieve a RegionLocator implementation to inspect region information on a table. | 
| Modifier and Type | Field and Description | 
|---|---|
| private RegionLocator | HRegionPartitioner. locator | 
| private RegionLocator | TableInputFormatBase. regionLocator | 
| Modifier and Type | Field and Description | 
|---|---|
| private RegionLocator | HRegionPartitioner. locator | 
| private RegionLocator | TableInputFormatBase. regionLocatorThe  RegionLocatorof the table. | 
| private RegionLocator | HFileOutputFormat2.TableInfo. regionLocator | 
| Modifier and Type | Method and Description | 
|---|---|
| protected RegionLocator | TableInputFormatBase. getRegionLocator()Allows subclasses to get the  RegionLocator. | 
| RegionLocator | HFileOutputFormat2.TableInfo. getRegionLocator() | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | HFileOutputFormat2. configureIncrementalLoad(org.apache.hadoop.mapreduce.Job job,
                        TableDescriptor tableDescriptor,
                        RegionLocator regionLocator)Configure a MapReduce Job to perform an incremental load into the given
 table. | 
| static void | HFileOutputFormat2. configureIncrementalLoad(org.apache.hadoop.mapreduce.Job job,
                        Table table,
                        RegionLocator regionLocator)Configure a MapReduce Job to perform an incremental load into the given
 table. | 
| protected RegionSizeCalculator | TableInputFormatBase. createRegionSizeCalculator(RegionLocator locator,
                          Admin admin) | 
| private Set<ServerName> | RegionSizeCalculator. getRegionServersOfTable(RegionLocator regionLocator) | 
| private void | RegionSizeCalculator. init(RegionLocator regionLocator,
    Admin admin) | 
| Modifier and Type | Method and Description | 
|---|---|
| private static List<ImmutableBytesWritable> | HFileOutputFormat2. getRegionStartKeys(List<RegionLocator> regionLocators,
                  boolean writeMultipleTables)Return the start keys of all of the regions in this table,
 as a list of ImmutableBytesWritable. | 
| Constructor and Description | 
|---|
| RegionSizeCalculator(RegionLocator regionLocator,
                    Admin admin)Computes size of each region for table and given column families. | 
| TableInfo(TableDescriptor tableDesctiptor,
         RegionLocator regionLocator) | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | HFileReplicator. doBulkLoad(LoadIncrementalHFiles loadHFiles,
          Table table,
          Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
          RegionLocator locator,
          int maxRetries) | 
| Modifier and Type | Method and Description | 
|---|---|
| private RegionLocator | ThriftHBaseServiceHandler. getLocator(ByteBuffer tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| RegionLocator | ThriftTable. getRegionLocator() | 
| RegionLocator | ThriftConnection. getRegionLocator(TableName tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | LoadIncrementalHFiles. doBulkLoad(Map<byte[],List<org.apache.hadoop.fs.Path>> map,
          Admin admin,
          Table table,
          RegionLocator regionLocator,
          boolean silence,
          boolean copyFile)Deprecated.  Perform a bulk load of the given directory into the given pre-existing table. | 
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | LoadIncrementalHFiles. doBulkLoad(org.apache.hadoop.fs.Path hfofDir,
          Admin admin,
          Table table,
          RegionLocator regionLocator)Deprecated.  Perform a bulk load of the given directory into the given pre-existing table. | 
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | LoadIncrementalHFiles. doBulkLoad(org.apache.hadoop.fs.Path hfofDir,
          Admin admin,
          Table table,
          RegionLocator regionLocator,
          boolean silence,
          boolean copyFile)Deprecated.  Perform a bulk load of the given directory into the given pre-existing table. | 
| private Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | LoadIncrementalHFiles. performBulkLoad(Admin admin,
               Table table,
               RegionLocator regionLocator,
               Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
               ExecutorService pool,
               SecureBulkLoadClient secureClient,
               boolean copyFile)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| RegionLocator | ConnectionCache. getRegionLocator(byte[] tableName)Retrieve a regionLocator for the table. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.