A C D E F G H I M O P R S T U V W 
All Classes All Packages

A

addDataNodeConfigChangeListener(DataNodeConfigChangeListener) - Method in class com.github.ambry.clustermap.CompositeDataNodeConfigSource
 
addDataNodeConfigChangeListener(DataNodeConfigChangeListener) - Method in class com.github.ambry.clustermap.InstanceConfigToDataNodeConfigAdapter
 
ADMIN_CONFIG_ZNODE_PATH - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 
AmbryPartition - Class in com.github.ambry.clustermap
PartitionId implementation to use within dynamic cluster managers.
AmbryPartitionStateModel - Class in com.github.ambry.clustermap
 
AmbryReplica - Class in com.github.ambry.clustermap
ReplicaId implementation to use within dynamic cluster managers.
AmbryReplicaSyncUpManager - Class in com.github.ambry.clustermap
An implementation of ReplicaSyncUpManager that helps track replica catchup state.
AmbryReplicaSyncUpManager(ClusterMapConfig) - Constructor for class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 

C

close() - Method in class com.github.ambry.clustermap.CompositeDataNodeConfigSource
 
close() - Method in class com.github.ambry.clustermap.HelixClusterManager
Disconnect from the HelixManagers associated with each and every datacenter.
close() - Method in class com.github.ambry.clustermap.HelixParticipant
Disconnect from the HelixManager.
close() - Method in class com.github.ambry.clustermap.InstanceConfigToDataNodeConfigAdapter
 
close() - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
Cloud_Replica_Keyword - Static variable in class com.github.ambry.clustermap.CloudReplica
 
CloudDataNode - Class in com.github.ambry.clustermap
DataNodeId implementation to use within VCR cluster.
CloudDataNode(CloudConfig, ClusterMapConfig) - Constructor for class com.github.ambry.clustermap.CloudDataNode
Instantiate a CloudDataNode object.
CloudDataNode(String, Port, Port, Port, String, ClusterMapConfig) - Constructor for class com.github.ambry.clustermap.CloudDataNode
Instantiate a CloudDataNode object from hostname, port and datacentername.
CloudReplica - Class in com.github.ambry.clustermap
ReplicaId implementation to use within virtual cloud replicator.
CloudReplica(PartitionId, DataNodeId) - Constructor for class com.github.ambry.clustermap.CloudReplica
Instantiate an CloudReplica instance.
ClusterChangeHandler - Interface in com.github.ambry.clustermap
General handler that handles any resource or state changes in cluster.
ClusterMapUtils - Class in com.github.ambry.clustermap
A class with clustermap related utility methods for use by other classes.
ClusterMapUtils() - Constructor for class com.github.ambry.clustermap.ClusterMapUtils
 
ClusterMapUtils.DcZkInfo - Class in com.github.ambry.clustermap
Stores all zk related info for a DC.
com.github.ambry.clustermap - package com.github.ambry.clustermap
 
compareTo(PartitionId) - Method in class com.github.ambry.clustermap.AmbryPartition
 
compareTo(PartitionId) - Method in class com.github.ambry.clustermap.Partition
 
CompositeClusterAgentsFactory - Class in com.github.ambry.clustermap
A factory that creates a CompositeClusterManager and ClusterParticipant.
CompositeClusterAgentsFactory(ClusterMapConfig, String, String) - Constructor for class com.github.ambry.clustermap.CompositeClusterAgentsFactory
Create an instance of this class.
CompositeDataNodeConfigSource - Class in com.github.ambry.clustermap
An implementation of DataNodeConfigSource that combines two sources.
CompositeDataNodeConfigSource(DataNodeConfigSource, DataNodeConfigSource, Time, DataNodeConfigSourceMetrics) - Constructor for class com.github.ambry.clustermap.CompositeDataNodeConfigSource
 

D

DataNodeConfigChangeListener - Interface in com.github.ambry.clustermap
Interface to implement a listener that will be called on updates to DataNodeConfigs.
DefaultLeaderStandbyStateModel - Class in com.github.ambry.clustermap
A default LeaderStandby StateModel to use when the Ambry participants (datanodes) register to Helix.
DynamicClusterChangeHandler - Class in com.github.ambry.clustermap
A more dynamic implementation of HelixClusterChangeHandler which supports adding new nodes/partitions at runtime.

E

equals(Object) - Method in class com.github.ambry.clustermap.AmbryPartition
 
equals(Object) - Method in class com.github.ambry.clustermap.Partition
 

F

FixedBackoffResourceStatePolicyFactory - Class in com.github.ambry.clustermap
 
FixedBackoffResourceStatePolicyFactory(Resource, HardwareState, ClusterMapConfig) - Constructor for class com.github.ambry.clustermap.FixedBackoffResourceStatePolicyFactory
 

G

get(String) - Method in class com.github.ambry.clustermap.CompositeDataNodeConfigSource
 
get(String) - Method in class com.github.ambry.clustermap.InstanceConfigToDataNodeConfigAdapter
 
getAllDataNodes() - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
 
getAllDataNodes() - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getAllDataNodes() - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getAllPartitionIds(String) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getAllPartitionIds(String) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
Get all partition ids from both the underlying StaticClusterManager.
getBootstrapReplica(String, DataNodeId) - Method in class com.github.ambry.clustermap.HelixClusterManager
To create bootstrap replica, HelixClusterManager needs to fetch replica info (i.e.
getBootstrapReplica(String, DataNodeId) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getBytes() - Method in class com.github.ambry.clustermap.AmbryPartition
 
getBytes() - Method in class com.github.ambry.clustermap.Partition
 
getCapacityInBytes() - Method in class com.github.ambry.clustermap.AmbryReplica
 
getCapacityInBytes() - Method in class com.github.ambry.clustermap.CloudReplica
 
getClusterMap() - Method in class com.github.ambry.clustermap.CompositeClusterAgentsFactory
Create and return a CompositeClusterManager.
getClusterMap() - Method in class com.github.ambry.clustermap.HelixClusterAgentsFactory
 
getClusterMap() - Method in class com.github.ambry.clustermap.RecoveryTestClusterAgentsFactory
Create and return a RecoveryTestClusterManager.
getClusterMap() - Method in class com.github.ambry.clustermap.StaticClusterAgentsFactory
 
getClusterParticipants() - Method in class com.github.ambry.clustermap.CompositeClusterAgentsFactory
 
getClusterParticipants() - Method in class com.github.ambry.clustermap.HelixClusterAgentsFactory
 
getClusterParticipants() - Method in class com.github.ambry.clustermap.RecoveryTestClusterAgentsFactory
 
getClusterParticipants() - Method in class com.github.ambry.clustermap.StaticClusterAgentsFactory
 
getClusterSpectator(CloudConfig, ClusterMapConfig) - Method in class com.github.ambry.clustermap.HelixClusterSpectatorFactory
 
getDatacenterName() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getDatacenterName(byte) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getDatacenterName(byte) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getDataNode(String) - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
Get ambry data node associated with given instance name.
getDataNode(String) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getDataNode(String) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getDataNodeConfigSource(ClusterMapConfig, String, DataNodeConfigSourceMetrics) - Method in class com.github.ambry.clustermap.HelixFactory
 
getDataNodeId() - Method in class com.github.ambry.clustermap.AmbryReplica
 
getDataNodeId() - Method in class com.github.ambry.clustermap.CloudReplica
 
getDataNodeId(String, int) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getDataNodeId(String, int) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
Return the DataNodeId associated with the given hostname and port in the underlying StaticClusterManager.
getDataNodeIds() - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getDataNodeIds() - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
The list of DataNodeIds present in the underlying HelixClusterManager
getDataNodeToDisksMap() - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
 
getDataNodeToDisksMap() - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getDataNodeToDisksMap() - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getDcId() - Method in class com.github.ambry.clustermap.ClusterMapUtils.DcZkInfo
 
getDcName() - Method in class com.github.ambry.clustermap.ClusterMapUtils.DcZkInfo
 
getDcName(InstanceConfig) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Get the datacenter name associated with the given instance.
getDcName(ZNRecord) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Get the datacenter name associated with the given instance.
getDisabledReplicas() - Method in class com.github.ambry.clustermap.HelixParticipant
 
getDisabledReplicas(InstanceConfig) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Get the list of disabled replicas on a given instance.
getDisabledReplicas(ZNRecord) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Get the list of disabled replicas on a given instance.
getDiskId() - Method in class com.github.ambry.clustermap.AmbryReplica
 
getDiskId() - Method in class com.github.ambry.clustermap.CloudReplica
 
getDisks(AmbryDataNode) - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
Get all disks belong to given data node.
getDisks(AmbryDataNode) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getDisks(AmbryDataNode) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getErrorCount() - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
 
getErrorCount() - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getErrorCount() - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getFullyQualifiedDomainName(String) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Converts a hostname into a canonical hostname.
getHelixAdmin() - Method in class com.github.ambry.clustermap.HelixParticipant
Exposed for testing
getHelixAdmin(String) - Method in class com.github.ambry.clustermap.HelixAdminFactory
Get a reference to a HelixAdmin
getHostname() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getHttp2Port() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getHttp2PortStr(InstanceConfig) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Get the http2 port associated with the given instance (if any).
getInstanceName(String, Integer) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Construct and return the instance name given the host and port.
getLocalDatacenterId() - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getLocalDatacenterId() - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getMetricRegistry() - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getMetricRegistry() - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getMountPath() - Method in class com.github.ambry.clustermap.CloudReplica
 
getPartitionClass() - Method in class com.github.ambry.clustermap.AmbryPartition
 
getPartitionClass() - Method in class com.github.ambry.clustermap.Partition
 
getPartitionId() - Method in class com.github.ambry.clustermap.AmbryReplica
 
getPartitionId() - Method in class com.github.ambry.clustermap.CloudReplica
 
getPartitionIdFromStream(InputStream) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getPartitionIdFromStream(InputStream) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getPartitionState() - Method in class com.github.ambry.clustermap.AmbryPartition
 
getPartitionState() - Method in class com.github.ambry.clustermap.Partition
 
getPartitionStateChangeListeners() - Method in class com.github.ambry.clustermap.HelixParticipant
 
getPartitionToDeactivationLatch() - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
getPartitionToDisconnectionLatch() - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
getPartitionToResourceMap() - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
 
getPartitionToResourceMap() - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getPartitionToResourceMap() - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getPeerReplicaIds() - Method in class com.github.ambry.clustermap.AmbryReplica
 
getPeerReplicaIds() - Method in class com.github.ambry.clustermap.CloudReplica
 
getPort() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getPortToConnectTo() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getRackId() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getRandomWritablePartition(String, List<PartitionId>) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getRandomWritablePartition(String, List<PartitionId>) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getReplicaId(AmbryDataNode, String) - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
Get AmbryReplica on given node that belongs to specified partition.
getReplicaId(AmbryDataNode, String) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getReplicaId(AmbryDataNode, String) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getReplicaIds() - Method in class com.github.ambry.clustermap.AmbryPartition
 
getReplicaIds() - Method in class com.github.ambry.clustermap.Partition
 
getReplicaIds(AmbryDataNode) - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
Get all replicas on given node.
getReplicaIds(AmbryDataNode) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getReplicaIds(AmbryDataNode) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getReplicaIds(DataNodeId) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getReplicaIds(DataNodeId) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
Get the list of ReplicaIds associated with the given DataNodeId in the underlying StaticClusterManager.
getReplicaIdsByState(AmbryPartition, ReplicaState) - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
Get replicas of given partition from this datacenter that are in required state
getReplicaIdsByState(ReplicaState, String) - Method in class com.github.ambry.clustermap.AmbryPartition
 
getReplicaIdsByState(ReplicaState, String) - Method in class com.github.ambry.clustermap.Partition
 
getReplicaPath() - Method in class com.github.ambry.clustermap.CloudReplica
 
getReplicaSyncUpManager() - Method in class com.github.ambry.clustermap.HelixParticipant
 
getReplicaType() - Method in class com.github.ambry.clustermap.CloudReplica
 
getReplicaType() - Method in class com.github.ambry.clustermap.ClusterMapUtils.DcZkInfo
 
getResourceName() - Method in class com.github.ambry.clustermap.AmbryPartition
 
getResourceStatePolicy() - Method in class com.github.ambry.clustermap.FixedBackoffResourceStatePolicyFactory
 
getRoutingTableSnapshot() - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
getRoutingTableSnapshot() - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
getSealedReplicas() - Method in class com.github.ambry.clustermap.HelixParticipant
 
getSnapshot() - Method in class com.github.ambry.clustermap.AmbryPartition
 
getSnapshot() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getSnapshot() - Method in class com.github.ambry.clustermap.CloudReplica
 
getSnapshot() - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getSnapshot() - Method in class com.github.ambry.clustermap.Partition
 
getSnapshot() - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getSSLPort() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getSslPortStr(InstanceConfig) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Get the ssl port associated with the given instance (if any).
getState() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getStoppedReplicas() - Method in class com.github.ambry.clustermap.HelixParticipant
 
getWritablePartitionIds(String) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
getWritablePartitionIds(String) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
getXid() - Method in class com.github.ambry.clustermap.CloudDataNode
 
getZkConnectStrs() - Method in class com.github.ambry.clustermap.ClusterMapUtils.DcZkInfo
 
getZKHelixManager(String, String, InstanceType, String) - Method in class com.github.ambry.clustermap.HelixFactory
Get a reference to a HelixManager
getZkHelixManagerAndConnect(String, String, InstanceType, String) - Method in class com.github.ambry.clustermap.HelixFactory
Get a reference to a HelixManager and connect to it, if not already connected

H

hasDatacenter(String) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
hasDatacenter(String) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
Check for existence of the given datacenter from both the static and the helix based cluster managers and update a metric if there is a mismatch.
hashCode() - Method in class com.github.ambry.clustermap.AmbryPartition
 
hashCode() - Method in class com.github.ambry.clustermap.Partition
 
hasHttp2Port() - Method in class com.github.ambry.clustermap.CloudDataNode
 
hasSSLPort() - Method in class com.github.ambry.clustermap.CloudDataNode
 
HelixAdminFactory - Class in com.github.ambry.clustermap
A factory class to construct and get a reference to a HelixAdmin
HelixAdminFactory() - Constructor for class com.github.ambry.clustermap.HelixAdminFactory
 
HelixBootstrapUpgradeUtil - Class in com.github.ambry.clustermap
A class to bootstrap static cluster map information into Helix.
HelixClusterAgentsFactory - Class in com.github.ambry.clustermap
A factory class to construct HelixClusterManager and HelixParticipant.
HelixClusterAgentsFactory(ClusterMapConfig, String, String) - Constructor for class com.github.ambry.clustermap.HelixClusterAgentsFactory
Construct an object of this factory.
HelixClusterAggregator - Class in com.github.ambry.clustermap
Responsible for performing cluster wide stats aggregation.
HelixClusterManager - Class in com.github.ambry.clustermap
An implementation of ClusterMap that makes use of Helix to dynamically manage the cluster information.
HelixClusterManager(ClusterMapConfig, String, HelixFactory, MetricRegistry) - Constructor for class com.github.ambry.clustermap.HelixClusterManager
Instantiate a HelixClusterManager.
HelixClusterSpectator - Class in com.github.ambry.clustermap
Spectator for vcr helix cluster.
HelixClusterSpectator(CloudConfig, ClusterMapConfig) - Constructor for class com.github.ambry.clustermap.HelixClusterSpectator
Constructor for HelixClusterSpectator.
HelixClusterSpectatorFactory - Class in com.github.ambry.clustermap
A factory to create ClusterSpectator object.
HelixClusterSpectatorFactory() - Constructor for class com.github.ambry.clustermap.HelixClusterSpectatorFactory
 
HelixFactory - Class in com.github.ambry.clustermap
A factory class to construct and get a reference to a HelixManager
HelixFactory() - Constructor for class com.github.ambry.clustermap.HelixFactory
 
HelixParticipant - Class in com.github.ambry.clustermap
An implementation of ClusterParticipant that registers as a participant to a Helix cluster.
HelixParticipant(ClusterMapConfig, HelixFactory, MetricRegistry, String, boolean) - Constructor for class com.github.ambry.clustermap.HelixParticipant
Instantiate a HelixParticipant.

I

initiateBootstrap(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
initiateDeactivation(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
initiateDisconnection(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
InstanceConfigToDataNodeConfigAdapter - Class in com.github.ambry.clustermap
An implementation of DataNodeConfigSource that converts between InstanceConfigs received by an InstanceConfigChangeListener and DataNodeConfigs.
InstanceConfigToDataNodeConfigAdapter(HelixManager, ClusterMapConfig) - Constructor for class com.github.ambry.clustermap.InstanceConfigToDataNodeConfigAdapter
 
isDown() - Method in class com.github.ambry.clustermap.AmbryReplica
 
isDown() - Method in class com.github.ambry.clustermap.CloudReplica
 
isEqual(String) - Method in class com.github.ambry.clustermap.AmbryPartition
 
isEqual(String) - Method in class com.github.ambry.clustermap.Partition
 
isSealed() - Method in class com.github.ambry.clustermap.AmbryReplica
 
isSealed() - Method in class com.github.ambry.clustermap.CloudReplica
 
isSyncUpComplete(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 

M

markDisablePartitionComplete() - Method in class com.github.ambry.clustermap.HelixParticipant
Mark disablePartitionsComplete = true, this is exposed for testing only.
markDiskDown() - Method in class com.github.ambry.clustermap.CloudReplica
 
markDiskUp() - Method in class com.github.ambry.clustermap.CloudReplica
 

O

onBecomeBootstrapFromOffline(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeDroppedFromError(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeDroppedFromOffline(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeInactiveFromStandby(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeLeaderFromStandby(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeLeaderFromStandby(Message, NotificationContext) - Method in class com.github.ambry.clustermap.DefaultLeaderStandbyStateModel
 
onBecomeOfflineFromError(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeOfflineFromInactive(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeOfflineFromLeader(Message, NotificationContext) - Method in class com.github.ambry.clustermap.DefaultLeaderStandbyStateModel
 
onBecomeOfflineFromStandby(Message, NotificationContext) - Method in class com.github.ambry.clustermap.DefaultLeaderStandbyStateModel
 
onBecomeStandbyFromBootstrap(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeStandbyFromLeader(Message, NotificationContext) - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
onBecomeStandbyFromLeader(Message, NotificationContext) - Method in class com.github.ambry.clustermap.DefaultLeaderStandbyStateModel
 
onBecomeStandbyFromOffline(Message, NotificationContext) - Method in class com.github.ambry.clustermap.DefaultLeaderStandbyStateModel
 
onBootstrapComplete(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
This method will count down the latch associated with given replica and unblock external service waiting on this latch.
onBootstrapError(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
This method will count down latch and terminates bootstrap.
onDataNodeConfigChange(Iterable<DataNodeConfig>) - Method in interface com.github.ambry.clustermap.DataNodeConfigChangeListener
Called when there is a relevant update to one or more DataNodeConfigs.
onDataNodeConfigChange(Iterable<DataNodeConfig>) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
Handle any DataNodeConfig related change in current datacenter.
onDataNodeConfigChange(Iterable<DataNodeConfig>) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
onDeactivationComplete(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
onDeactivationError(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
onDisconnectionComplete(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
onDisconnectionError(ReplicaId) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
onIdealStateChange(List<IdealState>, NotificationContext) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
Triggered whenever the IdealState in current data center has changed (for now, it is usually updated by Helix Bootstrap tool).
onIdealStateChange(List<IdealState>, NotificationContext) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
Triggered whenever the IdealState in current data center has changed (for now, it is usually updated by Helix Bootstrap tool).
onInstanceConfigChange(List<InstanceConfig>, NotificationContext) - Method in class com.github.ambry.clustermap.HelixClusterSpectator
 
onLiveInstanceChange(List<LiveInstance>, NotificationContext) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
Triggered whenever there is a change in the list of live instances.
onLiveInstanceChange(List<LiveInstance>, NotificationContext) - Method in class com.github.ambry.clustermap.HelixClusterSpectator
 
onLiveInstanceChange(List<LiveInstance>, NotificationContext) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
Triggered whenever there is a change in the list of live instances.
onPartitionBecomeBootstrapFromOffline(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeDroppedFromError(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeDroppedFromOffline(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeInactiveFromStandby(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeLeaderFromStandby(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeOfflineFromError(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeOfflineFromInactive(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeStandbyFromBootstrap(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onPartitionBecomeStandbyFromLeader(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onReplicaEvent(ReplicaId, ReplicaEventType) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
onReplicaEvent(ReplicaId, ReplicaEventType) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
Relay the event to both the underlying StaticClusterManager and the underlying HelixClusterManager.
onReset(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 
onRoutingTableChange(RoutingTableSnapshot, Object) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
Triggered whenever the state of replica in cluster has changed.
onRoutingTableChange(RoutingTableSnapshot, Object) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
Triggered whenever the state of replica in cluster has changed.

P

parseDcJsonAndPopulateDcInfo(String) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Parses DC information JSON string and returns a map of datacenter name to ClusterMapUtils.DcZkInfo.
participantMetrics - Variable in class com.github.ambry.clustermap.HelixParticipant
 
participate(List<AmbryHealthReport>, Callback<StatsSnapshot>) - Method in class com.github.ambry.clustermap.HelixParticipant
Initiate the participation by registering via the HelixManager as a participant to the associated Helix cluster.
Partition - Class in com.github.ambry.clustermap
An extension of PartitionId to be used within the StaticClusterManager.
Partition(long, String, PartitionState, long) - Constructor for class com.github.ambry.clustermap.Partition
 
PARTITION_DISABLED_STR - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 
PARTITION_DISABLED_ZNODE_PATH - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 
PARTITION_OVERRIDE_STR - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 
PARTITION_OVERRIDE_ZNODE_PATH - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 
PROPERTYSTORE_STR - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 

R

RecoveryTestClusterAgentsFactory - Class in com.github.ambry.clustermap
A factory class to construct RecoveryTestClusterManager and a no op ClusterParticipant.
RecoveryTestClusterAgentsFactory(ClusterMapConfig, String, String) - Constructor for class com.github.ambry.clustermap.RecoveryTestClusterAgentsFactory
Create an instance of this class.
RecoveryTestClusterManager - Class in com.github.ambry.clustermap
A cluster manager that is a composed of a StaticClusterManager and a HelixClusterManager.
registerClusterMapListener(ClusterMapChangeListener) - Method in interface com.github.ambry.clustermap.ClusterChangeHandler
Register a listener of cluster map for any changes.
registerClusterMapListener(ClusterMapChangeListener) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
registerClusterMapListener(ClusterMapChangeListener) - Method in class com.github.ambry.clustermap.HelixClusterManager
 
registerClusterMapListener(ClusterMapChangeListener) - Method in class com.github.ambry.clustermap.RecoveryTestClusterManager
 
registerClusterMapListener(ClusterMapChangeListener) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
registerInstanceConfigChangeListener(InstanceConfigChangeListener) - Method in class com.github.ambry.clustermap.HelixClusterSpectator
 
registerLiveInstanceChangeListener(LiveInstanceChangeListener) - Method in class com.github.ambry.clustermap.HelixClusterSpectator
 
registerPartitionStateChangeListener(StateModelListenerType, PartitionStateChangeListener) - Method in class com.github.ambry.clustermap.HelixParticipant
 
REPLICA_ADDITION_STR - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 
REPLICA_ADDITION_ZNODE_PATH - Static variable in class com.github.ambry.clustermap.ClusterMapUtils
 
reset() - Method in class com.github.ambry.clustermap.AmbryPartitionStateModel
 
reset() - Method in class com.github.ambry.clustermap.DefaultLeaderStandbyStateModel
 
resetPartitionState(String) - Method in class com.github.ambry.clustermap.HelixParticipant
 

S

set(DataNodeConfig) - Method in class com.github.ambry.clustermap.CompositeDataNodeConfigSource
 
set(DataNodeConfig) - Method in class com.github.ambry.clustermap.InstanceConfigToDataNodeConfigAdapter
 
setInitialLocalPartitions(Collection<String>) - Method in class com.github.ambry.clustermap.HelixParticipant
 
setReplicaDisabledState(ReplicaId, boolean) - Method in class com.github.ambry.clustermap.HelixParticipant
 
setReplicaSealedState(ReplicaId, boolean) - Method in class com.github.ambry.clustermap.HelixParticipant
 
setReplicaStoppedState(List<ReplicaId>, boolean) - Method in class com.github.ambry.clustermap.HelixParticipant
 
setRoutingTableSnapshot(RoutingTableSnapshot) - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
setRoutingTableSnapshot(RoutingTableSnapshot) - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
SimpleClusterChangeHandler - Class in com.github.ambry.clustermap
An implementation of HelixClusterChangeHandler to register as listener for Helix related changes in each datacenter.
spectate() - Method in class com.github.ambry.clustermap.HelixClusterSpectator
 
StaticClusterAgentsFactory - Class in com.github.ambry.clustermap
A class used to create the StaticClusterManager and ClusterParticipant.
StaticClusterAgentsFactory(ClusterMapConfig, String, String) - Constructor for class com.github.ambry.clustermap.StaticClusterAgentsFactory
Instantiate an instance of this factory.
supportsStateChanges() - Method in class com.github.ambry.clustermap.HelixParticipant
 

T

toPathString() - Method in class com.github.ambry.clustermap.AmbryPartition
Construct name based on the id that is appropriate for use as a file or directory name.
toPathString() - Method in class com.github.ambry.clustermap.Partition
Construct name based on Partition ID appropriate for use as a file or directory name.
toString() - Method in class com.github.ambry.clustermap.AmbryPartition
 
toString() - Method in class com.github.ambry.clustermap.CloudDataNode
 
toString() - Method in class com.github.ambry.clustermap.CloudReplica
 
toString() - Method in class com.github.ambry.clustermap.Partition
Generates a String representation that uniquely identifies this partition.

U

updateDataNodeInfoInCluster(ReplicaId, boolean) - Method in class com.github.ambry.clustermap.HelixParticipant
 
updateLagBetweenReplicas(ReplicaId, ReplicaId, long) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 

V

validateHostName(Boolean, String) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Validate hostName.
validatePorts(Port, Port, Port, boolean) - Static method in class com.github.ambry.clustermap.ClusterMapUtils
Validate plainTextPort, sslPort and http2Port.

W

waitBootstrapCompleted(String) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
The method is blocked on a CountDownLatch until the bootstrap is complete
waitDeactivationCompleted(String) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
waitDisconnectionCompleted(String) - Method in class com.github.ambry.clustermap.AmbryReplicaSyncUpManager
 
waitForInitNotification() - Method in class com.github.ambry.clustermap.DynamicClusterChangeHandler
 
waitForInitNotification() - Method in class com.github.ambry.clustermap.SimpleClusterChangeHandler
 
A C D E F G H I M O P R S T U V W 
All Classes All Packages