Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.balancer | |
org.apache.hadoop.hbase.tmpl.master |
Modifier and Type | Class and Description |
---|---|
class |
ServerLoad
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
ServerMetrics instead. |
private static class |
ServerMetricsBuilder.ServerMetricsImpl |
Modifier and Type | Field and Description |
---|---|
private ServerMetrics |
ServerLoad.metrics
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
private Map<ServerName,ServerMetrics> |
ClusterMetricsBuilder.liveServerMetrics |
private Map<ServerName,ServerMetrics> |
ClusterMetricsBuilder.ClusterMetricsImpl.liveServerMetrics |
Modifier and Type | Method and Description |
---|---|
ServerMetrics |
ServerMetricsBuilder.build() |
static ServerMetrics |
ServerMetricsBuilder.of(ServerName sn) |
static ServerMetrics |
ServerMetricsBuilder.of(ServerName sn,
int versionNumber) |
static ServerMetrics |
ServerMetricsBuilder.toServerMetrics(org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.LiveServerInfo serverInfo) |
static ServerMetrics |
ServerMetricsBuilder.toServerMetrics(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoadPB) |
static ServerMetrics |
ServerMetricsBuilder.toServerMetrics(ServerName serverName,
int versionNumber,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoadPB) |
Modifier and Type | Method and Description |
---|---|
Map<ServerName,ServerMetrics> |
ClusterStatus.getLiveServerMetrics()
Deprecated.
|
Map<ServerName,ServerMetrics> |
ClusterMetrics.getLiveServerMetrics() |
Map<ServerName,ServerMetrics> |
ClusterMetricsBuilder.ClusterMetricsImpl.getLiveServerMetrics() |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad |
ServerMetricsBuilder.toServerLoad(ServerMetrics metrics) |
Modifier and Type | Method and Description |
---|---|
ClusterMetricsBuilder |
ClusterMetricsBuilder.setLiveServerMetrics(Map<ServerName,ServerMetrics> value) |
Constructor and Description |
---|
ServerLoad(ServerMetrics metrics)
Deprecated.
|
Constructor and Description |
---|
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort) |
Modifier and Type | Field and Description |
---|---|
private ConcurrentNavigableMap<ServerName,ServerMetrics> |
ServerManager.onlineServers
Map of registered servers to their current load
|
Modifier and Type | Method and Description |
---|---|
ServerMetrics |
ServerManager.getLoad(ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
Map<ServerName,ServerMetrics> |
ServerManager.getOnlineServers() |
Modifier and Type | Method and Description |
---|---|
(package private) boolean |
ServerManager.checkAndRecordNewServer(ServerName serverName,
ServerMetrics sl)
Check is a server of same host and port already exists,
if not, or the existed one got a smaller start code, record it.
|
(package private) void |
ServerManager.recordNewServerWithLock(ServerName serverName,
ServerMetrics sl)
Adds the onlineServers list.
|
void |
ServerManager.regionServerReport(ServerName sn,
ServerMetrics sl) |
private void |
ServerManager.updateLastFlushedSequenceIds(ServerName sn,
ServerMetrics hsl)
Updates last flushed sequence Ids for the regions on server sn
|
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
ServerManager.getOnlineServersListWithPredicator(List<ServerName> keys,
Predicate<ServerMetrics> idleServerPredicator) |
Modifier and Type | Field and Description |
---|---|
(package private) static Predicate<ServerMetrics> |
BaseLoadBalancer.IDLE_SERVER_PREDICATOR |
Modifier and Type | Method and Description |
---|---|
private void |
RegionServerListTmplImpl.__jamon_innerUnit__serverNameLink(Writer jamonWriter,
ServerName serverName,
ServerMetrics serverLoad) |
Modifier and Type | Method and Description |
---|---|
private void |
RSGroupListTmplImpl.__jamon_innerUnit__rsgroup_baseStats(Writer jamonWriter,
RSGroupInfo[] rsGroupInfos,
Map<Address,ServerMetrics> collectServers) |
private void |
RSGroupListTmplImpl.__jamon_innerUnit__rsgroup_compactStats(Writer jamonWriter,
RSGroupInfo[] rsGroupInfos,
Map<Address,ServerMetrics> collectServers) |
private void |
RSGroupListTmplImpl.__jamon_innerUnit__rsgroup_memoryStats(Writer jamonWriter,
RSGroupInfo[] rsGroupInfos,
Map<Address,ServerMetrics> collectServers) |
private void |
RSGroupListTmplImpl.__jamon_innerUnit__rsgroup_requestStats(Writer jamonWriter,
RSGroupInfo[] rsGroupInfos,
Map<Address,ServerMetrics> collectServers) |
private void |
RSGroupListTmplImpl.__jamon_innerUnit__rsgroup_storeStats(Writer jamonWriter,
RSGroupInfo[] rsGroupInfos,
Map<Address,ServerMetrics> collectServers) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.