|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use ServerName | |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.catalog | |
org.apache.hadoop.hbase.client | Provides HBase Client |
org.apache.hadoop.hbase.client.backoff | |
org.apache.hadoop.hbase.coprocessor | Table of Contents |
org.apache.hadoop.hbase.exceptions | |
org.apache.hadoop.hbase.ipc | Tools to help define network clients and servers. |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.balancer | |
org.apache.hadoop.hbase.master.handler | |
org.apache.hadoop.hbase.master.snapshot | |
org.apache.hadoop.hbase.protobuf | Holds classes generated from protobuf
src/main/protobuf definition files. |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication | Multi Cluster Replication |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.tmpl.master | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.zookeeper |
Uses of ServerName in org.apache.hadoop.hbase |
---|
Fields in org.apache.hadoop.hbase with type parameters of type ServerName | |
---|---|
static List<ServerName> |
ServerName.EMPTY_SERVER_LIST
|
Methods in org.apache.hadoop.hbase that return ServerName | |
---|---|
ServerName |
ClusterStatus.getMaster()
Returns detailed information about the current master ServerName . |
ServerName |
SplitLogTask.getServerName()
|
ServerName |
RegionTransition.getServerName()
|
ServerName |
HRegionLocation.getServerName()
|
ServerName |
Server.getServerName()
|
static ServerName |
HRegionInfo.getServerName(Result r)
Returns a ServerName from catalog table Result . |
static ServerName |
ServerName.parseFrom(byte[] data)
Get a ServerName from the passed in data bytes. |
static ServerName |
ServerName.parseServerName(String str)
|
static ServerName |
ServerName.parseVersionedServerName(byte[] versionedBytes)
Use this method instantiating a ServerName from bytes
gotten from a call to getVersionedBytes() . |
static ServerName |
ServerName.valueOf(String serverName)
Retrieve an instance of ServerName. |
static ServerName |
ServerName.valueOf(String hostname,
int port,
long startcode)
Retrieve an instance of ServerName. |
static ServerName |
ServerName.valueOf(String hostAndPort,
long startCode)
Retrieve an instance of ServerName. |
Methods in org.apache.hadoop.hbase that return types with arguments of type ServerName | |
---|---|
Collection<ServerName> |
ClusterStatus.getBackupMasters()
|
Collection<ServerName> |
ClusterStatus.getDeadServerNames()
|
static Pair<HRegionInfo,ServerName> |
HRegionInfo.getHRegionInfoAndServerName(Result r)
Extract a HRegionInfo and ServerName from catalog table Result . |
Collection<ServerName> |
ClusterStatus.getServerInfo()
Deprecated. Use ClusterStatus.getServers() |
Collection<ServerName> |
ClusterStatus.getServers()
|
Methods in org.apache.hadoop.hbase with parameters of type ServerName | |
---|---|
int |
ServerName.compareTo(ServerName other)
|
static RegionTransition |
RegionTransition.createRegionTransition(EventType type,
byte[] regionName,
ServerName sn)
|
static RegionTransition |
RegionTransition.createRegionTransition(EventType type,
byte[] regionName,
ServerName sn,
byte[] payload)
|
ServerLoad |
ClusterStatus.getLoad(ServerName sn)
|
boolean |
SplitLogTask.isDone(ServerName sn)
|
boolean |
SplitLogTask.isErr(ServerName sn)
|
boolean |
SplitLogTask.isOwned(ServerName sn)
|
boolean |
SplitLogTask.isResigned(ServerName sn)
|
static boolean |
ServerName.isSameHostnameAndPort(ServerName left,
ServerName right)
|
boolean |
SplitLogTask.isUnassigned(ServerName sn)
|
Constructors in org.apache.hadoop.hbase with parameters of type ServerName | |
---|---|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn)
|
|
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName)
|
|
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName,
long seqNum)
|
|
SplitLogTask.Done(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode)
|
|
SplitLogTask.Err(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode)
|
|
SplitLogTask.Owned(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode)
|
|
SplitLogTask.Resigned(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode)
|
|
SplitLogTask.Unassigned(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode)
|
Constructor parameters in org.apache.hadoop.hbase with type arguments of type ServerName | |
---|---|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn)
|
|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn)
|
|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn)
|
Uses of ServerName in org.apache.hadoop.hbase.catalog |
---|
Methods in org.apache.hadoop.hbase.catalog that return ServerName | |
---|---|
ServerName |
CatalogTracker.getMetaLocation()
Gets the current location for hbase:meta or null if location is
not currently available. |
ServerName |
CatalogTracker.waitForMeta(long timeout)
Gets the current location for hbase:meta if available and waits
for up to the specified timeout if not immediately available. |
Methods in org.apache.hadoop.hbase.catalog that return types with arguments of type ServerName | |
---|---|
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<TableName> disabledTables)
Performs a full scan of hbase:meta , skipping regions from any
tables in the specified set of disabled tables. |
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents)
Performs a full scan of hbase: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 List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
TableName tableName)
|
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
TableName tableName,
boolean excludeOfflinedSplitParents)
|
Methods in org.apache.hadoop.hbase.catalog with parameters of type ServerName | |
---|---|
static void |
MetaEditor.addDaughter(CatalogTracker catalogTracker,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum)
Adds a daughter region entry to meta. |
static NavigableMap<HRegionInfo,Result> |
MetaReader.getServerUserRegions(CatalogTracker catalogTracker,
ServerName serverName)
|
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 hbase: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 hbase:meta to be the specified server hostname and startcode. |
Uses of ServerName in org.apache.hadoop.hbase.client |
---|
Methods in org.apache.hadoop.hbase.client that return types with arguments of type ServerName | |
---|---|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf,
HConnection connection,
TableName tableName,
boolean offlined)
Lists all of the table regions currently in META. |
NavigableMap<HRegionInfo,ServerName> |
HTable.getRegionLocations()
Gets all the regions and their address for this table. |
Methods in org.apache.hadoop.hbase.client with parameters of type ServerName | ||
---|---|---|
void |
HConnection.clearCaches(ServerName sn)
Clear any caches that pertain to server name sn . |
|
void |
HConnectionManager.HConnectionImplementation.clearCaches(ServerName serverName)
|
|
void |
HBaseAdmin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region. |
|
void |
HBaseAdmin.compactRegionServer(ServerName sn,
boolean major)
Compact all regions on the region server |
|
CoprocessorRpcChannel |
HBaseAdmin.coprocessorService(ServerName sn)
Creates and returns a RpcChannel instance
connected to the passed region server. |
|
AdminProtos.AdminService.BlockingInterface |
HConnection.getAdmin(ServerName serverName)
Establishes a connection to the region server at the specified address. |
|
AdminProtos.AdminService.BlockingInterface |
HConnectionManager.HConnectionImplementation.getAdmin(ServerName serverName)
|
|
AdminProtos.AdminService.BlockingInterface |
HConnection.getAdmin(ServerName serverName,
boolean getMaster)
Deprecated. You can pass master flag but nothing special is done. |
|
AdminProtos.AdminService.BlockingInterface |
HConnectionManager.HConnectionImplementation.getAdmin(ServerName serverName,
boolean master)
|
|
ClientProtos.ClientService.BlockingInterface |
CoprocessorHConnection.getClient(ServerName serverName)
|
|
ClientProtos.ClientService.BlockingInterface |
HConnection.getClient(ServerName serverName)
Establishes a connection to the region server at the specified address, and returns a region client protocol. |
|
ClientProtos.ClientService.BlockingInterface |
HConnectionManager.HConnectionImplementation.getClient(ServerName sn)
|
|
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server. |
|
ServerStatistics |
ServerStatisticTracker.getStats(ServerName server)
|
|
boolean |
HConnection.isDeadServer(ServerName serverName)
|
|
boolean |
HConnectionManager.HConnectionImplementation.isDeadServer(ServerName sn)
|
|
void |
ServerStatisticTracker.updateRegionStats(ServerName server,
byte[] region,
ClientProtos.RegionLoadStats currentStats)
|
|
static
|
ResultStatsUtil.updateStats(T r,
ServerStatisticTracker serverStats,
ServerName server,
byte[] regionName)
Update the stats for the specified region if the result is an instance of ResultStatsUtil |
Uses of ServerName in org.apache.hadoop.hbase.client.backoff |
---|
Methods in org.apache.hadoop.hbase.client.backoff with parameters of type ServerName | |
---|---|
long |
ClientBackoffPolicyFactory.NoBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats)
|
long |
ExponentialClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats)
|
long |
ClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats)
|
Uses of ServerName in org.apache.hadoop.hbase.coprocessor |
---|
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type ServerName | |
---|---|
void |
BaseMasterAndRegionObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
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 |
BaseMasterAndRegionObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
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)
|
Uses of ServerName in org.apache.hadoop.hbase.exceptions |
---|
Methods in org.apache.hadoop.hbase.exceptions that return ServerName | |
---|---|
ServerName |
RegionMovedException.getServerName()
|
Constructors in org.apache.hadoop.hbase.exceptions with parameters of type ServerName | |
---|---|
RegionMovedException(ServerName serverName,
long locationSeqNum)
|
Uses of ServerName in org.apache.hadoop.hbase.ipc |
---|
Methods in org.apache.hadoop.hbase.ipc with parameters of type ServerName | |
---|---|
com.google.protobuf.BlockingRpcChannel |
RpcClient.createBlockingRpcChannel(ServerName sn,
User ticket,
int rpcTimeout)
Creates a "channel" that can be used by a blocking protobuf service. |
Constructors in org.apache.hadoop.hbase.ipc with parameters of type ServerName | |
---|---|
RegionServerCoprocessorRpcChannel(HConnection conn,
ServerName serverName)
|
|
RpcClient.BlockingRpcChannelImplementation(RpcClient rpcClient,
ServerName sn,
User ticket,
int rpcTimeout)
|
Uses of ServerName in org.apache.hadoop.hbase.master |
---|
Fields in org.apache.hadoop.hbase.master declared as ServerName | |
---|---|
static ServerName |
AssignmentManager.HBCK_CODE_SERVERNAME
|
Methods in org.apache.hadoop.hbase.master that return ServerName | |
---|---|
ServerName |
RegionPlan.getDestination()
Get the destination server for the plan for this region. |
ServerName |
RegionStates.getRegionServerOfRegion(HRegionInfo hri)
|
ServerName |
HMaster.getServerName()
|
ServerName |
RegionState.getServerName()
|
ServerName |
RegionPlan.getSource()
Get the source server for the plan for this region. |
ServerName |
LoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list |
Methods in org.apache.hadoop.hbase.master that return types with arguments of type ServerName | |
---|---|
List<Pair<ServerName,Long>> |
DeadServer.copyDeadServersSince(long ts)
Extract all the servers dead since a given time, and sort them. |
Set<ServerName> |
DeadServer.copyServerNames()
|
List<ServerName> |
ServerManager.createDestinationServersList()
Calls ServerManager.createDestinationServersList(org.apache.hadoop.hbase.ServerName) without server to exclude. |
List<ServerName> |
ServerManager.createDestinationServersList(ServerName serverToExclude)
Creates a list of possible destinations for a region. |
protected List<ServerName> |
ClusterStatusPublisher.generateDeadServersListToSend()
Create the dead server to send. |
protected Map<TableName,Map<ServerName,List<HRegionInfo>>> |
RegionStates.getAssignmentsByTable()
This is an EXPENSIVE clone. |
protected List<Pair<ServerName,Long>> |
ClusterStatusPublisher.getDeadServers(long since)
Get the servers which died since a given timestamp. |
List<ServerName> |
ServerManager.getDrainingServersList()
|
static List<ServerName> |
RegionPlacementMaintainer.getFavoredNodeList(String favoredNodesStr)
|
Map<ServerName,ServerLoad> |
ServerManager.getOnlineServers()
|
List<ServerName> |
ServerManager.getOnlineServersList()
|
Map<HRegionInfo,ServerName> |
RegionStates.getRegionAssignments()
|
Map<ServerName,List<HRegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getRegionServerToRegionMap()
Get regionserver to region map |
Map<HRegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.getRegionToRegionServerMap()
Get region to region server map |
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. |
Methods in org.apache.hadoop.hbase.master with parameters of type ServerName | |
---|---|
void |
DeadServer.add(ServerName sn)
Adds the server to the dead server list if it's not there already. |
boolean |
ServerManager.addServerToDrainList(ServerName sn)
|
void |
DeadServer.cleanAllPreviousInstances(ServerName newServerName)
|
boolean |
DeadServer.cleanPreviousInstance(ServerName newServerName)
A dead server that comes back alive has a different start code. |
List<ServerName> |
ServerManager.createDestinationServersList(ServerName serverToExclude)
Creates a list of possible destinations for a region. |
RegionState |
RegionStates.createRegionState(HRegionInfo hri,
RegionState.State newState,
ServerName serverName)
Add a region to RegionStates with the specified state. |
static TableLockManager |
TableLockManager.createTableLockManager(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zkWatcher,
ServerName serverName)
Creates and returns a TableLockManager according to the configuration |
void |
AssignmentManager.deleteClosingOrClosedNode(HRegionInfo region,
ServerName sn)
|
void |
ServerManager.expireServer(ServerName serverName)
|
void |
DeadServer.finish(ServerName sn)
|
SplitLogManager.TaskFinisher.Status |
SplitLogManager.TaskFinisher.finish(ServerName workerName,
String taskname)
finish the partially done task. |
ServerLoad |
ServerManager.getLoad(ServerName serverName)
|
String |
RackManager.getRack(ServerName server)
Get the name of the rack containing a server, according to the DNS to switch mapping. |
int |
HMaster.getRegionServerInfoPort(ServerName sn)
|
Date |
DeadServer.getTimeOfDeath(ServerName deadServerName)
Get the time when a server died |
boolean |
AssignmentManager.isCarryingMeta(ServerName serverName)
|
boolean |
DeadServer.isDeadServer(ServerName serverName)
|
boolean |
RegionState.isOnServer(ServerName sn)
|
boolean |
RegionState.isOpenOrMergingNewOnServer(ServerName sn)
|
boolean |
RegionState.isOpenOrMergingOnServer(ServerName sn)
|
boolean |
RegionState.isOpenOrSplittingNewOnServer(ServerName sn)
|
boolean |
RegionState.isOpenOrSplittingOnServer(ServerName sn)
|
boolean |
RegionState.isPendingCloseOrClosingOnServer(ServerName sn)
|
boolean |
RegionState.isPendingOpenOrOpeningOnServer(ServerName sn)
|
boolean |
ServerManager.isServerDead(ServerName serverName)
Check if a server is known to be dead. |
boolean |
ServerManager.isServerOnline(ServerName serverName)
|
boolean |
ServerManager.isServerReachable(ServerName server)
Check if a region server is reachable and has the expected start code |
void |
RegionStates.logSplit(ServerName serverName)
A dead server's hlogs have been split so that all the regions used to be open on it can be safely assigned now. |
protected String |
AssignmentManager.onRegionTransition(ServerName serverName,
RegionServerStatusProtos.RegionStateTransition transition)
Try to update some region states. |
void |
MasterCoprocessorHost.postMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
boolean |
MasterCoprocessorHost.preMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
void |
MasterFileSystem.prepareLogReplay(ServerName serverName,
Set<HRegionInfo> regions)
Mark regions in recovering state when distributedLogReplay are set true |
void |
ServerManager.processDeadServer(ServerName serverName)
|
void |
ServerManager.processDeadServer(ServerName serverName,
boolean shouldSplitHlog)
|
List<HRegionInfo> |
AssignmentManager.processServerShutdown(ServerName sn)
Process shutdown server removing any assignments. |
void |
RegionStates.regionOnline(HRegionInfo hri,
ServerName serverName)
|
void |
LoadBalancer.regionOnline(HRegionInfo regionInfo,
ServerName sn)
Marks the region as online at balancer. |
void |
RegionStates.regionOnline(HRegionInfo hri,
ServerName serverName,
long openSeqNum)
A region is online, won't be in transition any more. |
void |
AssignmentListener.regionOpened(HRegionInfo regionInfo,
ServerName serverName)
The region was opened on the specified server. |
boolean |
ServerManager.removeServerFromDrainList(ServerName sn)
|
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,
List<ServerName> favoredNodes)
Sends an OPEN RPC to the specified server to open the specified region. |
List<RegionOpeningState> |
ServerManager.sendRegionOpen(ServerName server,
List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos)
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 |
ServerListener.serverAdded(ServerName serverName)
The server has joined the cluster. |
List<HRegionInfo> |
RegionStates.serverOffline(ZooKeeperWatcher watcher,
ServerName sn)
A server is offline, all regions on it are dead. |
void |
ServerListener.serverRemoved(ServerName serverName)
The server was removed from the cluster. |
void |
RegionPlan.setDestination(ServerName dest)
Set the destination server for the plan for this region. |
void |
MasterFileSystem.splitLog(ServerName serverName)
|
void |
MasterFileSystem.splitMetaLog(ServerName serverName)
Specialized method to handle the splitting for meta HLog |
RegionState |
RegionStates.transitionOpenFromPendingOpenOrOpeningOnServer(RegionTransition transition,
RegionState fromState,
ServerName sn)
Transition a region state to OPEN from OPENING/PENDING_OPEN |
void |
AssignmentManager.unassign(HRegionInfo region,
boolean force,
ServerName dest)
Unassigns the specified region. |
RegionState |
RegionStates.updateRegionState(HRegionInfo hri,
RegionState.State state,
ServerName serverName)
Update a region state. |
Method parameters in org.apache.hadoop.hbase.master with type arguments of type ServerName | |
---|---|
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 |
Map<HRegionInfo,ServerName> |
LoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Sync assign a region |
void |
MasterFileSystem.prepareLogReplay(Set<ServerName> serverNames)
Mark regions in recovering state when distributedLogReplay are set true |
ServerName |
LoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list |
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.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. |
RegionOpeningState |
ServerManager.sendRegionOpen(ServerName server,
HRegionInfo region,
int versionOfOfflineNode,
List<ServerName> favoredNodes)
Sends an OPEN RPC to the specified server to open the specified region. |
List<RegionOpeningState> |
ServerManager.sendRegionOpen(ServerName server,
List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos)
Sends an OPEN RPC to the specified server to open the specified region. |
void |
MasterFileSystem.splitLog(Set<ServerName> serverNames)
|
void |
MasterFileSystem.splitLog(Set<ServerName> serverNames,
org.apache.hadoop.fs.PathFilter filter)
This method is the base split method that splits HLog files matching a filter. |
long |
SplitLogManager.splitLogDistributed(Set<ServerName> serverNames,
List<org.apache.hadoop.fs.Path> logDirs,
org.apache.hadoop.fs.PathFilter filter)
The caller will block until all the hbase:meta log files of the given region server have been processed - successfully split or an error is encountered - by an available worker region server. |
void |
MasterFileSystem.splitMetaLog(Set<ServerName> serverNames)
Specialized method to handle the splitting for meta HLog |
Constructors in org.apache.hadoop.hbase.master with parameters of type ServerName | |
---|---|
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,
long stamp,
ServerName serverName)
|
|
RegionState(HRegionInfo region,
RegionState.State state,
ServerName serverName)
|
|
SplitLogManager(ZooKeeperWatcher zkw,
org.apache.hadoop.conf.Configuration conf,
Stoppable stopper,
MasterServices master,
ServerName serverName,
boolean masterRecovery)
Wrapper around SplitLogManager.SplitLogManager(ZooKeeperWatcher zkw, Configuration conf,
Stoppable stopper, MasterServices master, ServerName serverName,
boolean masterRecovery, TaskFinisher tf)
that provides a task finisher for copying recovered edits to their final destination. |
|
SplitLogManager(ZooKeeperWatcher zkw,
org.apache.hadoop.conf.Configuration conf,
Stoppable stopper,
MasterServices master,
ServerName serverName,
boolean masterRecovery,
SplitLogManager.TaskFinisher tf)
Its OK to construct this object even when region-servers are not online. |
Constructor parameters in org.apache.hadoop.hbase.master with type arguments of type ServerName | |
---|---|
BulkReOpen(Server server,
Map<ServerName,List<HRegionInfo>> serverToRegions,
AssignmentManager am)
|
|
GeneralBulkAssigner(Server server,
Map<ServerName,List<HRegionInfo>> bulkPlan,
AssignmentManager am,
boolean waitTillAllAssigned)
|
Uses of ServerName in org.apache.hadoop.hbase.master.balancer |
---|
Methods in org.apache.hadoop.hbase.master.balancer that return ServerName | |
---|---|
static ServerName[] |
FavoredNodeAssignmentHelper.getFavoredNodesList(byte[] favoredNodes)
|
ServerName |
FavoredNodeLoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
|
ServerName |
BaseLoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server. |
Methods in org.apache.hadoop.hbase.master.balancer that return types with arguments of type ServerName | |
---|---|
Map<HRegionInfo,List<ServerName>> |
FavoredNodesPlan.getAssignmentMap()
|
List<ServerName> |
FavoredNodeLoadBalancer.getFavoredNodes(HRegionInfo regionInfo)
|
List<ServerName> |
FavoredNodesPlan.getFavoredNodes(HRegionInfo region)
|
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>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
|
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 ServerName | |
---|---|
static FavoredNodesPlan.Position |
FavoredNodesPlan.getFavoredServerPosition(List<ServerName> favoredNodes,
ServerName server)
Return the position of the server in the favoredNodes list. |
void |
BaseLoadBalancer.regionOnline(HRegionInfo regionInfo,
ServerName sn)
|
Method parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type ServerName | |
---|---|
List<RegionPlan> |
FavoredNodeLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
|
List<RegionPlan> |
SimpleLoadBalancer.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. |
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Given the cluster state this will try and approach an optimal balance. |
static byte[] |
FavoredNodeAssignmentHelper.getFavoredNodes(List<ServerName> serverAddrList)
|
static String |
FavoredNodeAssignmentHelper.getFavoredNodesAsString(List<ServerName> nodes)
|
static FavoredNodesPlan.Position |
FavoredNodesPlan.getFavoredServerPosition(List<ServerName> favoredNodes,
ServerName server)
Return the position of the server in the favoredNodes list. |
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<HRegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions(Map<HRegionInfo,ServerName> primaryRSMap)
For regions that share the primary, avoid placing the secondary and tertiary on a same RS. |
ServerName |
FavoredNodeLoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
|
ServerName |
BaseLoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server. |
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.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>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
|
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. |
void |
FavoredNodesPlan.updateAssignmentPlan(HRegionInfo region,
List<ServerName> servers)
Add an assignment to the plan |
void |
FavoredNodesPlan.updateFavoredNodesMap(HRegionInfo region,
List<ServerName> servers)
Add an assignment to the plan |
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<HRegionInfo,List<ServerName>> regionToFavoredNodes,
CatalogTracker catalogTracker)
Update meta table with favored nodes info |
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<HRegionInfo,List<ServerName>> regionToFavoredNodes,
org.apache.hadoop.conf.Configuration conf)
Update meta table with favored nodes info |
Constructor parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type ServerName | |
---|---|
BaseLoadBalancer.Cluster(Map<ServerName,List<HRegionInfo>> clusterState,
Map<String,Deque<RegionLoad>> loads,
org.apache.hadoop.hbase.master.balancer.RegionLocationFinder regionFinder)
|
|
ClusterLoadState(Map<ServerName,List<HRegionInfo>> clusterState)
|
|
FavoredNodeAssignmentHelper(List<ServerName> servers,
org.apache.hadoop.conf.Configuration conf)
|
|
FavoredNodeAssignmentHelper(List<ServerName> servers,
RackManager rackManager)
|
Uses of ServerName in org.apache.hadoop.hbase.master.handler |
---|
Fields in org.apache.hadoop.hbase.master.handler declared as ServerName | |
---|---|
protected ServerName |
ServerShutdownHandler.serverName
|
Constructors in org.apache.hadoop.hbase.master.handler with parameters of type ServerName | |
---|---|
LogReplayHandler(Server server,
MasterServices services,
DeadServer deadServers,
ServerName serverName)
|
|
MetaServerShutdownHandler(Server server,
MasterServices services,
DeadServer deadServers,
ServerName serverName)
|
|
OpenedRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo,
ServerName sn,
int expectedVersion)
|
|
ServerShutdownHandler(Server server,
MasterServices services,
DeadServer deadServers,
ServerName serverName,
boolean shouldSplitHlog)
|
Uses of ServerName in org.apache.hadoop.hbase.master.snapshot |
---|
Method parameters in org.apache.hadoop.hbase.master.snapshot with type arguments of type ServerName | |
---|---|
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 ServerName in org.apache.hadoop.hbase.protobuf |
---|
Methods in org.apache.hadoop.hbase.protobuf that return ServerName | |
---|---|
static ServerName |
ProtobufUtil.toServerName(HBaseProtos.ServerName proto)
Convert a protocol buffer ServerName to a ServerName |
Methods in org.apache.hadoop.hbase.protobuf with parameters of type ServerName | |
---|---|
static AdminProtos.CloseRegionRequest |
RequestConverter.buildCloseRegionRequest(ServerName server,
byte[] regionName,
boolean transitionInZK)
Create a CloseRegionRequest for a given region name |
static AdminProtos.CloseRegionRequest |
RequestConverter.buildCloseRegionRequest(ServerName server,
byte[] regionName,
int versionOfClosingNode,
ServerName destinationServer,
boolean transitionInZK)
|
static AdminProtos.CloseRegionRequest |
RequestConverter.buildCloseRegionRequest(ServerName server,
String encodedRegionName,
boolean transitionInZK)
Create a CloseRegionRequest for a given encoded region name |
static AdminProtos.GetServerInfoResponse |
ResponseConverter.buildGetServerInfoResponse(ServerName serverName,
int webuiPort)
A utility to build a GetServerInfoResponse. |
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
HRegionInfo region,
int versionOfOfflineNode,
List<ServerName> favoredNodes,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest for a given region |
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest to open a list of regions |
static void |
ProtobufUtil.closeRegion(AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
byte[] regionName,
boolean transitionInZK)
A helper to close a region given a region name using admin protocol. |
static boolean |
ProtobufUtil.closeRegion(AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
byte[] regionName,
int versionOfClosingNode,
ServerName destinationServer,
boolean transitionInZK)
A helper to close a region given a region name using admin protocol. |
static void |
ProtobufUtil.openRegion(AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
HRegionInfo region)
A helper to open a region using admin protocol. |
static HBaseProtos.ServerName |
ProtobufUtil.toServerName(ServerName serverName)
Convert a ServerName to a protocol buffer ServerName |
Method parameters in org.apache.hadoop.hbase.protobuf with type arguments of type ServerName | |
---|---|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
HRegionInfo region,
int versionOfOfflineNode,
List<ServerName> favoredNodes,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest for a given region |
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest to open a list of regions |
static AdminProtos.UpdateFavoredNodesRequest |
RequestConverter.buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo,List<ServerName>>> updateRegionInfos)
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings |
Uses of ServerName in org.apache.hadoop.hbase.regionserver |
---|
Methods in org.apache.hadoop.hbase.regionserver that return ServerName | |
---|---|
protected ServerName |
HRegionServer.createRegionServerStatusStub()
Get the current master from ZooKeeper and open the RPC connection to it. |
ServerName |
HRegionServer.getServerName()
|
Methods in org.apache.hadoop.hbase.regionserver with parameters of type ServerName | |
---|---|
Put |
SplitTransaction.addLocation(Put p,
ServerName sn,
long openSeqNum)
|
Put |
RegionMergeTransaction.addLocation(Put p,
ServerName sn,
long openSeqNum)
|
protected void |
HRegionServer.addToMovedRegions(String encodedName,
ServerName destination,
long closeSeqNum)
|
protected static int |
SplitLogWorker.attemptToOwnTask(boolean isFirstTime,
ZooKeeperWatcher zkw,
ServerName server,
String task,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode,
int taskZKVersion)
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED. |
protected boolean |
HRegionServer.closeRegion(String encodedName,
boolean abort,
boolean zk,
int versionOfClosingNode,
ServerName sn)
Close asynchronously a region, can be called from the master or internally by the regionserver when stopping. |
static void |
RegionMergeTransaction.createNodeMerging(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
HRegionInfo a,
HRegionInfo b)
Creates a new ephemeral node in the PENDING_MERGE state for the merged region. |
static void |
SplitTransaction.createNodeSplitting(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
HRegionInfo a,
HRegionInfo b)
Creates a new ephemeral node in the PENDING_SPLIT state for the specified region. |
void |
RegionMergeTransaction.prepareMutationsForMerge(HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName serverName,
List<Mutation> mutations)
|
boolean |
HRegionServer.removeFromOnlineRegions(HRegion r,
ServerName destination)
|
static int |
RegionMergeTransaction.transitionMergingNode(ZooKeeperWatcher zkw,
HRegionInfo merged,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
int znodeVersion,
EventType beginState,
EventType endState)
Transitions an existing ephemeral node for the specified region which is currently in the begin state to be in the end state. |
static int |
SplitTransaction.transitionSplittingNode(ZooKeeperWatcher zkw,
HRegionInfo parent,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
int znodeVersion,
EventType beginState,
EventType endState)
Transitions an existing ephemeral node for the specified region which is currently in the begin state to be in the end state. |
Uses of ServerName in org.apache.hadoop.hbase.regionserver.handler |
---|
Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type ServerName | |
---|---|
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)
|
Uses of ServerName in org.apache.hadoop.hbase.regionserver.wal |
---|
Methods in org.apache.hadoop.hbase.regionserver.wal that return ServerName | |
---|---|
static ServerName |
HLogUtil.getServerNameFromHLogDirectoryName(org.apache.hadoop.conf.Configuration conf,
String path)
|
static ServerName |
HLogUtil.getServerNameFromHLogDirectoryName(org.apache.hadoop.fs.Path logFile)
This function returns region server name from a log file name which is in either format: hdfs:// |
Uses of ServerName in org.apache.hadoop.hbase.replication |
---|
Methods in org.apache.hadoop.hbase.replication that return types with arguments of type ServerName | |
---|---|
protected static List<ServerName> |
HBaseReplicationEndpoint.fetchSlavesAddresses(ZooKeeperWatcher zkw)
Get the list of all the region servers from the specified peer |
List<ServerName> |
HBaseReplicationEndpoint.getRegionServers()
Get a list of all the addresses of all the region servers for this peer cluster |
Method parameters in org.apache.hadoop.hbase.replication with type arguments of type ServerName | |
---|---|
void |
HBaseReplicationEndpoint.setRegionServers(List<ServerName> regionServers)
Set the list of region servers for that peer |
Uses of ServerName in org.apache.hadoop.hbase.replication.regionserver |
---|
Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type ServerName | |
---|---|
ReplicationSinkManager.SinkPeer(ServerName serverName,
AdminProtos.AdminService.BlockingInterface regionServer)
|
Uses of ServerName in org.apache.hadoop.hbase.security.access |
---|
Methods in org.apache.hadoop.hbase.security.access with parameters of type ServerName | |
---|---|
void |
AccessController.preMove(ObserverContext<MasterCoprocessorEnvironment> c,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
Uses of ServerName in org.apache.hadoop.hbase.tmpl.master |
---|
Fields in org.apache.hadoop.hbase.tmpl.master declared as ServerName | |
---|---|
protected ServerName |
MasterStatusTmpl.metaLocation
|
Fields in org.apache.hadoop.hbase.tmpl.master with type parameters of type ServerName | |
---|---|
protected Set<ServerName> |
MasterStatusTmpl.deadServers
|
protected List<ServerName> |
MasterStatusTmpl.servers
|
protected List<ServerName> |
RegionServerListTmpl.servers
|
Methods in org.apache.hadoop.hbase.tmpl.master that return ServerName | |
---|---|
ServerName |
MasterStatusTmpl.ImplData.getMetaLocation()
|
Methods in org.apache.hadoop.hbase.tmpl.master that return types with arguments of type ServerName | |
---|---|
Set<ServerName> |
MasterStatusTmpl.ImplData.getDeadServers()
|
List<ServerName> |
MasterStatusTmpl.ImplData.getServers()
|
List<ServerName> |
RegionServerListTmpl.ImplData.getServers()
|
Methods in org.apache.hadoop.hbase.tmpl.master with parameters of type ServerName | |
---|---|
MasterStatusTmpl |
MasterStatusTmpl.setMetaLocation(ServerName p_metaLocation)
|
void |
MasterStatusTmpl.ImplData.setMetaLocation(ServerName metaLocation)
|
Method parameters in org.apache.hadoop.hbase.tmpl.master with type arguments of type ServerName | |
---|---|
MasterStatusTmpl |
MasterStatusTmpl.setDeadServers(Set<ServerName> p_deadServers)
|
void |
MasterStatusTmpl.ImplData.setDeadServers(Set<ServerName> deadServers)
|
MasterStatusTmpl |
MasterStatusTmpl.setServers(List<ServerName> p_servers)
|
void |
MasterStatusTmpl.ImplData.setServers(List<ServerName> servers)
|
RegionServerListTmpl |
RegionServerListTmpl.setServers(List<ServerName> p_servers)
|
void |
RegionServerListTmpl.ImplData.setServers(List<ServerName> servers)
|
Uses of ServerName in org.apache.hadoop.hbase.util |
---|
Methods in org.apache.hadoop.hbase.util with parameters of type ServerName | |
---|---|
void |
HBaseFsck.HbckInfo.addServer(HRegionInfo hri,
ServerName server)
|
void |
HBaseFsck.TableInfo.addServer(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. |
Method parameters in org.apache.hadoop.hbase.util with type arguments of type ServerName | |
---|---|
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. |
Uses of ServerName in org.apache.hadoop.hbase.zookeeper |
---|
Methods in org.apache.hadoop.hbase.zookeeper that return ServerName | |
---|---|
static ServerName |
MetaRegionTracker.blockUntilAvailable(ZooKeeperWatcher zkw,
long timeout)
Wait until the meta region is available. |
ServerName |
MasterAddressTracker.getMasterAddress()
Get the address of the current master if one is available. |
ServerName |
MasterAddressTracker.getMasterAddress(boolean refresh)
Get the address of the current master if one is available. |
static ServerName |
MasterAddressTracker.getMasterAddress(ZooKeeperWatcher zkw)
Get master address. |
ServerName |
MetaRegionTracker.getMetaRegionLocation()
Gets the meta region location, if available. |
static ServerName |
MetaRegionTracker.getMetaRegionLocation(ZooKeeperWatcher zkw)
Gets the meta region location, if available. |
ServerName |
MetaRegionTracker.waitMetaRegionLocation(long timeout)
Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available. |
Methods in org.apache.hadoop.hbase.zookeeper that return types with arguments of type ServerName | |
---|---|
List<ServerName> |
RegionServerTracker.getOnlineServers()
Gets the online servers. |
Methods in org.apache.hadoop.hbase.zookeeper with parameters of type ServerName | |
---|---|
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,
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.deleteClosedNode(ZooKeeperWatcher zkw,
String encodedRegionName,
ServerName sn)
Deletes an existing unassigned node that is in the CLOSED state for the specified region. |
static boolean |
ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName sn)
Deletes an existing unassigned node that is in the CLOSING state for the specified region. |
static boolean |
ZKAssign.deleteNode(ZooKeeperWatcher zkw,
String encodedRegionName,
EventType expectedState,
ServerName sn)
Deletes an existing unassigned node that is in the specified state for the specified region. |
static boolean |
ZKAssign.deleteNode(ZooKeeperWatcher zkw,
String encodedRegionName,
EventType expectedState,
ServerName serverName,
int expectedVersion)
Deletes an existing unassigned node that is in the specified state for the specified region. |
static boolean |
ZKAssign.deleteOfflineNode(ZooKeeperWatcher zkw,
String encodedRegionName,
ServerName sn)
Deletes an existing unassigned node that is in the OFFLINE state for the specified region. |
static boolean |
ZKAssign.deleteOpenedNode(ZooKeeperWatcher zkw,
String encodedRegionName,
ServerName sn)
Deletes an existing unassigned node that is in the OPENED state for the specified region. |
HBaseProtos.RegionServerInfo |
RegionServerTracker.getRegionServerInfo(ServerName sn)
|
static int |
ZKAssign.retransitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion,
boolean updateZNode)
Retransitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENING state. |
static boolean |
MasterAddressTracker.setMasterAddress(ZooKeeperWatcher zkw,
String znode,
ServerName master)
Set master address into the master znode or into the backup
subdirectory of backup masters; switch off the passed in znode
path. |
static void |
MetaRegionTracker.setMetaLocation(ZooKeeperWatcher zookeeper,
ServerName location,
RegionState.State regionState)
Sets the location of hbase:meta in ZooKeeper to the
specified server address. |
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 |