Uses of Interface
org.apache.hadoop.hbase.client.RegionLocator
Packages that use 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
Methods in org.apache.hadoop.hbase that return RegionLocator -
Uses of RegionLocator in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement RegionLocatorMethods in org.apache.hadoop.hbase.client that return RegionLocatorModifier 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 theRegionLocatorfor this table. -
Uses of RegionLocator in org.apache.hadoop.hbase.mapred
Fields in org.apache.hadoop.hbase.mapred declared as RegionLocatorModifier and TypeFieldDescriptionprivate RegionLocatorHRegionPartitioner.locatorprivate RegionLocatorTableInputFormatBase.regionLocator -
Uses of RegionLocator in org.apache.hadoop.hbase.mapreduce
Fields in org.apache.hadoop.hbase.mapreduce declared as RegionLocatorModifier and TypeFieldDescriptionprivate RegionLocatorHRegionPartitioner.locatorprivate RegionLocatorHFileOutputFormat2.TableInfo.regionLocatorprivate RegionLocatorTableInputFormatBase.regionLocatorTheRegionLocatorof the table.Methods in org.apache.hadoop.hbase.mapreduce that return RegionLocatorModifier and TypeMethodDescriptionHFileOutputFormat2.TableInfo.getRegionLocator()protected RegionLocatorTableInputFormatBase.getRegionLocator()Allows subclasses to get theRegionLocator.Methods in org.apache.hadoop.hbase.mapreduce with parameters of type RegionLocatorModifier and TypeMethodDescriptionstatic voidHFileOutputFormat2.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 voidHFileOutputFormat2.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 RegionSizeCalculatorTableInputFormatBase.createRegionSizeCalculator(RegionLocator locator, Admin admin) private Set<ServerName>RegionSizeCalculator.getRegionServersOfTable(RegionLocator regionLocator) private voidRegionSizeCalculator.init(RegionLocator regionLocator, Admin admin) Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type RegionLocatorModifier 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.Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type RegionLocatorModifierConstructorDescriptionRegionSizeCalculator(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
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type RegionLocatorModifier and TypeMethodDescriptionprivate voidHFileReplicator.doBulkLoad(LoadIncrementalHFiles loadHFiles, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, RegionLocator locator, int maxRetries) -
Uses of RegionLocator in org.apache.hadoop.hbase.thrift2
Methods in org.apache.hadoop.hbase.thrift2 that return RegionLocatorModifier and TypeMethodDescriptionprivate RegionLocatorThriftHBaseServiceHandler.getLocator(ByteBuffer tableName) -
Uses of RegionLocator in org.apache.hadoop.hbase.thrift2.client
Methods in org.apache.hadoop.hbase.thrift2.client that return RegionLocatorModifier and TypeMethodDescriptionThriftConnection.getRegionLocator(TableName tableName) ThriftTable.getRegionLocator() -
Uses of RegionLocator in org.apache.hadoop.hbase.tool
Methods in org.apache.hadoop.hbase.tool with parameters of type RegionLocatorModifier 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
Methods in org.apache.hadoop.hbase.util that return RegionLocatorModifier and TypeMethodDescriptionConnectionCache.getRegionLocator(byte[] tableName) Retrieve a regionLocator for the table.