Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master.janitor |
Modifier and Type | Method and Description |
---|---|
static RegionLocations |
MetaTableAccessor.getRegionLocations(Result r)
Returns an HRegionLocationList extracted from the result.
|
RegionLocations |
RegionLocations.mergeLocations(RegionLocations other)
Merges this RegionLocations list with the given list assuming same range, and keeping the most
up to date version of the HRegionLocation entries from either list according to seqNum.
|
RegionLocations |
RegionLocations.remove(HRegionLocation location)
Removes the given location from the list
|
RegionLocations |
RegionLocations.remove(int replicaId)
Removes location of the given replicaId from the list
|
RegionLocations |
RegionLocations.removeByServer(ServerName serverName)
Returns a new RegionLocations with the locations removed (set to null) which have the
destination server as given.
|
RegionLocations |
RegionLocations.removeElementsWithNullLocation()
Set the element to null if its getServerName method returns null.
|
RegionLocations |
RegionLocations.updateLocation(HRegionLocation location,
boolean checkForEquals,
boolean force)
Updates the location with new only if the new location has a higher seqNum than the old one or
force is true.
|
Modifier and Type | Method and Description |
---|---|
private static Optional<RegionLocations> |
AsyncMetaTableAccessor.getRegionLocations(Result r)
Returns an HRegionLocationList extracted from the result.
|
Modifier and Type | Method and Description |
---|---|
RegionLocations |
RegionLocations.mergeLocations(RegionLocations other)
Merges this RegionLocations list with the given list assuming same range, and keeping the most
up to date version of the HRegionLocation entries from either list according to seqNum.
|
Modifier and Type | Field and Description |
---|---|
private RegionLocations |
AsyncNonMetaRegionLocator.RegionLocationsFutureResult.result |
Modifier and Type | Field and Description |
---|---|
private Map<AsyncNonMetaRegionLocator.LocateRequest,CompletableFuture<RegionLocations>> |
AsyncNonMetaRegionLocator.TableCache.allRequests |
private ConcurrentNavigableMap<byte[],RegionLocations> |
AsyncNonMetaRegionLocator.TableCache.cache |
private ConcurrentMap<TableName,ConcurrentNavigableMap<byte[],RegionLocations>> |
MetaCache.cachedRegionLocations
Map of table to table
HRegionLocation s. |
private CompletableFuture<RegionLocations> |
AsyncNonMetaRegionLocator.RegionLocationsFutureResult.future |
private AtomicReference<RegionLocations> |
AsyncMetaRegionLocator.metaRegionLocations |
private AtomicReference<CompletableFuture<RegionLocations>> |
AsyncMetaRegionLocator.metaRelocateFuture |
Modifier and Type | Method and Description |
---|---|
private RegionLocations |
AsyncNonMetaRegionLocator.addToCache(AsyncNonMetaRegionLocator.TableCache tableCache,
RegionLocations locs) |
(package private) static RegionLocations |
AsyncRegionLocatorHelper.createRegionLocations(HRegionLocation loc) |
private RegionLocations |
AsyncRequestFutureImpl.findAllLocationsOrFail(Action action,
boolean useCache) |
RegionLocations |
MetaCache.getCachedLocation(TableName tableName,
byte[] row)
Search the cache for a location that fits our table and row key.
|
(package private) RegionLocations |
ConnectionImplementation.getCachedLocation(TableName tableName,
byte[] row)
Search the cache for a location that fits our table and row key.
|
(package private) RegionLocations |
AsyncNonMetaRegionLocator.getRegionLocationInCache(TableName tableName,
byte[] row) |
(package private) static RegionLocations |
RpcRetryingCallerWithReadReplicas.getRegionLocations(boolean useCache,
int replicaId,
ClusterConnection cConnection,
TableName tableName,
byte[] row) |
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
protected RegionLocations |
ScannerCallable.getRegionLocationsForPrepare(byte[] row)
Fetch region locations for the row.
|
private RegionLocations |
AsyncNonMetaRegionLocator.locateInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType) |
private RegionLocations |
ConnectionImplementation.locateMeta(TableName tableName,
boolean useCache,
int replicaId) |
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry)
Gets the locations of the region in the specified table, tableName, for a given row.
|
RegionLocations |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry) |
RegionLocations |
ClusterConnection.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId)
Gets the locations of the region in the specified table, tableName, for a given row.
|
RegionLocations |
ConnectionImplementation.locateRegion(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId) |
private RegionLocations |
ConnectionImplementation.locateRegionInMeta(TableName tableName,
byte[] row,
boolean useCache,
boolean retry,
int replicaId)
Search the hbase:meta table for the HRegionLocation info that contains the table and row we're
seeking.
|
private RegionLocations |
AsyncNonMetaRegionLocator.locateRowBeforeInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId) |
private RegionLocations |
AsyncNonMetaRegionLocator.locateRowInCache(AsyncNonMetaRegionLocator.TableCache tableCache,
TableName tableName,
byte[] row,
int replicaId) |
RegionLocations |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row,
int replicaId)
Find the location of the region of tableName that row lives in, ignoring any
value that might be in the cache.
|
RegionLocations |
ConnectionImplementation.relocateRegion(TableName tableName,
byte[] row,
int replicaId) |
(package private) static RegionLocations |
AsyncRegionLocatorHelper.removeRegionLocation(RegionLocations oldLocs,
int replicaId)
Create a new
RegionLocations based on the given oldLocs , and remove the
location for the given replicaId . |
(package private) static RegionLocations |
AsyncRegionLocatorHelper.replaceRegionLocation(RegionLocations oldLocs,
HRegionLocation loc)
Create a new
RegionLocations based on the given oldLocs , and replace the
location for the given replicaId with the given loc . |
private static RegionLocations |
AbstractRpcBasedConnectionRegistry.transformMetaRegionLocations(org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMetaRegionLocationsResponse resp)
Simple helper to transform the result of getMetaRegionLocations() rpc.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<RegionLocations> |
RegionServerRegistry.getMetaRegionLocations() |
CompletableFuture<RegionLocations> |
AbstractRpcBasedConnectionRegistry.getMetaRegionLocations() |
CompletableFuture<RegionLocations> |
ZKConnectionRegistry.getMetaRegionLocations() |
CompletableFuture<RegionLocations> |
ConnectionRegistry.getMetaRegionLocations()
Get the location of meta region(s).
|
(package private) CompletableFuture<RegionLocations> |
AsyncMetaRegionLocator.getRegionLocations(int replicaId,
boolean reload)
Get the region locations for meta region.
|
(package private) CompletableFuture<RegionLocations> |
AsyncNonMetaRegionLocator.getRegionLocations(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
boolean reload) |
(package private) CompletableFuture<RegionLocations> |
AsyncRegionLocator.getRegionLocations(TableName tableName,
byte[] row,
RegionLocateType type,
boolean reload,
long timeoutNs) |
private CompletableFuture<RegionLocations> |
AsyncNonMetaRegionLocator.getRegionLocationsInternal(TableName tableName,
byte[] row,
int replicaId,
RegionLocateType locateType,
boolean reload) |
private ConcurrentNavigableMap<byte[],RegionLocations> |
MetaCache.getTableLocations(TableName tableName)
n * @return Map of cached locations for passed
tableName |
private List<RegionLocations> |
HRegionLocator.listRegionLocations() |
Modifier and Type | Method and Description |
---|---|
private void |
RpcRetryingCallerWithReadReplicas.addCallsForReplica(ResultBoundedCompletionService<Result> cs,
RegionLocations rl,
int min,
int max)
Creates the calls and submit them
|
private RegionLocations |
AsyncNonMetaRegionLocator.addToCache(AsyncNonMetaRegionLocator.TableCache tableCache,
RegionLocations locs) |
private void |
MetaCache.addToCachedServers(RegionLocations locations) |
void |
ClusterConnection.cacheLocation(TableName tableName,
RegionLocations location) |
void |
MetaCache.cacheLocation(TableName tableName,
RegionLocations locations)
Put a newly discovered HRegionLocation into the cache.
|
void |
ConnectionImplementation.cacheLocation(TableName tableName,
RegionLocations location)
Put a newly discovered HRegionLocation into the cache.
|
List<AsyncNonMetaRegionLocator.RegionLocationsFutureResult> |
AsyncNonMetaRegionLocator.TableCache.clearCompletedRequests(RegionLocations locations) |
private void |
AsyncNonMetaRegionLocator.complete(TableName tableName,
AsyncNonMetaRegionLocator.LocateRequest req,
RegionLocations locs,
Throwable error) |
protected HRegionLocation |
ScannerCallable.getLocationForReplica(RegionLocations locs) |
(package private) static List<String> |
AsyncRegionLocator.getRegionNames(RegionLocations locs) |
private boolean |
AsyncNonMetaRegionLocator.isEqual(RegionLocations locs1,
RegionLocations locs2) |
(package private) static boolean |
AsyncRegionLocatorHelper.isGood(RegionLocations locs,
int replicaId) |
(package private) static RegionLocations |
AsyncRegionLocatorHelper.removeRegionLocation(RegionLocations oldLocs,
int replicaId)
Create a new
RegionLocations based on the given oldLocs , and remove the
location for the given replicaId . |
(package private) static RegionLocations |
AsyncRegionLocatorHelper.replaceRegionLocation(RegionLocations oldLocs,
HRegionLocation loc)
Create a new
RegionLocations based on the given oldLocs , and replace the
location for the given replicaId with the given loc . |
private static <T> void |
ConnectionUtils.sendRequestsToSecondaryReplicas(Function<Integer,CompletableFuture<T>> requestReplica,
RegionLocations locs,
CompletableFuture<T> future,
Optional<MetricsConnection> metrics) |
private boolean |
AsyncNonMetaRegionLocator.TableCache.tryComplete(AsyncNonMetaRegionLocator.LocateRequest req,
CompletableFuture<RegionLocations> future,
RegionLocations locations,
List<AsyncNonMetaRegionLocator.RegionLocationsFutureResult> futureResultList) |
Modifier and Type | Method and Description |
---|---|
private void |
ZKConnectionRegistry.getMetaRegionLocation(CompletableFuture<RegionLocations> future,
List<String> metaReplicaZNodes) |
private boolean |
AsyncNonMetaRegionLocator.TableCache.tryComplete(AsyncNonMetaRegionLocator.LocateRequest req,
CompletableFuture<RegionLocations> future,
RegionLocations locations,
List<AsyncNonMetaRegionLocator.RegionLocationsFutureResult> futureResultList) |
private static void |
ZKConnectionRegistry.tryComplete(org.apache.commons.lang3.mutable.MutableInt remaining,
Collection<HRegionLocation> locs,
CompletableFuture<RegionLocations> future) |
Constructor and Description |
---|
RegionLocationsFutureResult(CompletableFuture<RegionLocations> future,
RegionLocations result,
Throwable e) |
Constructor and Description |
---|
RegionLocationsFutureResult(CompletableFuture<RegionLocations> future,
RegionLocations result,
Throwable e) |
Modifier and Type | Method and Description |
---|---|
private void |
ReportMakingVisitor.checkServer(RegionLocations locations)
Run through referenced servers and save off unknown and the dead.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.