|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of HRegionInfo in org.apache.hadoop.hbase |
---|
Fields in org.apache.hadoop.hbase declared as HRegionInfo | |
---|---|
static HRegionInfo |
HRegionInfo.FIRST_META_REGIONINFO
HRegionInfo for first meta region |
static HRegionInfo |
HRegionInfo.ROOT_REGIONINFO
HRegionInfo for root region |
Methods in org.apache.hadoop.hbase that return HRegionInfo | |
---|---|
static HRegionInfo |
HRegionInfo.convert(HBaseProtos.RegionInfo proto)
Convert a RegionInfo to a HRegionInfo |
static HRegionInfo |
HRegionInfo.getHRegionInfo(Result data)
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result. |
static HRegionInfo |
HRegionInfo.getHRegionInfo(Result r,
byte[] qualifier)
Returns the HRegionInfo object from the column HConstants.CATALOG_FAMILY and
qualifier of the catalog table result. |
HRegionInfo |
HRegionLocation.getRegionInfo()
|
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes)
|
static HRegionInfo |
HRegionInfo.parseFrom(DataInputStream in)
Parses an HRegionInfo instance from the passed in stream. |
static HRegionInfo |
HRegionInfo.parseFromOrNull(byte[] bytes)
|
Methods in org.apache.hadoop.hbase that return types with arguments of type HRegionInfo | |
---|---|
static PairOfSameType<HRegionInfo> |
HRegionInfo.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table Result. |
static Pair<HRegionInfo,ServerName> |
HRegionInfo.getHRegionInfoAndServerName(Result r)
Extract a HRegionInfo and ServerName from catalog table Result . |
static List<HRegionInfo> |
HRegionInfo.parseDelimitedFrom(byte[] bytes,
int offset,
int length)
Parses all the HRegionInfo instances from the passed in stream until EOF. |
Methods in org.apache.hadoop.hbase with parameters of type HRegionInfo | |
---|---|
static boolean |
HRegionInfo.areAdjacent(HRegionInfo regionA,
HRegionInfo regionB)
Check whether two regions are adjacent |
int |
HRegionInfo.compareTo(HRegionInfo o)
|
static HBaseProtos.RegionInfo |
HRegionInfo.convert(HRegionInfo info)
Convert a HRegionInfo to a RegionInfo |
static byte[] |
HRegionInfo.toDelimitedByteArray(HRegionInfo... infos)
Serializes given HRegionInfo's as a byte array. |
Constructors in org.apache.hadoop.hbase with parameters of type HRegionInfo | |
---|---|
HRegionInfo(HRegionInfo other)
Costruct a copy of another HRegionInfo |
|
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName)
|
|
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName,
long seqNum)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.backup |
---|
Methods in org.apache.hadoop.hbase.backup with parameters of type HRegionInfo | |
---|---|
static void |
HFileArchiver.archiveFamily(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo parent,
org.apache.hadoop.fs.Path tableDir,
byte[] family)
Remove from the specified region the store files of the specified column family, either by archiving them or outright deletion |
static void |
HFileArchiver.archiveRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
HRegionInfo info)
Cleans up all the files for a HRegion by archiving the HFiles to the archive directory |
static void |
HFileArchiver.archiveStoreFile(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
HRegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
org.apache.hadoop.fs.Path storeFile)
Archive the store file |
static void |
HFileArchiver.archiveStoreFiles(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
HRegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
Collection<StoreFile> compactedFiles)
Remove the store files, either by archiving them or outright deletion |
Uses of HRegionInfo in org.apache.hadoop.hbase.catalog |
---|
Methods in org.apache.hadoop.hbase.catalog that return types with arguments of type HRegionInfo | |
---|---|
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<String> disabledTables)
Performs a full scan of .META. , skipping regions from any
tables in the specified set of disabled tables. |
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<String> disabledTables,
boolean excludeOfflinedSplitParents)
Performs a full scan of .META. , skipping regions from any
tables in the specified set of disabled tables. |
static Pair<HRegionInfo,ServerName> |
MetaReader.getRegion(CatalogTracker catalogTracker,
byte[] regionName)
Gets the region info and assignment for the specified region. |
static Pair<HRegionInfo,HRegionInfo> |
MetaReader.getRegionsFromMergeQualifier(CatalogTracker catalogTracker,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region |
static Pair<HRegionInfo,HRegionInfo> |
MetaReader.getRegionsFromMergeQualifier(CatalogTracker catalogTracker,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region |
static NavigableMap<HRegionInfo,Result> |
MetaReader.getServerUserRegions(CatalogTracker catalogTracker,
ServerName serverName)
|
static List<HRegionInfo> |
MetaReader.getTableRegions(CatalogTracker catalogTracker,
byte[] tableName)
Gets all of the regions of the specified table. |
static List<HRegionInfo> |
MetaReader.getTableRegions(CatalogTracker catalogTracker,
byte[] tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table. |
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
byte[] tableName,
boolean excludeOfflinedSplitParents)
|
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
String tableName)
|
Methods in org.apache.hadoop.hbase.catalog with parameters of type HRegionInfo | |
---|---|
static void |
MetaEditor.addDaughter(CatalogTracker catalogTracker,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum)
Adds a daughter region entry to meta. |
static Put |
MetaEditor.addDaughtersToPut(Put put,
HRegionInfo splitA,
HRegionInfo splitB)
Adds split daughters to the Put |
static void |
MetaEditor.addRegionToMeta(CatalogTracker catalogTracker,
HRegionInfo regionInfo)
Adds a META row for the specified new region. |
static void |
MetaEditor.addRegionToMeta(HTable meta,
HRegionInfo regionInfo)
Adds a META row for the specified new region to the given catalog table. |
static void |
MetaEditor.addRegionToMeta(HTable meta,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) META row for the specified new region and its daughters. |
static void |
MetaEditor.deleteDaughtersReferencesInParent(CatalogTracker catalogTracker,
HRegionInfo parent)
Deletes daughters references in offlined split parent. |
static void |
MetaEditor.deleteMergeQualifiers(CatalogTracker catalogTracker,
HRegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region. |
static void |
MetaEditor.deleteRegion(CatalogTracker catalogTracker,
HRegionInfo regionInfo)
Deletes the specified region from META. |
static Delete |
MetaEditor.makeDeleteFromRegionInfo(HRegionInfo regionInfo)
Generates and returns a Delete containing the region info for the catalog table |
static Put |
MetaEditor.makePutFromRegionInfo(HRegionInfo regionInfo)
Generates and returns a Put containing the region into for the catalog table |
static void |
MetaEditor.mergeRegions(CatalogTracker catalogTracker,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName sn)
Merge the two regions into one in an atomic operation. |
static void |
MetaEditor.splitRegion(CatalogTracker catalogTracker,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo splitB,
ServerName sn)
Splits the region into two in an atomic operation. |
static void |
MetaEditor.updateMetaLocation(CatalogTracker catalogTracker,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum)
Updates the location of the specified META region in ROOT to be the specified server hostname and startcode. |
static void |
MetaEditor.updateRegionLocation(CatalogTracker catalogTracker,
HRegionInfo regionInfo,
ServerName sn,
long updateSeqNum)
Updates the location of the specified region in META to be the specified server hostname and startcode. |
Method parameters in org.apache.hadoop.hbase.catalog with type arguments of type HRegionInfo | |
---|---|
static void |
MetaEditor.addRegionsToMeta(CatalogTracker catalogTracker,
List<HRegionInfo> regionInfos)
Adds a META row for each of the specified new regions. |
static void |
MetaEditor.deleteRegions(CatalogTracker catalogTracker,
List<HRegionInfo> regionsInfo)
Deletes the specified regions from META. |
static void |
MetaEditor.mutateRegions(CatalogTracker catalogTracker,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from .META. |
static void |
MetaEditor.mutateRegions(CatalogTracker catalogTracker,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from .META. |
Uses of HRegionInfo in org.apache.hadoop.hbase.client |
---|
Methods in org.apache.hadoop.hbase.client that return HRegionInfo | |
---|---|
HRegionInfo |
ScannerCallable.getHRegionInfo()
|
static HRegionInfo |
MetaScanner.getHRegionInfo(Result data)
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result. |
Methods in org.apache.hadoop.hbase.client that return types with arguments of type HRegionInfo | |
---|---|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf,
byte[] tablename,
boolean offlined)
Lists all of the table regions currently in META. |
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server. |
NavigableMap<HRegionInfo,ServerName> |
HTable.getRegionLocations()
Gets all the regions and their address for this table. |
List<HRegionInfo> |
HBaseAdmin.getTableRegions(byte[] tableName)
get the regions of a given table. |
static List<HRegionInfo> |
MetaScanner.listAllRegions(org.apache.hadoop.conf.Configuration conf)
Lists all of the regions currently in META. |
static List<HRegionInfo> |
MetaScanner.listAllRegions(org.apache.hadoop.conf.Configuration conf,
boolean offlined)
Lists all of the regions currently in META. |
Methods in org.apache.hadoop.hbase.client with parameters of type HRegionInfo | |
---|---|
void |
HBaseAdmin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region. |
Uses of HRegionInfo in org.apache.hadoop.hbase.coprocessor |
---|
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type HRegionInfo | |
---|---|
void |
MasterObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called after the region assignment has been requested. |
void |
BaseMasterObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
|
void |
MasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called after the createTable operation has been requested. |
void |
BaseMasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
|
void |
MasterObserver.postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called after the createTable operation has been requested. |
void |
BaseMasterObserver.postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
|
void |
MasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
Called after the region move has been requested. |
void |
BaseMasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
void |
MasterObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called after the region has been marked offline. |
void |
BaseMasterObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
|
void |
MasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
Called after the region unassignment has been requested. |
void |
BaseMasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
|
void |
RegionObserver.postWALRestore(ObserverContext<RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
Called after a WALEdit
replayed for this region. |
void |
BaseRegionObserver.postWALRestore(ObserverContext<RegionCoprocessorEnvironment> env,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
WALObserver.postWALWrite(ObserverContext<WALCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
Called after a WALEdit
is writen to WAL. |
void |
MasterObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called prior to assigning a specific region. |
void |
BaseMasterObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
|
void |
MasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called before a new table is created by HMaster . |
void |
BaseMasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
|
void |
MasterObserver.preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called before a new table is created by HMaster . |
void |
BaseMasterObserver.preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
|
void |
MasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
Called prior to moving a given region from one region server to another. |
void |
BaseMasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
void |
MasterObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called prior to marking a given region as offline. |
void |
BaseMasterObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
|
void |
MasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
Called prior to unassigning a given region. |
void |
BaseMasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
|
void |
RegionObserver.preWALRestore(ObserverContext<RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
Called before a WALEdit
replayed for this region. |
void |
BaseRegionObserver.preWALRestore(ObserverContext<RegionCoprocessorEnvironment> env,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
boolean |
WALObserver.preWALWrite(ObserverContext<WALCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
Called before a WALEdit
is writen to WAL. |
Uses of HRegionInfo in org.apache.hadoop.hbase.io |
---|
Methods in org.apache.hadoop.hbase.io with parameters of type HRegionInfo | |
---|---|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
HRegionInfo hfileRegionInfo,
String hfileName)
Create a new HFileLink |
static String |
HFileLink.createHFileLinkName(HRegionInfo hfileRegionInfo,
String hfileName)
Create a new HFileLink name |
Uses of HRegionInfo in org.apache.hadoop.hbase.master |
---|
Methods in org.apache.hadoop.hbase.master that return HRegionInfo | |
---|---|
HRegionInfo |
RegionState.getRegion()
|
HRegionInfo |
RegionPlan.getRegionInfo()
|
protected HRegionInfo |
RegionStates.getRegionInfo(byte[] regionName)
Get the HRegionInfo from cache, if not there, from the META table |
Methods in org.apache.hadoop.hbase.master that return types with arguments of type HRegionInfo | |
---|---|
protected Map<String,Map<ServerName,List<HRegionInfo>>> |
RegionStates.getAssignmentsByTable()
This is an EXPENSIVE clone. |
Map<HRegionInfo,ServerName> |
RegionStates.getRegionAssignments()
|
List<HRegionInfo> |
RegionStates.getRegionsOfTable(byte[] tableName)
Gets the online regions of the specified table. |
Map<HRegionInfo,ServerName> |
LoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Sync assign a region |
List<HRegionInfo> |
AssignmentManager.processServerShutdown(ServerName sn)
Process shutdown server removing any assignments. |
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server |
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions. |
List<HRegionInfo> |
RegionStates.serverOffline(ServerName sn)
A server is offline, all regions on it are dead. |
Methods in org.apache.hadoop.hbase.master with parameters of type HRegionInfo | |
---|---|
void |
AssignmentManager.assign(HRegionInfo region,
boolean setOfflineInZK)
Assigns the specified region. |
void |
AssignmentManager.assign(HRegionInfo region,
boolean setOfflineInZK,
boolean forceNewPlan)
Use care with forceNewPlan. |
void |
HMaster.assignRegion(HRegionInfo hri)
|
boolean |
CatalogJanitor.cleanMergeQualifier(HRegionInfo region)
Checks if the specified region has merge qualifiers, if so, try to clean them |
RegionState |
RegionStates.createRegionState(HRegionInfo hri)
Add a region to RegionStates. |
void |
AssignmentManager.deleteClosingOrClosedNode(HRegionInfo region)
|
void |
MasterFileSystem.deleteFamilyFromFS(HRegionInfo region,
byte[] familyName)
|
void |
MasterFileSystem.deleteRegion(HRegionInfo region)
|
void |
MasterServices.dispatchMergingRegions(HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
Merge two regions. |
void |
HMaster.dispatchMergingRegions(HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
|
RegionPlan |
AssignmentManager.getRegionReopenPlan(HRegionInfo hri)
|
ServerName |
RegionStates.getRegionServerOfRegion(HRegionInfo hri)
|
protected RegionState |
RegionStates.getRegionState(HRegionInfo hri)
|
RegionState |
RegionStates.getRegionTransitionState(HRegionInfo hri)
Get region transition state |
void |
AssignmentManager.handleRegionsMergeReport(ServerName sn,
HRegionInfo merged,
HRegionInfo a,
HRegionInfo b)
Update inmemory structures. |
void |
AssignmentManager.handleSplitReport(ServerName sn,
HRegionInfo parent,
HRegionInfo a,
HRegionInfo b)
Update inmemory structures. |
boolean |
RegionStates.isRegionAssigned(HRegionInfo hri)
|
boolean |
RegionStates.isRegionFailedToClose(HRegionInfo hri)
|
boolean |
RegionStates.isRegionFailedToOpen(HRegionInfo hri)
|
boolean |
RegionStates.isRegionInTransition(HRegionInfo hri)
|
void |
AssignmentManager.offlineDisabledRegion(HRegionInfo regionInfo)
|
void |
MasterCoprocessorHost.postCreateTable(HTableDescriptor htd,
HRegionInfo[] regions)
|
void |
MasterCoprocessorHost.postCreateTableHandler(HTableDescriptor htd,
HRegionInfo[] regions)
|
void |
MasterCoprocessorHost.postMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
void |
MasterCoprocessorHost.preCreateTable(HTableDescriptor htd,
HRegionInfo[] regions)
|
void |
MasterCoprocessorHost.preCreateTableHandler(HTableDescriptor htd,
HRegionInfo[] regions)
|
boolean |
MasterCoprocessorHost.preMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
ServerName |
LoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list |
void |
RegionStates.regionOffline(HRegionInfo hri)
A region is offline, won't be in transition any more. |
void |
AssignmentManager.regionOffline(HRegionInfo regionInfo)
Marks the region as offline. |
void |
RegionStates.regionOnline(HRegionInfo hri,
ServerName serverName)
A region is online, won't be in transition any more. |
void |
AssignmentManager.removeClosedRegion(HRegionInfo hri)
When a region is closed, it should be removed from the regionsToReopen |
boolean |
ServerManager.sendRegionClose(ServerName server,
HRegionInfo region,
int versionOfClosingNode)
|
boolean |
ServerManager.sendRegionClose(ServerName server,
HRegionInfo region,
int versionOfClosingNode,
ServerName dest,
boolean transitionInZK)
Sends an CLOSE RPC to the specified server to close the specified region. |
RegionOpeningState |
ServerManager.sendRegionOpen(ServerName server,
HRegionInfo region,
int versionOfOfflineNode)
Sends an OPEN RPC to the specified server to open the specified region. |
void |
ServerManager.sendRegionsMerge(ServerName server,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
Sends an MERGE REGIONS RPC to the specified server to merge the specified regions. |
void |
AssignmentManager.unassign(HRegionInfo region)
Unassigns the specified region. |
void |
AssignmentManager.unassign(HRegionInfo region,
boolean force)
|
void |
AssignmentManager.unassign(HRegionInfo region,
boolean force,
ServerName dest)
Unassigns the specified region. |
void |
MasterFileSystem.updateRegionInfo(HRegionInfo region)
|
RegionState |
RegionStates.updateRegionState(HRegionInfo hri,
RegionState.State state)
Update a region state. |
RegionState |
RegionStates.updateRegionState(HRegionInfo hri,
RegionState.State state,
ServerName serverName)
Update a region state. |
void |
RegionStates.waitForAssignment(HRegionInfo hri)
Waits until the specified region has completed assignment. |
boolean |
AssignmentManager.waitForAssignment(HRegionInfo regionInfo)
Waits until the specified region has completed assignment. |
void |
RegionStates.waitOnRegionToClearRegionsInTransition(HRegionInfo hri)
Wait on region to clear regions-in-transition. |
void |
AssignmentManager.waitOnRegionToClearRegionsInTransition(HRegionInfo hri)
Wait on region to clear regions-in-transition. |
Method parameters in org.apache.hadoop.hbase.master with type arguments of type HRegionInfo | |
---|---|
void |
AssignmentManager.assign(List<HRegionInfo> regions)
Assigns specified regions round robin, if any. |
void |
AssignmentManager.assign(Map<HRegionInfo,ServerName> regions)
Assigns specified regions retaining assignments, if any. |
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Perform the major balance operation |
void |
RegionStates.createRegionStates(List<HRegionInfo> hris)
Add a list of regions to RegionStates. |
Map<HRegionInfo,ServerName> |
LoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Sync assign a region |
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server |
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions. |
List<RegionOpeningState> |
ServerManager.sendRegionOpen(ServerName server,
List<Pair<HRegionInfo,Integer>> regionOpenInfos)
Sends an OPEN RPC to the specified server to open the specified region. |
void |
AssignmentManager.setRegionsToReopen(List<HRegionInfo> regions)
Set the list of regions that will be reopened because of an update in table schema |
void |
AssignmentManager.unassign(List<HRegionInfo> regions)
Unassign the list of regions. |
Constructors in org.apache.hadoop.hbase.master with parameters of type HRegionInfo | |
---|---|
AssignCallable(AssignmentManager assignmentManager,
HRegionInfo hri)
|
|
RegionPlan(HRegionInfo hri,
ServerName source,
ServerName dest)
Instantiate a plan for a region move, moving the specified region from the specified source server to the specified destination server. |
|
RegionState(HRegionInfo region,
RegionState.State state)
|
|
RegionState(HRegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName)
|
|
UnAssignCallable(AssignmentManager assignmentManager,
HRegionInfo hri)
|
Constructor parameters in org.apache.hadoop.hbase.master with type arguments of type HRegionInfo | |
---|---|
BulkReOpen(Server server,
Map<ServerName,List<HRegionInfo>> serverToRegions,
AssignmentManager am)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.master.balancer |
---|
Methods in org.apache.hadoop.hbase.master.balancer that return types with arguments of type HRegionInfo | |
---|---|
Map<HRegionInfo,ServerName> |
BaseLoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates an immediate assignment plan to be used by a new master for regions in transition that do not have an already known destination. |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing assignment information from META, but adjusting for the specified list of available/online servers available for assignment. |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment. |
Methods in org.apache.hadoop.hbase.master.balancer with parameters of type HRegionInfo | |
---|---|
ServerName |
BaseLoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server. |
Method parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type HRegionInfo | |
---|---|
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Given the cluster state this will try and approach an optimal balance. |
List<RegionPlan> |
DefaultLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterMap)
Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server. |
protected double |
StochasticLoadBalancer.computeCost(Map<HRegionInfo,ServerName> initialRegionMapping,
Map<ServerName,List<HRegionInfo>> clusterState)
This is the main cost function. |
protected double |
StochasticLoadBalancer.computeCost(Map<HRegionInfo,ServerName> initialRegionMapping,
Map<ServerName,List<HRegionInfo>> clusterState)
This is the main cost function. |
Map<HRegionInfo,ServerName> |
BaseLoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates an immediate assignment plan to be used by a new master for regions in transition that do not have an already known destination. |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing assignment information from META, but adjusting for the specified list of available/online servers available for assignment. |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment. |
Constructor parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type HRegionInfo | |
---|---|
ClusterLoadState(Map<ServerName,List<HRegionInfo>> clusterState)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.master.handler |
---|
Methods in org.apache.hadoop.hbase.master.handler that return HRegionInfo | |
---|---|
HRegionInfo |
TotesHRegionInfo.getHRegionInfo()
|
HRegionInfo |
SplitRegionHandler.getHRegionInfo()
|
HRegionInfo |
OpenedRegionHandler.getHRegionInfo()
|
HRegionInfo |
MergedRegionHandler.getHRegionInfo()
|
HRegionInfo |
ClosedRegionHandler.getHRegionInfo()
|
Methods in org.apache.hadoop.hbase.master.handler that return types with arguments of type HRegionInfo | |
---|---|
protected List<HRegionInfo> |
CreateTableHandler.handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
String tableName)
Create the on-disk structure for the table, and returns the regions info. |
Methods in org.apache.hadoop.hbase.master.handler with parameters of type HRegionInfo | |
---|---|
static boolean |
ServerShutdownHandler.processDeadRegion(HRegionInfo hri,
Result result,
AssignmentManager assignmentManager,
CatalogTracker catalogTracker)
Process a dead region from a dead RS. |
Method parameters in org.apache.hadoop.hbase.master.handler with type arguments of type HRegionInfo | |
---|---|
protected void |
TableModifyFamilyHandler.handleTableOperation(List<HRegionInfo> regions)
|
protected abstract void |
TableEventHandler.handleTableOperation(List<HRegionInfo> regions)
|
protected void |
TableDeleteFamilyHandler.handleTableOperation(List<HRegionInfo> hris)
|
protected void |
TableAddFamilyHandler.handleTableOperation(List<HRegionInfo> hris)
|
protected void |
ModifyTableHandler.handleTableOperation(List<HRegionInfo> hris)
|
protected void |
DeleteTableHandler.handleTableOperation(List<HRegionInfo> regions)
|
boolean |
TableEventHandler.reOpenAllRegions(List<HRegionInfo> regions)
|
Constructors in org.apache.hadoop.hbase.master.handler with parameters of type HRegionInfo | |
---|---|
ClosedRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo)
|
|
CreateTableHandler(Server server,
MasterFileSystem fileSystemManager,
HTableDescriptor hTableDescriptor,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo[] newRegions,
MasterServices masterServices)
|
|
DispatchMergingRegionHandler(MasterServices services,
CatalogJanitor catalogJanitor,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
|
|
OpenedRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo,
ServerName sn,
int expectedVersion)
|
|
SplitRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo,
ServerName sn,
List<HRegionInfo> daughters)
|
Constructor parameters in org.apache.hadoop.hbase.master.handler with type arguments of type HRegionInfo | |
---|---|
MergedRegionHandler(Server server,
AssignmentManager assignmentManager,
ServerName sn,
List<HRegionInfo> mergeRegions)
|
|
SplitRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo,
ServerName sn,
List<HRegionInfo> daughters)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.master.snapshot |
---|
Methods in org.apache.hadoop.hbase.master.snapshot that return types with arguments of type HRegionInfo | |
---|---|
protected List<HRegionInfo> |
CloneSnapshotHandler.handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
String tableName)
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler. |
Method parameters in org.apache.hadoop.hbase.master.snapshot with type arguments of type HRegionInfo | |
---|---|
protected void |
RestoreSnapshotHandler.handleTableOperation(List<HRegionInfo> hris)
The restore table is executed in place. |
protected abstract void |
TakeSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
Snapshot the specified regions |
protected void |
EnabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
This method kicks off a snapshot procedure. |
void |
DisabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regionsAndLocations)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.protobuf |
---|
Methods in org.apache.hadoop.hbase.protobuf that return HRegionInfo | |
---|---|
static HRegionInfo |
ProtobufUtil.getRegionInfo(AdminProtocol admin,
byte[] regionName)
A helper to retrieve region info given a region name using admin protocol. |
Methods in org.apache.hadoop.hbase.protobuf that return types with arguments of type HRegionInfo | |
---|---|
static List<HRegionInfo> |
ProtobufUtil.getOnlineRegions(AdminProtocol admin)
A helper to get the all the online regions on a region server using admin protocol. |
static List<HRegionInfo> |
ResponseConverter.getRegionInfos(AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse |
Methods in org.apache.hadoop.hbase.protobuf with parameters of type HRegionInfo | |
---|---|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(HRegionInfo region,
int versionOfOfflineNode)
Create a protocol buffer OpenRegionRequest for a given region |
static void |
ProtobufUtil.mergeRegions(AdminProtocol admin,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
A helper to merge regions using admin protocol. |
static void |
ProtobufUtil.openRegion(AdminProtocol admin,
HRegionInfo region)
A helper to open a region using admin protocol. |
static void |
ProtobufUtil.split(AdminProtocol admin,
HRegionInfo hri,
byte[] splitPoint)
A helper to split a region using admin protocol. |
Method parameters in org.apache.hadoop.hbase.protobuf with type arguments of type HRegionInfo | |
---|---|
static AdminProtos.GetOnlineRegionResponse |
ResponseConverter.buildGetOnlineRegionResponse(List<HRegionInfo> regions)
A utility to build a GetOnlineRegionResponse. |
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(List<Pair<HRegionInfo,Integer>> regionOpenInfos)
Create a protocol buffer OpenRegionRequest to open a list of regions |
Uses of HRegionInfo in org.apache.hadoop.hbase.regionserver |
---|
Methods in org.apache.hadoop.hbase.regionserver that return HRegionInfo | |
---|---|
static HRegionInfo |
RegionMergeTransaction.getMergedRegionInfo(HRegionInfo a,
HRegionInfo b)
Get merged region info through the specified two regions |
protected HRegionInfo[] |
HRegionServer.getMostLoadedRegions()
Get the top N most loaded regions this server is serving so we can tell the master which regions it can reallocate if we're overloaded. |
HRegionInfo |
Store.getRegionInfo()
|
HRegionInfo |
RegionScanner.getRegionInfo()
|
HRegionInfo |
HStore.getRegionInfo()
|
HRegionInfo |
HRegionFileSystem.getRegionInfo()
|
HRegionInfo |
HRegion.getRegionInfo()
|
static HRegionInfo |
HRegionFileSystem.loadRegionInfoFileContent(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path regionDir)
Create a HRegionInfo from the serialized version on-disk. |
Methods in org.apache.hadoop.hbase.regionserver with parameters of type HRegionInfo | |
---|---|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
HTableDescriptor tableDescriptor,
HRegionInfo regionInfo)
This is a helper function to compute HDFS block distribution on demand |
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor)
Convenience method creating new HRegions. |
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
HLog hlog)
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
HLog hlog,
boolean initialize)
Convenience method creating new HRegions. |
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
HLog hlog,
boolean initialize,
boolean ignoreHLog)
Convenience method creating new HRegions. |
static HRegionFileSystem |
HRegionFileSystem.createRegionOnFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo)
Create a new Region on file-system. |
static void |
HRegionFileSystem.deleteRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo)
Remove the region from the table directory, archiving the region's hfiles. |
static HRegionInfo |
RegionMergeTransaction.getMergedRegionInfo(HRegionInfo a,
HRegionInfo b)
Get merged region info through the specified two regions |
static org.apache.hadoop.fs.Path |
HRegion.getRegionDir(org.apache.hadoop.fs.Path rootdir,
HRegionInfo info)
Deprecated. |
static org.apache.hadoop.fs.Path |
HStore.getStoreHomedir(org.apache.hadoop.fs.Path tabledir,
HRegionInfo hri,
byte[] family)
Deprecated. |
HLog |
RegionServerServices.getWAL(HRegionInfo regionInfo)
|
HLog |
HRegionServer.getWAL(HRegionInfo regionInfo)
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
HLog wal)
Open a Region. |
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
HLog wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region. |
static HRegion |
HRegion.openHRegion(HRegionInfo info,
HTableDescriptor htd,
HLog wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region. |
static HRegion |
HRegion.openHRegion(HRegionInfo info,
HTableDescriptor htd,
HLog wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region. |
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
HLog wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region. |
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
HLog wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region. |
static HRegionFileSystem |
HRegionFileSystem.openRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo,
boolean readOnly)
Open Region from file-system. |
void |
RegionCoprocessorHost.postWALRestore(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
boolean |
RegionCoprocessorHost.preWALRestore(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
static boolean |
HRegion.rowIsInRange(HRegionInfo info,
byte[] row)
Determines if the specified row is within the row range specified by the specified HRegionInfo |
Constructors in org.apache.hadoop.hbase.regionserver with parameters of type HRegionInfo | |
---|---|
HRegion(org.apache.hadoop.fs.Path tableDir,
HLog log,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration confParam,
HRegionInfo regionInfo,
HTableDescriptor htd,
RegionServerServices rsServices)
Deprecated. |
Uses of HRegionInfo in org.apache.hadoop.hbase.regionserver.handler |
---|
Methods in org.apache.hadoop.hbase.regionserver.handler that return HRegionInfo | |
---|---|
HRegionInfo |
OpenRegionHandler.getRegionInfo()
|
HRegionInfo |
CloseRegionHandler.getRegionInfo()
|
Methods in org.apache.hadoop.hbase.regionserver.handler with parameters of type HRegionInfo | |
---|---|
static boolean |
OpenRegionHandler.tryTransitionFromOfflineToFailedOpen(RegionServerServices rsServices,
HRegionInfo hri,
int versionOfOfflineNode)
Try to transition to open. |
Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type HRegionInfo | |
---|---|
CloseMetaHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo)
|
|
CloseMetaHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
boolean abort,
boolean zk,
int versionOfClosingNode)
|
|
CloseRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo)
|
|
CloseRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
boolean abort,
boolean zk,
int versionOfClosingNode)
This method used internally by the RegionServer to close out regions. |
|
CloseRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
boolean abort,
boolean zk,
int versionOfClosingNode,
EventType eventType)
|
|
CloseRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
boolean abort,
boolean zk,
int versionOfClosingNode,
EventType eventType,
ServerName destination)
|
|
CloseRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
boolean abort,
boolean zk,
int versionOfClosingNode,
ServerName destination)
|
|
CloseRootHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo)
|
|
CloseRootHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
boolean abort,
boolean zk,
int versionOfClosingNode)
|
|
OpenMetaHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd)
|
|
OpenMetaHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd,
int versionOfOfflineNode)
|
|
OpenRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd)
|
|
OpenRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd,
EventType eventType,
int versionOfOfflineNode)
|
|
OpenRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd,
int versionOfOfflineNode)
|
|
OpenRootHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd)
|
|
OpenRootHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd,
int versionOfOfflineNode)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.regionserver.wal |
---|
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type HRegionInfo | |
---|---|
void |
HLog.append(HRegionInfo info,
byte[] tableName,
WALEdit edits,
long now,
HTableDescriptor htd)
Only used in tests. |
long |
HLog.append(HRegionInfo info,
byte[] tableName,
WALEdit edits,
UUID clusterId,
long now,
HTableDescriptor htd)
Append a set of edits to the log. |
long |
HLog.append(HRegionInfo regionInfo,
HLogKey logKey,
WALEdit logEdit,
HTableDescriptor htd,
boolean doSync)
Append an entry to the log. |
long |
HLog.appendNoSync(HRegionInfo info,
byte[] tableName,
WALEdit edits,
UUID clusterId,
long now,
HTableDescriptor htd)
Append a set of edits to the log. |
void |
WALCoprocessorHost.postWALWrite(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
boolean |
WALCoprocessorHost.preWALWrite(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
WALActionsListener.visitLogEntryBeforeWrite(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
Called before each write. |
Uses of HRegionInfo in org.apache.hadoop.hbase.replication.regionserver |
---|
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type HRegionInfo | |
---|---|
void |
Replication.visitLogEntryBeforeWrite(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.security.access |
---|
Uses of HRegionInfo in org.apache.hadoop.hbase.snapshot |
---|
Methods in org.apache.hadoop.hbase.snapshot that return HRegionInfo | |
---|---|
HRegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(HRegionInfo snapshotRegionInfo)
Create a new HRegionInfo from the snapshot region info. |
Methods in org.apache.hadoop.hbase.snapshot that return types with arguments of type HRegionInfo | |
---|---|
List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToAdd()
Returns the list of new regions added during the on-disk restore. |
List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRemove()
Returns the list of regions removed during the on-disk restore. |
List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRestore()
Returns the list of 'restored regions' during the on-disk restore. |
Methods in org.apache.hadoop.hbase.snapshot with parameters of type HRegionInfo | |
---|---|
HRegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(HRegionInfo snapshotRegionInfo)
Create a new HRegionInfo from the snapshot region info. |
static void |
TakeSnapshotUtils.verifyRecoveredEdits(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HRegionInfo regionInfo,
HBaseProtos.SnapshotDescription snapshot)
Verify one of a snapshot's region's recovered.edits, has been at the surface (file names, length), match the original directory. |
Uses of HRegionInfo in org.apache.hadoop.hbase.tmpl.regionserver |
---|
Methods in org.apache.hadoop.hbase.tmpl.regionserver that return types with arguments of type HRegionInfo | |
---|---|
List<HRegionInfo> |
RegionListTmpl.ImplData.getOnlineRegions()
|
Method parameters in org.apache.hadoop.hbase.tmpl.regionserver with type arguments of type HRegionInfo | |
---|---|
org.jamon.Renderer |
RegionListTmpl.makeRenderer(HRegionServer regionServer,
List<HRegionInfo> onlineRegions)
|
void |
RegionListTmpl.render(Writer jamonWriter,
HRegionServer regionServer,
List<HRegionInfo> onlineRegions)
|
void |
RegionListTmpl.renderNoFlush(Writer jamonWriter,
HRegionServer regionServer,
List<HRegionInfo> onlineRegions)
|
void |
RegionListTmpl.ImplData.setOnlineRegions(List<HRegionInfo> onlineRegions)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.tool |
---|
Methods in org.apache.hadoop.hbase.tool with parameters of type HRegionInfo | |
---|---|
void |
Canary.Sink.publishReadFailure(HRegionInfo region)
|
void |
Canary.StdOutSink.publishReadFailure(HRegionInfo region)
|
void |
Canary.Sink.publishReadFailure(HRegionInfo region,
HColumnDescriptor column)
|
void |
Canary.StdOutSink.publishReadFailure(HRegionInfo region,
HColumnDescriptor column)
|
void |
Canary.Sink.publishReadTiming(HRegionInfo region,
HColumnDescriptor column,
long msTime)
|
void |
Canary.StdOutSink.publishReadTiming(HRegionInfo region,
HColumnDescriptor column,
long msTime)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.util |
---|
Methods in org.apache.hadoop.hbase.util that return types with arguments of type HRegionInfo | |
---|---|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions)
Create new set of regions on the specified file-system. |
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system. |
Methods in org.apache.hadoop.hbase.util with parameters of type HRegionInfo | |
---|---|
void |
HBaseFsck.HbckInfo.addServer(HRegionInfo hri,
ServerName server)
|
static void |
HBaseFsckRepair.closeRegionSilentlyAndWait(HBaseAdmin admin,
ServerName server,
HRegionInfo region)
Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close the region. |
static HRegion |
HBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf,
HRegionInfo hri,
HTableDescriptor htd)
Creates, flushes, and closes a new region. |
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions)
Create new set of regions on the specified file-system. |
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system. |
static void |
HBaseFsckRepair.fixMetaHoleOnline(org.apache.hadoop.conf.Configuration conf,
HRegionInfo hri)
Puts the specified HRegionInfo into META. |
static void |
HBaseFsckRepair.fixMultiAssignment(HBaseAdmin admin,
HRegionInfo region,
List<ServerName> servers)
Fix multiple assignment by doing silent closes on each RS hosting the region and then force ZK unassigned node to OFFLINE to trigger assignment by master. |
static void |
HBaseFsckRepair.fixUnassigned(HBaseAdmin admin,
HRegionInfo region)
Fix unassigned by creating/transition the unassigned ZK node for this region to OFFLINE state with a special flag to tell the master that this is a forced operation by HBCK. |
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
HRegionInfo region,
org.apache.hadoop.fs.Path tabledir,
byte[] family)
Get the directory to archive a store directory |
static void |
HBaseFsckRepair.waitUntilAssigned(HBaseAdmin admin,
HRegionInfo region)
|
Method parameters in org.apache.hadoop.hbase.util with type arguments of type HRegionInfo | |
---|---|
static void |
ModifyRegionUtils.assignRegions(AssignmentManager assignmentManager,
List<HRegionInfo> regions)
Trigger immediate assignment of the regions in round-robin fashion |
Uses of HRegionInfo in org.apache.hadoop.hbase.zookeeper |
---|
Methods in org.apache.hadoop.hbase.zookeeper with parameters of type HRegionInfo | |
---|---|
static void |
ZKAssign.asyncCreateNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
org.apache.zookeeper.AsyncCallback.StringCallback cb,
Object ctx)
Creates an unassigned node in the OFFLINE state for the specified region. |
static boolean |
ZKAssign.checkClosingState(ZooKeeperWatcher zkw,
HRegionInfo region,
int expectedVersion)
|
static int |
ZKAssign.createNodeClosing(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates a new unassigned node in the CLOSING state for the specified region. |
static void |
ZKAssign.createNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates a new unassigned node in the OFFLINE state for the specified region. |
static void |
ZKAssign.createNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType event)
|
static int |
ZKAssign.createOrForceNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates or force updates an unassigned node to the OFFLINE state for the specified region. |
static boolean |
ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw,
HRegionInfo region)
Deletes an existing unassigned node that is in the CLOSING state for the specified region. |
static void |
ZKAssign.deleteNodeFailSilent(ZooKeeperWatcher watcher,
HRegionInfo regionInfo)
Delete the assignment node regardless of its current state. |
static int |
ZKAssign.getVersion(ZooKeeperWatcher zkw,
HRegionInfo region)
Get the version of the specified znode |
static int |
ZKAssign.retransitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Retransitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENING state. |
static int |
ZKAssign.transitionNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState,
EventType endState,
int expectedVersion)
Method that actually performs unassigned node transitions. |
static int |
ZKAssign.transitionNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState,
EventType endState,
int expectedVersion,
byte[] payload)
|
static int |
ZKAssign.transitionNodeClosed(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Transitions an existing unassigned node for the specified region which is currently in the CLOSING state to be in the CLOSED state. |
static int |
ZKAssign.transitionNodeOpened(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Transitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENED state. |
static int |
ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Transitions an existing unassigned node for the specified region which is currently in the OFFLINE state to be in the OPENING state. |
static int |
ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |