|
||||||||||
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 | |
---|---|
HRegionInfo |
HRegionLocation.getRegionInfo()
|
Methods in org.apache.hadoop.hbase with parameters of type HRegionInfo | |
---|---|
int |
HRegionInfo.compareTo(HRegionInfo o)
|
Constructors in org.apache.hadoop.hbase with parameters of type HRegionInfo | |
---|---|
HRegionInfo(HRegionInfo other)
Costruct a copy of another HRegionInfo |
|
HRegionLocation(HRegionInfo regionInfo,
String hostname,
int port)
Constructor |
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.fs.FileSystem fs,
HRegionInfo regionInfo,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
org.apache.hadoop.fs.Path storeFile)
Archive the store file |
Uses of HRegionInfo in org.apache.hadoop.hbase.catalog |
---|
Methods in org.apache.hadoop.hbase.catalog that return HRegionInfo | |
---|---|
static HRegionInfo |
MetaEditor.getHRegionInfo(Result data)
|
static HRegionInfo |
MetaReader.parseHRegionInfoFromCatalogResult(Result r,
byte[] qualifier)
Parse the content of the cell at HConstants.CATALOG_FAMILY and
qualifier as an HRegionInfo and return it, or null. |
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 PairOfSameType<HRegionInfo> |
MetaEditor.getDaughterRegions(Result data)
Returns the daughter regions by reading from the corresponding columns of the .META. |
static PairOfSameType<HRegionInfo> |
MetaReader.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table Result. |
static Pair<HRegionInfo,ServerName> |
MetaReader.getRegion(CatalogTracker catalogTracker,
byte[] regionName)
Gets the region info and assignment for the specified 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)
|
static Pair<HRegionInfo,ServerName> |
MetaReader.parseCatalogResult(Result r)
Extract a HRegionInfo and ServerName. |
Methods in org.apache.hadoop.hbase.catalog with parameters of type HRegionInfo | |
---|---|
static void |
MetaEditor.addDaughter(CatalogTracker catalogTracker,
HRegionInfo regionInfo,
ServerName sn)
|
static void |
MetaEditor.addRegionToMeta(CatalogTracker catalogTracker,
HRegionInfo regionInfo)
Adds a META row for the specified new region. |
static void |
MetaEditor.deleteDaughtersReferencesInParent(CatalogTracker catalogTracker,
HRegionInfo parent)
Deletes daughters references in offlined split parent. |
static void |
MetaEditor.deleteRegion(CatalogTracker catalogTracker,
HRegionInfo regionInfo)
Deletes the specified region from META. |
static void |
MetaEditor.offlineParentInMeta(CatalogTracker catalogTracker,
HRegionInfo parent,
HRegionInfo a,
HRegionInfo b)
Offline parent in meta. |
static void |
MetaEditor.updateMetaLocation(CatalogTracker catalogTracker,
HRegionInfo regionInfo,
ServerName sn)
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)
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()
|
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. |
Map<HRegionInfo,HServerAddress> |
HTable.deserializeRegionInfo(DataInput in)
Read from in and deserialize the regions information. |
NavigableMap<HRegionInfo,ServerName> |
HTable.getRegionLocations()
Gets all the regions and their address for this table. |
Map<HRegionInfo,HServerAddress> |
HTable.getRegionsInfo()
Deprecated. Use HTable.getRegionLocations() or HTable.getStartEndKeys() |
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. |
Method parameters in org.apache.hadoop.hbase.client with type arguments of type HRegionInfo | |
---|---|
void |
HConnection.prewarmRegionCache(byte[] tableName,
Map<HRegionInfo,HServerAddress> regions)
Load the region map and warm up the global region cache for the table. |
void |
HTable.prewarmRegionCache(Map<HRegionInfo,HServerAddress> regionMap)
Save the passed region information and the table's regions cache. |
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.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.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 |
BaseRegionObserver.postWALRestore(ObserverContext<RegionCoprocessorEnvironment> env,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
RegionObserver.postWALRestore(ObserverContext<RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
Called after a WALEdit
replayed for this region. |
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.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.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 |
BaseRegionObserver.preWALRestore(ObserverContext<RegionCoprocessorEnvironment> env,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
RegionObserver.preWALRestore(ObserverContext<RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
Called before a WALEdit
replayed for this region. |
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.ipc |
---|
Methods in org.apache.hadoop.hbase.ipc that return HRegionInfo | |
---|---|
HRegionInfo |
HRegionInterface.getRegionInfo(byte[] regionName)
Get metainfo about an HRegion |
Methods in org.apache.hadoop.hbase.ipc that return types with arguments of type HRegionInfo | |
---|---|
List<HRegionInfo> |
HRegionInterface.getOnlineRegions()
|
Methods in org.apache.hadoop.hbase.ipc with parameters of type HRegionInfo | |
---|---|
boolean |
HRegionInterface.closeRegion(HRegionInfo region)
Closes the specified region. |
boolean |
HRegionInterface.closeRegion(HRegionInfo region,
boolean zk)
Closes the specified region and will use or not use ZK during the close according to the specified flag. |
boolean |
HRegionInterface.closeRegion(HRegionInfo region,
int versionOfClosingNode)
Closes the specified region. |
void |
HRegionInterface.compactRegion(HRegionInfo regionInfo,
boolean major)
Compacts the specified region. |
void |
HRegionInterface.compactRegion(HRegionInfo regionInfo,
boolean major,
byte[] columnFamily)
Compacts a column-family within a specified region. |
void |
HRegionInterface.flushRegion(HRegionInfo regionInfo)
Deprecated. use HRegionInterface.flushRegion(byte[]) instead |
RegionOpeningState |
HRegionInterface.openRegion(HRegionInfo region)
Opens the specified region. |
RegionOpeningState |
HRegionInterface.openRegion(HRegionInfo region,
int versionOfOfflineNode)
Opens the specified region. |
void |
HRegionInterface.splitRegion(HRegionInfo regionInfo)
Splits the specified region. |
void |
HRegionInterface.splitRegion(HRegionInfo regionInfo,
byte[] splitPoint)
Splits the specified region. |
Method parameters in org.apache.hadoop.hbase.ipc with type arguments of type HRegionInfo | |
---|---|
void |
HRegionInterface.openRegions(List<HRegionInfo> regions)
Opens the specified regions. |
Uses of HRegionInfo in org.apache.hadoop.hbase.master |
---|
Methods in org.apache.hadoop.hbase.master that return HRegionInfo | |
---|---|
HRegionInfo |
AssignmentManager.RegionState.getRegion()
|
HRegionInfo |
RegionPlan.getRegionInfo()
|
Methods in org.apache.hadoop.hbase.master that return types with arguments of type HRegionInfo | |
---|---|
List<HRegionInfo> |
AssignmentManager.getEnablingTableRegions(String tableName)
Gives enabling table regions. |
List<HRegionInfo> |
AssignmentManager.getRegionsOfTable(byte[] tableName)
Gets the online regions of the specified table. |
Map<HRegionInfo,ServerName> |
DefaultLoadBalancer.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<HRegionInfo,ServerName> |
LoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Sync assign a region |
Pair<Set<HRegionInfo>,List<AssignmentManager.RegionState>> |
AssignmentManager.processServerShutdown(ServerName sn)
Start processing of shutdown server. |
Map<ServerName,List<HRegionInfo>> |
DefaultLoadBalancer.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>> |
LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server |
Map<ServerName,List<HRegionInfo>> |
DefaultLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment. |
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions. |
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)
|
void |
AssignmentManager.assign(HRegionInfo region,
boolean setOfflineInZK,
boolean forceNewPlan,
boolean hijack)
|
void |
HMaster.assignRegion(HRegionInfo hri)
|
void |
HMaster.clearFromTransition(HRegionInfo hri)
|
void |
AssignmentManager.clearRegionFromTransition(HRegionInfo hri)
Deprecated. This is a dupe of AssignmentManager.regionOffline(HRegionInfo) .
Please use that method instead. |
void |
AssignmentManager.deleteClosingOrClosedNode(HRegionInfo region)
|
void |
MasterFileSystem.deleteFamilyFromFS(HRegionInfo region,
byte[] familyName)
|
void |
MasterFileSystem.deleteRegion(HRegionInfo region)
|
ServerName |
AssignmentManager.getRegionServerOfRegion(HRegionInfo hri)
Returns the RegionServer to which hri is assigned. |
void |
AssignmentManager.handleSplitReport(ServerName sn,
HRegionInfo parent,
HRegionInfo a,
HRegionInfo b)
Update inmemory structures. |
boolean |
AssignmentManager.isCarryingRegion(ServerName serverName,
HRegionInfo hri)
Check if the shutdown server carries the specific region. |
boolean |
AssignmentManager.isRegionAssigned(HRegionInfo hri)
Checks whether the region is assigned. |
AssignmentManager.RegionState |
AssignmentManager.isRegionInTransition(HRegionInfo hri)
|
void |
AssignmentManager.offlineDisabledRegion(HRegionInfo regionInfo)
|
void |
AssignmentManager.regionOffline(HRegionInfo regionInfo)
Marks the region as offline. |
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)
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 |
AssignmentManager.setOffline(HRegionInfo regionInfo)
Sets the region as offline by removing in-memory assignment information but retaining transition information. |
void |
AssignmentManager.unassign(HRegionInfo region)
Unassigns the specified region. |
void |
AssignmentManager.unassign(HRegionInfo region,
boolean force)
Unassigns the specified region. |
void |
MasterFileSystem.updateRegionInfo(HRegionInfo region)
|
void |
AssignmentManager.waitForAssignment(HRegionInfo regionInfo)
Waits until the specified region has completed assignment. |
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.assignUserRegions(List<HRegionInfo> regions,
List<ServerName> servers)
Assigns all user regions, if any. |
void |
AssignmentManager.assignUserRegionsToOnlineServers(List<HRegionInfo> regions)
Assigns all user regions to online servers. |
List<RegionPlan> |
DefaultLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server. |
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Perform the major balance operation |
Map<HRegionInfo,ServerName> |
DefaultLoadBalancer.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<HRegionInfo,ServerName> |
LoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Sync assign a region |
Map<ServerName,List<HRegionInfo>> |
DefaultLoadBalancer.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>> |
LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server |
Map<ServerName,List<HRegionInfo>> |
DefaultLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment. |
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions. |
void |
ServerManager.sendRegionOpen(ServerName server,
List<HRegionInfo> regions)
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. |
|
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.handler |
---|
Methods in org.apache.hadoop.hbase.master.handler that return HRegionInfo | |
---|---|
HRegionInfo |
SplitRegionHandler.getHRegionInfo()
|
HRegionInfo |
ClosedRegionHandler.getHRegionInfo()
|
HRegionInfo |
TotesHRegionInfo.getHRegionInfo()
|
HRegionInfo |
OpenedRegionHandler.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 |
TableAddFamilyHandler.handleTableOperation(List<HRegionInfo> hris)
|
protected void |
ModifyTableHandler.handleTableOperation(List<HRegionInfo> hris)
|
protected void |
TableModifyFamilyHandler.handleTableOperation(List<HRegionInfo> regions)
|
protected void |
DeleteTableHandler.handleTableOperation(List<HRegionInfo> regions)
|
protected abstract void |
TableEventHandler.handleTableOperation(List<HRegionInfo> regions)
|
protected void |
TableDeleteFamilyHandler.handleTableOperation(List<HRegionInfo> hris)
|
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,
ServerManager serverManager,
HTableDescriptor hTableDescriptor,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo[] newRegions,
CatalogTracker catalogTracker,
AssignmentManager assignmentManager)
|
|
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 | |
---|---|
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 void |
EnabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
This method kicks off a snapshot procedure. |
void |
DisabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regionsAndLocations)
|
protected abstract void |
TakeSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
Snapshot the specified regions |
Uses of HRegionInfo in org.apache.hadoop.hbase.regionserver |
---|
Methods in org.apache.hadoop.hbase.regionserver that return HRegionInfo | |
---|---|
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 |
HRegion.getRegionInfo()
|
HRegionInfo |
RegionScanner.getRegionInfo()
|
HRegionInfo |
HRegionServer.getRegionInfo(byte[] regionName)
|
static HRegionInfo |
HRegion.loadDotRegionInfoFileContent(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dir)
|
Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type HRegionInfo | |
---|---|
List<HRegionInfo> |
HRegionServer.getOnlineRegions()
|
Methods in org.apache.hadoop.hbase.regionserver with parameters of type HRegionInfo | |
---|---|
protected void |
HRegionServer.addRegionsInTransition(HRegionInfo region,
String currentAction)
String currentAction) throws RegionAlreadyInTransitionException { Add region to this regionservers list of in transitions regions ONLY if its not already byte[] encodedName = region.getEncodedNameAsBytes(); in transition. |
boolean |
HRegionServer.closeRegion(HRegionInfo region)
|
boolean |
HRegionServer.closeRegion(HRegionInfo region,
boolean zk)
|
protected boolean |
HRegionServer.closeRegion(HRegionInfo region,
boolean abort,
boolean zk)
|
protected boolean |
HRegionServer.closeRegion(HRegionInfo region,
boolean abort,
boolean zk,
int versionOfClosingNode)
|
protected boolean |
HRegionServer.closeRegion(HRegionInfo region,
boolean zk,
int versionOfClosingNode)
|
boolean |
HRegionServer.closeRegion(HRegionInfo region,
int versionOfClosingNode)
|
void |
HRegionServer.compactRegion(HRegionInfo regionInfo,
boolean major)
|
void |
HRegionServer.compactRegion(HRegionInfo regionInfo,
boolean major,
byte[] family)
|
boolean |
HRegionServer.containsKeyInRegionsInTransition(HRegionInfo hri)
|
boolean |
RegionServerServices.containsKeyInRegionsInTransition(HRegionInfo hri)
|
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 void |
HRegion.deleteRegion(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootdir,
HRegionInfo info)
Deletes all the files for a HRegion |
void |
HRegionServer.flushRegion(HRegionInfo regionInfo)
|
static org.apache.hadoop.fs.Path |
HRegion.getRegionDir(org.apache.hadoop.fs.Path rootdir,
HRegionInfo info)
Computes the Path of the HRegion |
static void |
HRegion.makeColumnFamilyDirs(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tabledir,
HRegionInfo hri,
byte[] colFamily)
Make the directories for a specific column family |
static HRegion |
HRegion.newHRegion(org.apache.hadoop.fs.Path tableDir,
HLog log,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo regionInfo,
HTableDescriptor htd,
RegionServerServices rsServices)
A utility method to create new instances of HRegion based on the HConstants.REGION_IMPL configuration property. |
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 tableDir,
HRegionInfo info,
HTableDescriptor htd,
HLog wal,
org.apache.hadoop.conf.Configuration conf)
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path tableDir,
HRegionInfo info,
HTableDescriptor htd,
HLog wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region. |
RegionOpeningState |
HRegionServer.openRegion(HRegionInfo region)
|
RegionOpeningState |
HRegionServer.openRegion(HRegionInfo region,
int versionOfOfflineNode)
|
void |
RegionCoprocessorHost.postWALRestore(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
boolean |
RegionCoprocessorHost.preWALRestore(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
boolean |
HRegionServer.removeFromRegionsInTransition(HRegionInfo hri)
|
boolean |
RegionServerServices.removeFromRegionsInTransition(HRegionInfo hri)
Remove passed hri from the internal list of regions in transition on this
regionserver. |
static boolean |
HRegion.rowIsInRange(HRegionInfo info,
byte[] row)
Determines if the specified row is within the row range specified by the specified HRegionInfo |
void |
HRegionServer.splitRegion(HRegionInfo regionInfo)
|
void |
HRegionServer.splitRegion(HRegionInfo regionInfo,
byte[] splitPoint)
|
static void |
HRegion.writeRegioninfoOnFilesystem(HRegionInfo regionInfo,
org.apache.hadoop.fs.Path regiondir,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf)
Write out an info file under the region directory. |
Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type HRegionInfo | |
---|---|
void |
HRegionServer.openRegions(List<HRegionInfo> regions)
|
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 conf,
HRegionInfo regionInfo,
HTableDescriptor htd,
RegionServerServices rsServices)
HRegion constructor. |
Uses of HRegionInfo in org.apache.hadoop.hbase.regionserver.handler |
---|
Methods in org.apache.hadoop.hbase.regionserver.handler that return HRegionInfo | |
---|---|
HRegionInfo |
CloseRegionHandler.getRegionInfo()
|
HRegionInfo |
OpenRegionHandler.getRegionInfo()
|
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,
EventHandler.EventType eventType)
|
|
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,
EventHandler.EventType eventType,
int version)
|
|
OpenRegionHandler(Server server,
RegionServerServices rsServices,
HRegionInfo regionInfo,
HTableDescriptor htd,
int version)
|
|
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.metrics |
---|
Constructors in org.apache.hadoop.hbase.regionserver.metrics with parameters of type HRegionInfo | |
---|---|
OperationMetrics(org.apache.hadoop.conf.Configuration conf,
HRegionInfo regionInfo)
Create a new OperationMetrics |
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. |
protected void |
HLog.doWrite(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit,
HTableDescriptor htd)
|
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.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.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 HRegionInfo | |
---|---|
static HRegionInfo |
Writables.getHRegionInfo(byte[] bytes)
|
static HRegionInfo |
Writables.getHRegionInfoOrNull(byte[] bytes)
|
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. |
static List<HRegionInfo> |
Writables.getHRegionInfos(byte[] bytes,
int offset,
int length)
|
List<HRegionInfo> |
MetaUtils.getMETARows(byte[] tableName)
|
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. |
HRegion |
MetaUtils.getMetaRegion(HRegionInfo metaInfo)
Open or return cached opened meta region |
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 |
boolean |
MetaUtils.ScannerListener.processRow(HRegionInfo info)
Callback so client of scanner can process row contents |
void |
MetaUtils.scanMetaRegion(HRegionInfo metaRegionInfo,
MetaUtils.ScannerListener listener)
Scans a meta region. |
void |
MetaUtils.updateMETARegionInfo(HRegion r,
HRegionInfo hri)
Update COL_REGIONINFO in meta region r with HRegionInfo hri |
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 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,
EventHandler.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 int |
ZKAssign.createOrForceNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
boolean hijack,
boolean allowCreation)
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 void |
ZKAssign.forceNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Forces an existing unassigned node to the OFFLINE state for the specified region. |
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,
EventHandler.EventType beginState,
EventHandler.EventType endState,
int expectedVersion)
Method that actually performs unassigned node transitions. |
static int |
ZKAssign.transitionNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventHandler.EventType beginState,
EventHandler.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,
EventHandler.EventType beginState)
|
static boolean |
ZKAssign.verifyRegionState(ZooKeeperWatcher zkw,
HRegionInfo region,
EventHandler.EventType expectedState)
Verifies that the specified region is in the specified state in ZooKeeper. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |