|
||||||||||
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.coprocessor | Table of Contents |
org.apache.hadoop.hbase.exceptions | |
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.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 |
---|
Methods in org.apache.hadoop.hbase that return ServerName | |
---|---|
static ServerName |
ServerName.findServerWithSameHostnamePort(Collection<ServerName> names,
ServerName serverName)
|
ServerName |
ClusterStatus.getMaster()
Returns detailed information about the current master ServerName . |
ServerName |
SplitLogTask.getServerName()
|
ServerName |
Server.getServerName()
|
ServerName |
RegionTransition.getServerName()
|
ServerName |
HRegionLocation.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() . |
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)
|
static ServerName |
ServerName.findServerWithSameHostnamePort(Collection<ServerName> names,
ServerName serverName)
|
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)
|
Method parameters in org.apache.hadoop.hbase with type arguments of type ServerName | |
---|---|
static ServerName |
ServerName.findServerWithSameHostnamePort(Collection<ServerName> names,
ServerName serverName)
|
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)
|
|
SplitLogTask.Err(ServerName originServer)
|
|
SplitLogTask.Owned(ServerName originServer)
|
|
SplitLogTask.Resigned(ServerName originServer)
|
|
SplitLogTask.Unassigned(ServerName originServer)
|
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 .META. or null if location is
not currently available. |
ServerName |
CatalogTracker.waitForMeta(long timeout)
Gets the current location for .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<String> disabledTables)
Performs a full scan of .META. , skipping regions from any
tables in the specified set of disabled tables. |
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<String> disabledTables,
boolean excludeOfflinedSplitParents)
Performs a full scan of .META. , skipping regions from any
tables in the specified set of disabled tables. |
static Pair<HRegionInfo,ServerName> |
MetaReader.getRegion(CatalogTracker catalogTracker,
byte[] regionName)
Gets the region info and assignment for the specified region. |
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
byte[] tableName,
boolean excludeOfflinedSplitParents)
|
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
String tableName)
|
Methods in org.apache.hadoop.hbase.catalog with parameters of type 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 META region in ROOT to be the specified server hostname and startcode. |
static void |
MetaEditor.updateRegionLocation(CatalogTracker catalogTracker,
HRegionInfo regionInfo,
ServerName sn,
long updateSeqNum)
Updates the location of the specified region in META to be the specified server hostname and startcode. |
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,
byte[] 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 |
HBaseAdmin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region. |
AdminProtocol |
HConnection.getAdmin(ServerName serverName)
Establishes a connection to the region server at the specified address. |
AdminProtocol |
HConnection.getAdmin(ServerName serverName,
boolean getMaster)
Establishes a connection to the region server at the specified address. |
ClientProtocol |
HConnection.getClient(ServerName serverName)
Establishes a connection to the region server at the specified address, and return a region client protocol. |
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server. |
boolean |
HConnection.isDeadServer(ServerName serverName)
|
Uses of ServerName in org.apache.hadoop.hbase.coprocessor |
---|
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type ServerName | |
---|---|
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.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.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<String,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()
|
Map<ServerName,ServerLoad> |
ServerManager.getOnlineServers()
|
List<ServerName> |
ServerManager.getOnlineServersList()
|
Map<HRegionInfo,ServerName> |
RegionStates.getRegionAssignments()
|
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. |
static TableLockManager |
TableLockManager.createTableLockManager(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zkWatcher,
ServerName serverName)
Creates and returns a TableLockManager according to the configuration |
void |
ServerManager.expireServer(ServerName serverName)
|
void |
DeadServer.finish(ServerName ignored)
|
SplitLogManager.TaskFinisher.Status |
SplitLogManager.TaskFinisher.finish(ServerName workerName,
String taskname)
finish the partially done task. |
ServerLoad |
ServerManager.getLoad(ServerName serverName)
|
void |
AssignmentManager.handleRegionsMergeReport(ServerName sn,
HRegionInfo merged,
HRegionInfo a,
HRegionInfo b)
Update inmemory structures. |
void |
AssignmentManager.handleSplitReport(ServerName sn,
HRegionInfo parent,
HRegionInfo a,
HRegionInfo b)
Update inmemory structures. |
boolean |
AssignmentManager.isCarryingMeta(ServerName serverName)
|
boolean |
DeadServer.isDeadServer(ServerName serverName)
|
boolean |
RegionState.isOnServer(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)
|
void |
MasterCoprocessorHost.postMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
boolean |
MasterCoprocessorHost.preMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
void |
ServerManager.processDeadServer(ServerName serverName)
|
List<HRegionInfo> |
AssignmentManager.processServerShutdown(ServerName sn)
Process shutdown server removing any assignments. |
void |
RegionStates.regionOnline(HRegionInfo hri,
ServerName serverName)
A region is online, won't be in transition any more. |
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)
Sends an OPEN RPC to the specified server to open the specified region. |
List<RegionOpeningState> |
ServerManager.sendRegionOpen(ServerName server,
List<Pair<HRegionInfo,Integer>> regionOpenInfos)
Sends an OPEN RPC to the specified server to open the specified region. |
void |
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. |
List<HRegionInfo> |
RegionStates.serverOffline(ServerName sn)
A server is offline, all regions on it are dead. |
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 |
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 |
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. |
void |
MasterFileSystem.splitLog(List<ServerName> serverNames)
|
void |
MasterFileSystem.splitLog(List<ServerName> serverNames,
org.apache.hadoop.fs.PathFilter filter)
This method is the base split method that splits HLog files matching a filter. |
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)
|
|
SplitLogManager(ZooKeeperWatcher zkw,
org.apache.hadoop.conf.Configuration conf,
Stoppable stopper,
MasterServices master,
ServerName serverName)
Wrapper around SplitLogManager.SplitLogManager(ZooKeeperWatcher zkw, Configuration conf,
Stoppable stopper, MasterServices master, ServerName serverName, 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,
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)
|
Uses of ServerName in org.apache.hadoop.hbase.master.balancer |
---|
Methods in org.apache.hadoop.hbase.master.balancer that return ServerName | |
---|---|
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,ServerName> |
BaseLoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates an immediate assignment plan to be used by a new master for regions in transition that do not have an already known destination. |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing assignment information from META, but adjusting for the specified list of available/online servers available for assignment. |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment. |
Method parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type ServerName | |
---|---|
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Given the cluster state this will try and approach an optimal balance. |
List<RegionPlan> |
DefaultLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterMap)
Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server. |
protected double |
StochasticLoadBalancer.computeCost(Map<HRegionInfo,ServerName> initialRegionMapping,
Map<ServerName,List<HRegionInfo>> clusterState)
This is the main cost function. |
protected double |
StochasticLoadBalancer.computeCost(Map<HRegionInfo,ServerName> initialRegionMapping,
Map<ServerName,List<HRegionInfo>> clusterState)
This is the main cost function. |
Map<HRegionInfo,ServerName> |
BaseLoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates an immediate assignment plan to be used by a new master for regions in transition that do not have an already known destination. |
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>> |
BaseLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment. |
Constructor parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type ServerName | |
---|---|
ClusterLoadState(Map<ServerName,List<HRegionInfo>> clusterState)
|
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 | |
---|---|
MergedRegionHandler(Server server,
AssignmentManager assignmentManager,
ServerName sn,
List<HRegionInfo> mergeRegions)
|
|
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)
|
|
SplitRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo,
ServerName sn,
List<HRegionInfo> daughters)
|
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(byte[] regionName,
int versionOfClosingNode,
ServerName destinationServer,
boolean transitionInZK)
|
static AdminProtos.GetServerInfoResponse |
ResponseConverter.buildGetServerInfoResponse(ServerName serverName,
int webuiPort)
A utility to build a GetServerInfoResponse. |
static boolean |
ProtobufUtil.closeRegion(AdminProtocol admin,
byte[] regionName,
int versionOfClosingNode,
ServerName destinationServer,
boolean transitionInZK)
A helper to close a region given a region name using admin protocol. |
static HBaseProtos.ServerName |
ProtobufUtil.toServerName(ServerName serverName)
Convert a ServerName to a protocol buffer ServerName |
Uses of ServerName in org.apache.hadoop.hbase.regionserver |
---|
Methods in org.apache.hadoop.hbase.regionserver that return ServerName | |
---|---|
ServerName |
HRegionServer.getServerName()
|
Methods in org.apache.hadoop.hbase.regionserver with parameters of type ServerName | |
---|---|
protected void |
HRegionServer.addToMovedRegions(String encodedName,
ServerName destination,
long closeSeqNum)
|
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. |
boolean |
HRegionServer.removeFromOnlineRegions(HRegion r,
ServerName destination)
|
Constructors in org.apache.hadoop.hbase.regionserver with parameters of type ServerName | |
---|---|
SplitLogWorker(ZooKeeperWatcher watcher,
org.apache.hadoop.conf.Configuration conf,
ServerName serverName,
LastSequenceId sequenceIdChecker)
|
|
SplitLogWorker(ZooKeeperWatcher watcher,
org.apache.hadoop.conf.Configuration conf,
ServerName serverName,
SplitLogWorker.TaskExecutor splitTaskExecutor)
|
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)
|
Uses of ServerName in org.apache.hadoop.hbase.replication |
---|
Methods in org.apache.hadoop.hbase.replication that return types with arguments of type ServerName | |
---|---|
List<ServerName> |
ReplicationPeer.getRegionServers()
Get a list of all the addresses of all the region servers for this peer cluster |
List<ServerName> |
ReplicationZookeeper.getSlavesAddresses(String peerClusterId)
Returns all region servers from given peer |
static List<ServerName> |
ReplicationZookeeper.listChildrenAndGetAsServerNames(ZooKeeperWatcher zkw,
String znode)
Lists the children of the specified znode, retrieving the data of each child as a server address. |
Method parameters in org.apache.hadoop.hbase.replication with type arguments of type ServerName | |
---|---|
void |
ReplicationPeer.setRegionServers(List<ServerName> regionServers)
Set the list of region servers for that peer |
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.postMove(ObserverContext<MasterCoprocessorEnvironment> c,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
|
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> |
RegionServerListTmpl.servers
|
protected List<ServerName> |
MasterStatusTmpl.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> |
RegionServerListTmpl.ImplData.getServers()
|
List<ServerName> |
MasterStatusTmpl.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)
|
RegionServerListTmpl |
RegionServerListTmpl.setServers(List<ServerName> p_servers)
|
void |
RegionServerListTmpl.ImplData.setServers(List<ServerName> servers)
|
MasterStatusTmpl |
MasterStatusTmpl.setServers(List<ServerName> p_servers)
|
void |
MasterStatusTmpl.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 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 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)
Sets the location of .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 |