Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.thrift2 |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.wal |
Modifier and Type | Field and Description |
---|---|
private HRegionLocation[] |
RegionLocations.locations |
Modifier and Type | Method and Description |
---|---|
HRegionLocation |
RegionLocations.getDefaultRegionLocation() |
HRegionLocation |
RegionLocations.getRegionLocation()
Returns the first not-null region location in the list
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
byte[] regionName)
Returns the HRegionLocation from meta for the given region
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
HRegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
HRegionLocation |
RegionLocations.getRegionLocation(int replicaId) |
private static HRegionLocation |
MetaTableAccessor.getRegionLocation(Result r,
HRegionInfo regionInfo,
int replicaId)
Returns the HRegionLocation parsed from the given meta row Result
for the given regionInfo and replicaId.
|
HRegionLocation |
RegionLocations.getRegionLocationByRegionName(byte[] regionName)
Returns the region location from the list for matching regionName, which can
be regionName or encodedRegionName
|
HRegionLocation[] |
RegionLocations.getRegionLocations() |
private HRegionLocation |
RegionLocations.selectRegionLocation(HRegionLocation oldLocation,
HRegionLocation location,
boolean checkForEquals,
boolean force) |
Modifier and Type | Method and Description |
---|---|
int |
HRegionLocation.compareTo(HRegionLocation o) |
RegionLocations |
RegionLocations.remove(HRegionLocation location)
Removes the given location from the list
|
private HRegionLocation |
RegionLocations.selectRegionLocation(HRegionLocation oldLocation,
HRegionLocation location,
boolean checkForEquals,
boolean force) |
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.
|
Constructor and Description |
---|
RegionLocations(HRegionLocation... locations)
Constructs the region location list.
|
Constructor and Description |
---|
RegionLocations(Collection<HRegionLocation> locations) |
Modifier and Type | Field and Description |
---|---|
private HRegionLocation |
HTableMultiplexer.FlushWorker.addr |
protected HRegionLocation |
RegionServerCallable.location |
protected HRegionLocation |
RegionAdminServiceCallable.location |
Modifier and Type | Field and Description |
---|---|
private Map<HRegionLocation,HTableMultiplexer.FlushWorker> |
HTableMultiplexer.serverToFlushWorkerMap
The map between each region server to its flush worker
|
Modifier and Type | Method and Description |
---|---|
protected HRegionLocation |
RegionServerCallable.getLocation() |
protected HRegionLocation |
MultiServerCallable.getLocation() |
HRegionLocation |
RegionAdminServiceCallable.getLocation(boolean useCache) |
HRegionLocation |
HTable.getRegionLocation(byte[] row)
Deprecated.
Use
RegionLocator.getRegionLocation(byte[]) instead. |
HRegionLocation |
HRegionLocator.getRegionLocation(byte[] row)
Finds the region on which the given row is being served.
|
HRegionLocation |
RegionLocator.getRegionLocation(byte[] row)
Finds the region on which the given row is being served.
|
HRegionLocation |
HTable.getRegionLocation(byte[] row,
boolean reload)
Deprecated.
Use
RegionLocator.getRegionLocation(byte[], boolean) instead. |
HRegionLocation |
HRegionLocator.getRegionLocation(byte[] row,
boolean reload)
Finds the region on which the given row is being served.
|
HRegionLocation |
RegionLocator.getRegionLocation(byte[] row,
boolean reload)
Finds the region on which the given row is being served.
|
HRegionLocation |
ConnectionManager.HConnectionImplementation.getRegionLocation(byte[] tableName,
byte[] row,
boolean reload) |
HRegionLocation |
ConnectionAdapter.getRegionLocation(byte[] tableName,
byte[] row,
boolean reload)
Deprecated.
|
HRegionLocation |
HConnection.getRegionLocation(byte[] tableName,
byte[] row,
boolean reload)
Deprecated.
|
HRegionLocation |
HTable.getRegionLocation(String row)
Deprecated.
|
HRegionLocation |
ConnectionManager.HConnectionImplementation.getRegionLocation(TableName tableName,
byte[] row,
boolean reload) |
HRegionLocation |
ConnectionAdapter.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Deprecated.
|
HRegionLocation |
HConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Deprecated.
internal method, do not use thru HConnection
|
HRegionLocation |
ClusterConnection.getRegionLocation(TableName tableName,
byte[] row,
boolean reload)
Find region location hosting passed row
|
private HRegionLocation |
AsyncProcess.AsyncRequestFutureImpl.getReplicaLocationOrFail(Action<Row> action) |
HRegionLocation |
ConnectionManager.HConnectionImplementation.locateRegion(byte[] regionName) |
HRegionLocation |
ConnectionAdapter.locateRegion(byte[] regionName)
Deprecated.
|
HRegionLocation |
HConnection.locateRegion(byte[] regionName)
Deprecated.
internal method, do not use thru HConnection
|
HRegionLocation |
ClusterConnection.locateRegion(byte[] regionName)
Gets the location of the region of regionName.
|
HRegionLocation |
ConnectionManager.HConnectionImplementation.locateRegion(byte[] tableName,
byte[] row) |
HRegionLocation |
ConnectionAdapter.locateRegion(byte[] tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
HConnection.locateRegion(byte[] tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
ConnectionManager.HConnectionImplementation.locateRegion(TableName tableName,
byte[] row) |
HRegionLocation |
ConnectionAdapter.locateRegion(TableName tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
HConnection.locateRegion(TableName tableName,
byte[] row)
Deprecated.
internal method, do not use thru HConnection
|
HRegionLocation |
ClusterConnection.locateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in.
|
HRegionLocation |
ConnectionManager.HConnectionImplementation.relocateRegion(byte[] tableName,
byte[] row) |
HRegionLocation |
ConnectionAdapter.relocateRegion(byte[] tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
HConnection.relocateRegion(byte[] tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
ConnectionManager.HConnectionImplementation.relocateRegion(TableName tableName,
byte[] row) |
HRegionLocation |
ConnectionAdapter.relocateRegion(TableName tableName,
byte[] row)
Deprecated.
|
HRegionLocation |
HConnection.relocateRegion(TableName tableName,
byte[] row)
Deprecated.
internal method, do not use thru HConnection
|
HRegionLocation |
ClusterConnection.relocateRegion(TableName tableName,
byte[] row)
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
|
Modifier and Type | Method and Description |
---|---|
List<HRegionLocation> |
HTable.getAllRegionLocations()
Deprecated.
Use
RegionLocator.getAllRegionLocations() instead; |
List<HRegionLocation> |
HRegionLocator.getAllRegionLocations() |
List<HRegionLocation> |
RegionLocator.getAllRegionLocations()
Retrieves all of the regions associated with this table.
|
private Pair<List<byte[]>,List<HRegionLocation>> |
HTable.getKeysAndRegionsInRange(byte[] startKey,
byte[] endKey,
boolean includeEndKey)
Deprecated.
This is no longer a public API
|
private Pair<List<byte[]>,List<HRegionLocation>> |
HTable.getKeysAndRegionsInRange(byte[] startKey,
byte[] endKey,
boolean includeEndKey,
boolean reload)
Deprecated.
This is no longer a public API
|
List<HRegionLocation> |
HTable.getRegionsInRange(byte[] startKey,
byte[] endKey)
Deprecated.
This is no longer a public API
|
List<HRegionLocation> |
HTable.getRegionsInRange(byte[] startKey,
byte[] endKey,
boolean reload)
Deprecated.
This is no longer a public API
|
List<HRegionLocation> |
ConnectionManager.HConnectionImplementation.locateRegions(byte[] tableName) |
List<HRegionLocation> |
ConnectionAdapter.locateRegions(byte[] tableName)
Deprecated.
|
List<HRegionLocation> |
HConnection.locateRegions(byte[] tableName)
Deprecated.
|
List<HRegionLocation> |
ConnectionManager.HConnectionImplementation.locateRegions(byte[] tableName,
boolean useCache,
boolean offlined) |
List<HRegionLocation> |
ConnectionAdapter.locateRegions(byte[] tableName,
boolean useCache,
boolean offlined)
Deprecated.
|
List<HRegionLocation> |
HConnection.locateRegions(byte[] tableName,
boolean useCache,
boolean offlined)
Deprecated.
|
List<HRegionLocation> |
ConnectionManager.HConnectionImplementation.locateRegions(TableName tableName) |
List<HRegionLocation> |
ConnectionAdapter.locateRegions(TableName tableName)
Deprecated.
|
List<HRegionLocation> |
HConnection.locateRegions(TableName tableName)
Deprecated.
internal method, do not use thru HConnection
|
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName)
Gets the locations of all regions in the specified table, tableName.
|
List<HRegionLocation> |
ConnectionManager.HConnectionImplementation.locateRegions(TableName tableName,
boolean useCache,
boolean offlined) |
List<HRegionLocation> |
ConnectionAdapter.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Deprecated.
|
List<HRegionLocation> |
HConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Deprecated.
internal method, do not use thru HConnection
|
List<HRegionLocation> |
ClusterConnection.locateRegions(TableName tableName,
boolean useCache,
boolean offlined)
Gets the locations of all regions in the specified table, tableName.
|
private List<HRegionLocation> |
ReversedScannerCallable.locateRegionsInRange(byte[] startKey,
byte[] endKey,
boolean reload)
Get the corresponding regions for an arbitrary range of keys.
|
Modifier and Type | Method and Description |
---|---|
private void |
ConnectionManager.HConnectionImplementation.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
void |
MetaCache.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
protected boolean |
AsyncProcess.canTakeOperation(HRegionLocation loc,
Map<HRegionInfo,Boolean> regionsIncluded,
Map<ServerName,Boolean> serversIncluded)
Check if we should send new operations to this region or region server.
|
void |
MetaCache.clearCache(HRegionLocation location) |
void |
ConnectionManager.HConnectionImplementation.deleteCachedRegionLocation(HRegionLocation location) |
void |
ConnectionAdapter.deleteCachedRegionLocation(HRegionLocation location)
Deprecated.
|
void |
HConnection.deleteCachedRegionLocation(HRegionLocation location)
Deprecated.
internal method, do not use thru HConnection
|
void |
ClusterConnection.deleteCachedRegionLocation(HRegionLocation location)
Deletes cached locations for the specific region.
|
(package private) LinkedBlockingQueue<HTableMultiplexer.PutStatus> |
HTableMultiplexer.getQueue(HRegionLocation addr) |
(package private) boolean |
HTableMultiplexer.FlushWorker.resubmitFailedPut(HTableMultiplexer.PutStatus ps,
HRegionLocation oldLoc) |
protected void |
RegionServerCallable.setLocation(HRegionLocation location) |
void |
ConnectionManager.HConnectionImplementation.updateCachedLocations(byte[] tableName,
byte[] rowkey,
Object exception,
HRegionLocation source) |
void |
ConnectionAdapter.updateCachedLocations(byte[] tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Deprecated.
|
void |
HConnection.updateCachedLocations(byte[] tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Deprecated.
|
void |
ConnectionManager.HConnectionImplementation.updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source) |
void |
ConnectionAdapter.updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Deprecated.
|
void |
HConnection.updateCachedLocations(TableName tableName,
byte[] rowkey,
Object exception,
HRegionLocation source)
Deprecated.
|
static <T> T |
ResultStatsUtil.updateStats(T r,
ServerStatisticTracker stats,
HRegionLocation regionLocation) |
Modifier and Type | Method and Description |
---|---|
private void |
HTableMultiplexer.HTableMultiplexerStatus.initialize(Map<HRegionLocation,HTableMultiplexer.FlushWorker> serverToFlushWorkerMap) |
Constructor and Description |
---|
HTableMultiplexer.FlushWorker(org.apache.hadoop.conf.Configuration conf,
ClusterConnection conn,
HRegionLocation addr,
HTableMultiplexer htableMultiplexer,
int perRegionServerBufferQueueSize,
ExecutorService pool,
ScheduledExecutorService executor) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row) |
RegionAdminServiceCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionLocation location,
TableName tableName,
byte[] row,
int replicaId) |
RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable(int id,
HRegionLocation location) |
Constructor and Description |
---|
HTableMultiplexer.HTableMultiplexerStatus(Map<HRegionLocation,HTableMultiplexer.FlushWorker> serverToFlushWorkerMap) |
Modifier and Type | Method and Description |
---|---|
private void |
WALEditsReplaySink.replayEdits(HRegionLocation regionLoc,
HRegionInfo regionInfo,
List<WAL.Entry> entries) |
Modifier and Type | Method and Description |
---|---|
void |
WALEditsReplaySink.replayEntries(List<Pair<HRegionLocation,WAL.Entry>> entries)
Replay an array of actions of the same region directly into the newly assigned Region Server
|
Constructor and Description |
---|
WALEditsReplaySink.ReplayServerCallable(HConnection connection,
TableName tableName,
HRegionLocation regionLoc,
HRegionInfo regionInfo,
List<WAL.Entry> entries) |
Constructor and Description |
---|
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
HRegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.thrift2.generated.THRegionLocation |
ThriftUtilities.regionLocationFromHBase(HRegionLocation hrl) |
Modifier and Type | Method and Description |
---|---|
static List<org.apache.hadoop.hbase.thrift2.generated.THRegionLocation> |
ThriftUtilities.regionLocationsFromHBase(List<HRegionLocation> locations) |
Modifier and Type | Field and Description | ||||||||||||||
---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|
private Map<String,HRegionLocation> |
WALSplitter.LogReplayOutputSink.onlineRegions |
||||||||||||||
private Map<String,List<Pair<HRegionLocation,WAL.Entry>>> |
WALSplitter.LogReplayOutputSink.serverToBufferQueueMap
Map key -> value layout
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved. |