Uses of Interface
org.apache.hadoop.hbase.client.RegionLocator
Package
Description
Provides HBase Client
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides an HBase Thrift
service.
-
Uses of RegionLocator in org.apache.hadoop.hbase
-
Uses of RegionLocator in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionConnection.getRegionLocator
(TableName tableName) Retrieve a RegionLocator implementation to inspect region information on a table.ConnectionImplementation.getRegionLocator
(TableName tableName) HTable.getRegionLocator()
Table.getRegionLocator()
Gets theRegionLocator
for this table. -
Uses of RegionLocator in org.apache.hadoop.hbase.mapred
Modifier and TypeFieldDescriptionprivate RegionLocator
HRegionPartitioner.locator
private RegionLocator
TableInputFormatBase.regionLocator
-
Uses of RegionLocator in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionprivate RegionLocator
HRegionPartitioner.locator
private RegionLocator
HFileOutputFormat2.TableInfo.regionLocator
private RegionLocator
TableInputFormatBase.regionLocator
TheRegionLocator
of the table.Modifier and TypeMethodDescriptionHFileOutputFormat2.TableInfo.getRegionLocator()
protected RegionLocator
TableInputFormatBase.getRegionLocator()
Allows subclasses to get theRegionLocator
.Modifier and TypeMethodDescriptionstatic 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 TypeMethodDescriptionprivate 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.ModifierConstructorDescriptionRegionSizeCalculator
(RegionLocator regionLocator, Admin admin) Computes size of each region for table and given column families.TableInfo
(TableDescriptor tableDesctiptor, RegionLocator regionLocator) -
Uses of RegionLocator in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionprivate void
HFileReplicator.doBulkLoad
(LoadIncrementalHFiles loadHFiles, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, RegionLocator locator, int maxRetries) -
Uses of RegionLocator in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionprivate RegionLocator
ThriftHBaseServiceHandler.getLocator
(ByteBuffer tableName) -
Uses of RegionLocator in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftConnection.getRegionLocator
(TableName tableName) ThriftTable.getRegionLocator()
-
Uses of RegionLocator in org.apache.hadoop.hbase.tool
Modifier and TypeMethodDescriptionLoadIncrementalHFiles.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.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.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.LoadIncrementalHFiles.performBulkLoad
(Admin admin, Table table, RegionLocator regionLocator, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, ExecutorService pool, SecureBulkLoadClient secureClient, boolean copyFile) Deprecated. -
Uses of RegionLocator in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescriptionConnectionCache.getRegionLocator
(byte[] tableName) Retrieve a regionLocator for the table.