Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.master.balancer | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.util |
Modifier and Type | Method and Description |
---|---|
void |
HDFSBlocksDistribution.add(HDFSBlocksDistribution otherBlocksDistribution)
This will add the distribution from input to this object
|
Modifier and Type | Method and Description |
---|---|
static List<String> |
TableSnapshotInputFormatImpl.getBestLocations(org.apache.hadoop.conf.Configuration conf,
HDFSBlocksDistribution blockDistribution) |
private static List<String> |
TableSnapshotInputFormatImpl.getBestLocations(org.apache.hadoop.conf.Configuration conf,
HDFSBlocksDistribution blockDistribution,
int numTopsAtMost)
This computes the locations to be passed from the InputSplit.
|
Modifier and Type | Field and Description |
---|---|
private static HDFSBlocksDistribution |
RegionLocationFinder.EMPTY_BLOCK_DISTRIBUTION |
Modifier and Type | Field and Description |
---|---|
private org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.cache |
private org.apache.hbase.thirdparty.com.google.common.cache.CacheLoader<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.loader |
Modifier and Type | Method and Description |
---|---|
HDFSBlocksDistribution |
RegionLocationFinder.getBlockDistribution(RegionInfo hri) |
protected HDFSBlocksDistribution |
RegionLocationFinder.internalGetTopBlockLocation(RegionInfo region)
Returns an ordered list of hosts that are hosting the blocks for this
region.
|
Modifier and Type | Method and Description |
---|---|
private org.apache.hbase.thirdparty.com.google.common.util.concurrent.ListenableFuture<HDFSBlocksDistribution> |
RegionLocationFinder.asyncGetBlockDistribution(RegionInfo hri) |
private org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.createCache()
Create a cache for region to list of servers
|
(package private) org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.getCache() |
Modifier and Type | Field and Description |
---|---|
private HDFSBlocksDistribution |
StoreFileInfo.hdfsBlocksDistribution |
Modifier and Type | Method and Description |
---|---|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
TableDescriptor tableDescriptor,
RegionInfo regionInfo)
This is a helper function to compute HDFS block distribution on demand
|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
TableDescriptor tableDescriptor,
RegionInfo regionInfo,
org.apache.hadoop.fs.Path tablePath)
This is a helper function to compute HDFS block distribution on demand
|
HDFSBlocksDistribution |
StoreFileInfo.computeHDFSBlocksDistribution(org.apache.hadoop.fs.FileSystem fs)
Compute the HDFS Block Distribution for this StoreFile
|
private HDFSBlocksDistribution |
StoreFileInfo.computeHDFSBlocksDistributionInternal(org.apache.hadoop.fs.FileSystem fs) |
private static HDFSBlocksDistribution |
StoreFileInfo.computeRefFileHDFSBlockDistribution(org.apache.hadoop.fs.FileSystem fs,
Reference reference,
org.apache.hadoop.fs.FileStatus status)
helper function to compute HDFS blocks distribution of a given reference
file.For reference file, we don't compute the exact value.
|
HDFSBlocksDistribution |
HStoreFile.getHDFSBlockDistribution() |
HDFSBlocksDistribution |
StoreFileInfo.getHDFSBlockDistribution() |
HDFSBlocksDistribution |
HRegion.getHDFSBlocksDistribution() |
Modifier and Type | Method and Description |
---|---|
static HDFSBlocksDistribution |
FSUtils.computeHDFSBlocksDistribution(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.FileStatus status,
long start,
long length)
Compute HDFS blocks distribution of a given file, or a portion of the file
|
Modifier and Type | Method and Description |
---|---|
static void |
FSUtils.addToHDFSBlocksDistribution(HDFSBlocksDistribution blocksDistribution,
org.apache.hadoop.fs.BlockLocation[] blockLocations)
Update blocksDistribution with blockLocations
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.