A B C D E F G H I J K L M N O P Q R S T U V W Y 
All Classes All Packages

A

ABIVersion - Enum in org.opendaylight.controller.cluster.access
Enumeration of all ABI versions supported by this implementation of the client access API.
abort() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractClientHandle
Release all state associated with this transaction.
abort() - Method in class org.opendaylight.controller.cluster.datastore.ThreePhaseCommitCohortProxy
 
abort(FutureCallback<Void>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
 
ABORT - org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
Abort protocol.
ABORTED - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
AbortLocalTransactionRequest - Class in org.opendaylight.controller.cluster.access.commands
Request to abort a local transaction.
AbortLocalTransactionRequest(TransactionIdentifier, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.AbortLocalTransactionRequest
 
AbortTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
 
AbortTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
 
AbortTransaction(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
 
AbortTransactionPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
Payload persisted when a transaction is aborted.
AbortTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
AbortTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbortTransactionReply
 
abortTransfer() - Method in class org.opendaylight.controller.cluster.raft.RaftActorLeadershipTransferCohort
This method is invoked to abort leadership transfer on failure.
AbstractBatchedModificationsCursor - Class in org.opendaylight.controller.cluster.datastore.utils
Base class for a DataTreeModificationCursor that publishes to BatchedModifications instance(s).
AbstractBatchedModificationsCursor() - Constructor for class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
 
AbstractBuilder() - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
AbstractBuilder(Class<? extends S>) - Constructor for class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
AbstractClientActor - Class in org.opendaylight.controller.cluster.access.client
Frontend actor which takes care of persisting generations and creates an appropriate ClientIdentifier.
AbstractClientActor(FrontendIdentifier) - Constructor for class org.opendaylight.controller.cluster.access.client.AbstractClientActor
 
AbstractClientActorBehavior<C extends org.opendaylight.controller.cluster.access.client.AbstractClientActorContext> - Class in org.opendaylight.controller.cluster.access.client
Base behavior attached to AbstractClientActor.
AbstractClientConnection<T extends BackendInfo> - Class in org.opendaylight.controller.cluster.access.client
Base class for a connection to the backend.
AbstractClientHandle<T extends org.opendaylight.controller.cluster.databroker.actors.dds.AbstractProxyTransaction> - Class in org.opendaylight.controller.cluster.databroker.actors.dds
Abstract superclass of both ClientSnapshot and ClientTransaction.
AbstractClientHistory - Class in org.opendaylight.controller.cluster.databroker.actors.dds
Abstract base class for client view of a history.
AbstractConfig - Class in org.opendaylight.controller.cluster.common.actor
 
AbstractConfig(Config) - Constructor for class org.opendaylight.controller.cluster.common.actor.AbstractConfig
 
AbstractConfig.Builder<T extends AbstractConfig.Builder<T>> - Class in org.opendaylight.controller.cluster.common.actor
 
AbstractDataStore - Class in org.opendaylight.controller.cluster.datastore
Base implementation of a distributed DOMStore.
AbstractDataStore(ActorSystem, ClusterWrapper, Configuration, DatastoreContextFactory, DatastoreSnapshot) - Constructor for class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
AbstractDataStore(ActorUtils, ClientIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
AbstractDataStore(ActorUtils, ClientIdentifier, DataStoreClient) - Constructor for class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
AbstractDataStoreClientActor - Class in org.opendaylight.controller.cluster.databroker.actors.dds
 
AbstractDataTreeModificationCursor - Class in org.opendaylight.controller.cluster.datastore.util
Abstract DataTreeModificationCursor which tracks the current path.
AbstractDataTreeModificationCursor() - Constructor for class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
AbstractDOMBroker - Class in org.opendaylight.controller.cluster.databroker
 
AbstractDOMBroker(Map<LogicalDatastoreType, DOMStore>) - Constructor for class org.opendaylight.controller.cluster.databroker.AbstractDOMBroker
 
AbstractDOMBrokerTransaction<T extends DOMStoreTransaction> - Class in org.opendaylight.controller.cluster.databroker
 
AbstractDOMBrokerTransaction(Object, Map<LogicalDatastoreType, ? extends DOMStoreTransactionFactory>) - Constructor for class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
Creates new composite Transactions.
AbstractDOMBrokerWriteTransaction<T extends DOMStoreWriteTransaction> - Class in org.opendaylight.controller.cluster.databroker
 
AbstractDOMBrokerWriteTransaction(Object, Map<LogicalDatastoreType, ? extends DOMStoreTransactionFactory>, AbstractDOMTransactionFactory<?>) - Constructor for class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerWriteTransaction
 
AbstractDOMTransactionFactory<T extends DOMStoreTransactionFactory> - Class in org.opendaylight.controller.cluster.databroker
 
AbstractDOMTransactionFactory(Map<LogicalDatastoreType, T>) - Constructor for class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
 
AbstractExecute<T extends NormalizedNode<?,​?>> - Class in org.opendaylight.controller.remote.rpc.messages
An abstract base class for invocation requests.
AbstractIdentifiablePayload<T extends Identifier> - Class in org.opendaylight.controller.cluster.datastore.persisted
Abstract base class for Payloads which hold a single Identifier.
AbstractIdentifiablePayload.AbstractProxy<T extends Identifier> - Class in org.opendaylight.controller.cluster.datastore.persisted
 
AbstractLeader - Class in org.opendaylight.controller.cluster.raft.behaviors
The behavior of a RaftActor when it is in the Leader state.
AbstractLeader(RaftActorContext, RaftState) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
AbstractLeader(RaftActorContext, RaftState, AbstractLeader) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
AbstractLocalTransactionRequest<T extends AbstractLocalTransactionRequest<T>> - Class in org.opendaylight.controller.cluster.access.commands
Abstract base class for Requests involving specific transactions local to a member node.
AbstractModification - Class in org.opendaylight.controller.cluster.datastore.modification
Base class to be used for all simple modifications that can be applied to a DOMStoreTransaction.
AbstractModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
 
AbstractModification(short, YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
 
AbstractModification(YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
 
AbstractMXBean - Class in org.opendaylight.controller.md.sal.common.util.jmx
Abstract base for an MXBean implementation class.
AbstractMXBean(String, String, String) - Constructor for class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
Constructor.
AbstractProxy() - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.AbstractProxy
 
AbstractProxy(byte[]) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.AbstractProxy
 
AbstractRaftActorBehavior - Class in org.opendaylight.controller.cluster.raft.behaviors
Abstract class that provides common code for a RaftActor behavior.
AbstractRaftRPC - Class in org.opendaylight.controller.cluster.raft.messages
 
AbstractRead<T> - Class in org.opendaylight.controller.cluster.datastore.messages
Abstract base class for ReadData and DataExists messages.
AbstractRead() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
AbstractRead(YangInstanceIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
AbstractReadPathTransactionRequest<T extends AbstractReadPathTransactionRequest<T>> - Class in org.opendaylight.controller.cluster.access.commands
Abstract base class for TransactionRequests accessing data as visible in the isolated context of a particular transaction.
AbstractReadTransactionRequest<T extends AbstractReadTransactionRequest<T>> - Class in org.opendaylight.controller.cluster.access.commands
Abstract base class for TransactionRequests accessing transaction state without modifying it.
AbstractReplicatedLogImpl - Class in org.opendaylight.controller.cluster.raft
Abstract class handling the mapping of logical LogEntry Index and the physical list index.
AbstractReplicatedLogImpl() - Constructor for class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
AbstractReplicatedLogImpl(long, long, List<ReplicatedLogEntry>, String) - Constructor for class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
AbstractRequestFailureProxy<T extends WritableIdentifier,​C extends RequestFailure<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
Abstract Externalizable proxy for use with RequestFailure subclasses.
AbstractRequestFailureProxy() - Constructor for class org.opendaylight.controller.cluster.access.concepts.AbstractRequestFailureProxy
 
AbstractRequestFailureProxy(C) - Constructor for class org.opendaylight.controller.cluster.access.concepts.AbstractRequestFailureProxy
 
AbstractRequestProxy<T extends WritableIdentifier,​C extends Request<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
Abstract Externalizable proxy for use with Request subclasses.
AbstractRequestProxy() - Constructor for class org.opendaylight.controller.cluster.access.concepts.AbstractRequestProxy
 
AbstractRequestProxy(C) - Constructor for class org.opendaylight.controller.cluster.access.concepts.AbstractRequestProxy
 
AbstractResponse<T extends NormalizedNode<?,​?>> - Class in org.opendaylight.controller.remote.rpc.messages
An abstract base class for invocation responses.
AbstractResponse(T) - Constructor for class org.opendaylight.controller.remote.rpc.messages.AbstractResponse
 
AbstractRoutingTable<T extends AbstractRoutingTable<T,​I>,​I> - Class in org.opendaylight.controller.remote.rpc.registry
Common class for routing tables.
AbstractServerChangeReply - Class in org.opendaylight.controller.cluster.raft.messages
Abstract base class for a server configuration change reply.
AbstractShardManagerCreator<T extends AbstractShardManagerCreator<T>> - Class in org.opendaylight.controller.cluster.datastore.shardmanager
 
AbstractSuccessProxy<T extends WritableIdentifier,​C extends RequestSuccess<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
Abstract Externalizable proxy for use with RequestSuccess subclasses.
AbstractSuccessProxy() - Constructor for class org.opendaylight.controller.cluster.access.concepts.AbstractSuccessProxy
 
AbstractSuccessProxy(C) - Constructor for class org.opendaylight.controller.cluster.access.concepts.AbstractSuccessProxy
 
AbstractThreePhaseCommitCohort<T> - Class in org.opendaylight.controller.cluster.datastore
Abstract base class for DOMStoreThreePhaseCommitCohort instances returned by this implementation.
AbstractThreePhaseCommitCohort() - Constructor for class org.opendaylight.controller.cluster.datastore.AbstractThreePhaseCommitCohort
 
AbstractThreePhaseCommitMessage - Class in org.opendaylight.controller.cluster.datastore.messages
Base class for a 3PC message.
AbstractThreePhaseCommitMessage() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
 
AbstractThreePhaseCommitMessage(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
 
AbstractUntypedActor - Class in org.opendaylight.controller.cluster.common.actor
 
AbstractUntypedActor() - Constructor for class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
 
AbstractUntypedActorWithMetering - Class in org.opendaylight.controller.cluster.common.actor
Actor with its behaviour metered.
AbstractUntypedActorWithMetering() - Constructor for class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActorWithMetering
 
AbstractUntypedActorWithMetering(String) - Constructor for class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActorWithMetering
 
AbstractUntypedPersistentActor - Class in org.opendaylight.controller.cluster.common.actor
 
AbstractUntypedPersistentActor() - Constructor for class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
AbstractUntypedPersistentActorWithMetering - Class in org.opendaylight.controller.cluster.common.actor
Actor with its behaviour metered.
AbstractUntypedPersistentActorWithMetering() - Constructor for class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActorWithMetering
 
AbstractVersionException - Exception in org.opendaylight.controller.cluster.access
Abstract base exception used for reporting version mismatches from ABIVersion.
AbstractVersionException - Exception in org.opendaylight.controller.cluster.datastore.persisted
Abstract base exception used for reporting version mismatches from PayloadVersion.
acquire() - Method in class org.opendaylight.controller.cluster.datastore.utils.TransactionRateLimiter
 
acquireCandidate() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
The cached candidate needs to be cleared after it is done applying to the DataTree, otherwise it would be keeping deserialized in memory which are not needed anymore leading to wasted memory.
acquireTxCreationPermit() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Try to acquire a transaction creation permit.
ActionRegistry - Class in org.opendaylight.controller.remote.rpc.registry
Registry to look up cluster nodes that have registered for a given Action.
ActionRegistry(RemoteOpsProviderConfig, ActorRef, ActorRef) - Constructor for class org.opendaylight.controller.remote.rpc.registry.ActionRegistry
 
ActionRegistry.Messages - Class in org.opendaylight.controller.remote.rpc.registry
All messages used by the ActionRegistry.
ActionRegistry.Messages.UpdateActions - Class in org.opendaylight.controller.remote.rpc.registry
 
ActionRegistry.Messages.UpdateRemoteActionEndpoints - Class in org.opendaylight.controller.remote.rpc.registry
 
ActionRegistry.RemoteActionEndpoint - Class in org.opendaylight.controller.remote.rpc.registry
 
ActionResponse - Class in org.opendaylight.controller.remote.rpc.messages
 
ActionResponse(Optional<ContainerNode>, Collection<RpcError>) - Constructor for class org.opendaylight.controller.remote.rpc.messages.ActionResponse
 
ActionRoutingTable - Class in org.opendaylight.controller.remote.rpc.registry
 
Active - org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
 
actor() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the actor associated with this behavior.
ActorInitialized - Class in org.opendaylight.controller.cluster.datastore.messages
 
ActorInitialized() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ActorInitialized
 
actorOf(Props) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Creates a new local actor.
actorOf(Props) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
actorSelection(ActorPath) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
actorSelection(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
actorSelection(String) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Creates an actor selection.
actorSelection(String) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
ActorSystemProvider - Interface in org.opendaylight.controller.cluster
Interface that provides an akka ActorSystem instance.
ActorSystemProviderImpl - Class in org.opendaylight.controller.cluster.akka.impl
 
ActorSystemProviderImpl(ClassLoader, Props, Config) - Constructor for class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
 
ActorSystemProviderListener - Interface in org.opendaylight.controller.cluster
Listener interface for notification of ActorSystem changes from an ActorSystemProvider.
ActorUtils - Class in org.opendaylight.controller.cluster.datastore.utils
The ActorUtils class contains utility methods which could be used by non-actors (like DistributedDataStore) to work with actors a little more easily.
ActorUtils(ActorSystem, ActorRef, ClusterWrapper, Configuration) - Constructor for class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
ActorUtils(ActorSystem, ActorRef, ClusterWrapper, Configuration, DatastoreContext, PrimaryShardInfoFutureCache) - Constructor for class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
add(long) - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
add(UnsignedLong) - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
addAugmentation(Class<? extends Augmentation<CreateTopicInput>>, Augmentation<CreateTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<CreateTopicOutput>>, Augmentation<CreateTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<DestroyTopicInput>>, Augmentation<DestroyTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<DestroyTopicOutput>>, Augmentation<DestroyTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<TopicNotification>>, Augmentation<TopicNotification>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<DisJoinTopicInput>>, Augmentation<DisJoinTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<DisJoinTopicOutput>>, Augmentation<DisJoinTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<EventSourceStatusNotification>>, Augmentation<EventSourceStatusNotification>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<JoinTopicInput>>, Augmentation<JoinTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<JoinTopicOutput>>, Augmentation<JoinTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<TopologyEventSource>>, Augmentation<TopologyEventSource>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSourceBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<NodeConnector>>, Augmentation<NodeConnector>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<NodeConnectorRemoved>>, Augmentation<NodeConnectorRemoved>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<NodeConnectorUpdated>>, Augmentation<NodeConnectorUpdated>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<NodeRemoved>>, Augmentation<NodeRemoved>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<Node>>, Augmentation<Node>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<Nodes>>, Augmentation<Nodes>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<NodeUpdated>>, Augmentation<NodeUpdated>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<NodeIdentifier>>, Augmentation<NodeIdentifier>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<OriginalNode>>, Augmentation<OriginalNode>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<DataStorePropertiesContainer>>, Augmentation<DataStorePropertiesContainer>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<AddPrefixShardReplicaInput>>, Augmentation<AddPrefixShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<AddPrefixShardReplicaOutput>>, Augmentation<AddPrefixShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<AddReplicasForAllShardsInput>>, Augmentation<AddReplicasForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<AddReplicasForAllShardsOutput>>, Augmentation<AddReplicasForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<AddShardReplicaInput>>, Augmentation<AddShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<AddShardReplicaOutput>>, Augmentation<AddShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<BackupDatastoreInput>>, Augmentation<BackupDatastoreInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<BackupDatastoreOutput>>, Augmentation<BackupDatastoreOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForAllShardsInput>>, Augmentation<ChangeMemberVotingStatesForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForAllShardsOutput>>, Augmentation<ChangeMemberVotingStatesForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForShardInput>>, Augmentation<ChangeMemberVotingStatesForShardInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForShardOutput>>, Augmentation<ChangeMemberVotingStatesForShardOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<FlipMemberVotingStatesForAllShardsInput>>, Augmentation<FlipMemberVotingStatesForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<FlipMemberVotingStatesForAllShardsOutput>>, Augmentation<FlipMemberVotingStatesForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<KnownClients>>, Augmentation<KnownClients>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<GetKnownClientsForAllShardsInput>>, Augmentation<GetKnownClientsForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<GetKnownClientsForAllShardsOutput>>, Augmentation<GetKnownClientsForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<GetPrefixShardRoleInput>>, Augmentation<GetPrefixShardRoleInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<GetPrefixShardRoleOutput>>, Augmentation<GetPrefixShardRoleOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<GetShardRoleInput>>, Augmentation<GetShardRoleInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<GetShardRoleOutput>>, Augmentation<GetShardRoleOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<LeaderActorRef>>, Augmentation<LeaderActorRef>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<Local>>, Augmentation<Local>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<LocateShardInput>>, Augmentation<LocateShardInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<LocateShardOutput>>, Augmentation<LocateShardOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<MakeLeaderLocalInput>>, Augmentation<MakeLeaderLocalInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<MakeLeaderLocalOutput>>, Augmentation<MakeLeaderLocalOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<MemberVotingState>>, Augmentation<MemberVotingState>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<RemoveAllShardReplicasInput>>, Augmentation<RemoveAllShardReplicasInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<RemoveAllShardReplicasOutput>>, Augmentation<RemoveAllShardReplicasOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<RemovePrefixShardReplicaInput>>, Augmentation<RemovePrefixShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<RemovePrefixShardReplicaOutput>>, Augmentation<RemovePrefixShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<RemoveShardReplicaInput>>, Augmentation<RemoveShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<RemoveShardReplicaOutput>>, Augmentation<RemoveShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<ShardResult>>, Augmentation<ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<Replicas>>, Augmentation<Replicas>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<Shard>>, Augmentation<Shard>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Class<? extends Augmentation<PrefixShards>>, Augmentation<PrefixShards>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addAugmentation(Augmentation<CreateTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<CreateTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<DestroyTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<DestroyTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<TopicNotification>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<DisJoinTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<DisJoinTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<EventSourceStatusNotification>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<JoinTopicInput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<JoinTopicOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<TopologyEventSource>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSourceBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<NodeConnector>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<NodeConnectorRemoved>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<NodeConnectorUpdated>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<NodeRemoved>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<Node>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<Nodes>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<NodeUpdated>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<NodeIdentifier>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<OriginalNode>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<DataStorePropertiesContainer>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<AddPrefixShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<AddPrefixShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<AddReplicasForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<AddReplicasForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<AddShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<AddShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<BackupDatastoreInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<BackupDatastoreOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<ChangeMemberVotingStatesForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<ChangeMemberVotingStatesForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<ChangeMemberVotingStatesForShardInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<ChangeMemberVotingStatesForShardOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<FlipMemberVotingStatesForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<FlipMemberVotingStatesForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<KnownClients>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<GetKnownClientsForAllShardsInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<GetKnownClientsForAllShardsOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<GetPrefixShardRoleInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<GetPrefixShardRoleOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<GetShardRoleInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<GetShardRoleOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<LeaderActorRef>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<Local>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<LocateShardInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<LocateShardOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<MakeLeaderLocalInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<MakeLeaderLocalOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<MemberVotingState>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<RemoveAllShardReplicasInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<RemoveAllShardReplicasOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<RemovePrefixShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<RemovePrefixShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<RemoveShardReplicaInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<RemoveShardReplicaOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<Replicas>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<Shard>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
Add an augmentation to this builder's product.
addAugmentation(Augmentation<PrefixShards>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
Add an augmentation to this builder's product.
addFollower(String) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
addMemberReplicaForShard(String, MemberName) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Adds the given member as the new replica for the given shardName.
addMemberReplicaForShard(String, MemberName) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
addModification(TransactionModification) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
addModification(Modification) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
Add a new Modification to the list of Modifications represented by this composite.
addModifications(Iterable<Modification>) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
addModuleShardConfiguration(ModuleShardConfiguration) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Adds a new configuration for a module and shard.
addModuleShardConfiguration(ModuleShardConfiguration) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
addOnComplete(OnComplete<T>) - Method in class org.opendaylight.controller.cluster.datastore.utils.CompositeOnComplete
 
AddOrUpdateRoutes(Collection<DOMRpcIdentifier>) - Constructor for class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.Messages.AddOrUpdateRoutes
 
addPrefixShardConfiguration(PrefixShardConfiguration) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Adds a new configuration for a shard based on prefix.
addPrefixShardConfiguration(PrefixShardConfiguration) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
addPrefixShardReplica(AddPrefixShardReplicaInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
addPrefixShardReplica(AddPrefixShardReplicaInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Adds a replica of a shard to this node and joins it to an existing cluster.
AddPrefixShardReplica - Class in org.opendaylight.controller.cluster.datastore.messages
A message sent to the ShardManager to dynamically add a new local shard that is a replica for an existing prefix shard that is already available in the cluster.
AddPrefixShardReplica(YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AddPrefixShardReplica
Constructor.
AddPrefixShardReplicaInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
AddPrefixShardReplicaInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds AddPrefixShardReplicaInputBuilder instances.
AddPrefixShardReplicaInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
AddPrefixShardReplicaInputBuilder(AddPrefixShardReplicaInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
AddPrefixShardReplicaOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
AddPrefixShardReplicaOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds AddPrefixShardReplicaOutputBuilder instances.
AddPrefixShardReplicaOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutputBuilder
 
AddPrefixShardReplicaOutputBuilder(AddPrefixShardReplicaOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutputBuilder
 
addReplicasForAllShards(AddReplicasForAllShardsInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
addReplicasForAllShards(AddReplicasForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Adds replicas on this node for all currently defined shards.
AddReplicasForAllShardsInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
AddReplicasForAllShardsInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds AddReplicasForAllShardsInputBuilder instances.
AddReplicasForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
 
AddReplicasForAllShardsInputBuilder(AddReplicasForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
 
AddReplicasForAllShardsOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
AddReplicasForAllShardsOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds AddReplicasForAllShardsOutputBuilder instances.
AddReplicasForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
 
AddReplicasForAllShardsOutputBuilder(AddReplicasForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
 
AddReplicasForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
 
ADDRESS - Static variable in class org.opendaylight.controller.cluster.common.actor.QuarantinedMonitorActor
 
ADDRESS - Static variable in class org.opendaylight.controller.cluster.datastore.TerminationMonitor
 
AddServer - Class in org.opendaylight.controller.cluster.raft.messages
Message sent to add a new server/replica (§4.1).
AddServer(String, String, boolean) - Constructor for class org.opendaylight.controller.cluster.raft.messages.AddServer
 
AddServerReply - Class in org.opendaylight.controller.cluster.raft.messages
Reply to an AddServer message (§4.1).
AddServerReply(ServerChangeStatus, String) - Constructor for class org.opendaylight.controller.cluster.raft.messages.AddServerReply
 
addShardReplica(AddShardReplicaInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
addShardReplica(AddShardReplicaInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Adds a replica of a shard to this node and joins it to an existing cluster.
AddShardReplica - Class in org.opendaylight.controller.cluster.datastore.messages
A message sent to the ShardManager to dynamically add a new local shard that is a replica for an existing shard that is already available in the cluster.
AddShardReplica(String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AddShardReplica
Constructor.
AddShardReplicaInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
AddShardReplicaInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds AddShardReplicaInputBuilder instances.
AddShardReplicaInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
AddShardReplicaInputBuilder(AddShardReplicaInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
AddShardReplicaInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
AddShardReplicaOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
AddShardReplicaOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds AddShardReplicaOutputBuilder instances.
AddShardReplicaOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
 
AddShardReplicaOutputBuilder(AddShardReplicaOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
 
addSlice(int, byte[], int) - Method in class org.opendaylight.controller.cluster.messaging.AssembledMessageState
Adds a slice to the assembled stream.
addToPeers(String, String, VotingState) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Adds a new peer.
addToPeers(String, String, VotingState) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.concepts.Message
Add attributes to the output of Message.toString().
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.commands.AbstractReadPathTransactionRequest
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.commands.AbstractReadTransactionRequest
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.commands.CommitLocalTransactionRequest
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientRequest
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.commands.ExistsTransactionSuccess
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequest
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.concepts.Request
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.access.concepts.RequestFailure
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
 
addToStringAttributes(MoreObjects.ToStringHelper) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerWriteTransaction
 
adjustedIndex(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
aggregate(YangInstanceIdentifier, List<Optional<NormalizedNode<?, ?>>>, EffectiveModelContext, LogicalDatastoreType) - Static method in class org.opendaylight.controller.cluster.datastore.utils.NormalizedNodeAggregator
Combine data from all the nodes in the list into a tree with root as rootIdentifier.
AggregatedNode - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030
 
AggregatedNodeBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030
Class that builds AggregatedNodeBuilder instances.
AggregatedNodeBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNodeBuilder
 
AggregatedNodeBuilder(AggregatedNode) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNodeBuilder
 
AggregatedNodeBuilder(AggregateNode) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNodeBuilder
 
AggregatedTopology - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030
 
AggregatedTopologyBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030
Class that builds AggregatedTopologyBuilder instances.
AggregatedTopologyBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopologyBuilder
 
AggregatedTopologyBuilder(AggregatedTopology) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopologyBuilder
 
AggregatedTopologyBuilder(AggregateTopology) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopologyBuilder
 
AggregateNode - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030
This class represents the following YANG schema fragment defined in module opendaylight-topology-view
AggregateTopology - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030
This class represents the following YANG schema fragment defined in module opendaylight-topology-view
AkkaConfigFactory - Class in org.opendaylight.controller.cluster.akka.impl
 
AkkaConfigurationReader - Interface in org.opendaylight.controller.cluster.common.actor
 
ALREADY_EXISTS - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
For an AddServer request, the server to add already exists.
AlreadyExistsException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
 
AlreadyExistsException(String) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.AlreadyExistsException
 
anyVotingPeers() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Determines if there are any voting peers.
anyVotingPeers() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
append(ReplicatedLogEntry) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
append(ReplicatedLogEntry) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Appends an entry to the log.
appendAndPersist(ReplicatedLogEntry, Consumer<ReplicatedLogEntry>, boolean) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Appends an entry to the in-memory log and persists it as well.
appendEntries(ActorRef, AppendEntries) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Handles the common logic for the AppendEntries message and delegates handling to the derived class.
AppendEntries - Class in org.opendaylight.controller.cluster.raft.messages
Invoked by leader to replicate log entries (§5.3); also used as heartbeat (§5.2).
AppendEntries(long, String, long, long, List<ReplicatedLogEntry>, long, long, short) - Constructor for class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
AppendEntries(long, String, long, long, List<ReplicatedLogEntry>, long, long, short, short, String) - Constructor for class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
AppendEntriesReply - Class in org.opendaylight.controller.cluster.raft.messages
Reply for the AppendEntries message.
AppendEntriesReply(String, long, boolean, long, long, short) - Constructor for class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
AppendEntriesReply(String, long, boolean, long, long, short, boolean, boolean, short) - Constructor for class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
appendRecoveredLogEntry(Payload) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorRecoveryCohort
This method is called during recovery to append state data to the current batch.
apply(Object) - Method in class org.opendaylight.controller.cluster.common.actor.MeteringBehavior
Uses 2 timers to measure message processing rate.
apply(Object) - Method in class org.opendaylight.controller.cluster.raft.NoopProcedure
 
apply(ApplySnapshot) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
apply(ApplySnapshot) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Applies a snapshot on a follower that was installed by the leader.
apply(DOMStoreReadTransaction) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
apply(DOMStoreReadTransaction) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
 
apply(DOMStoreReadTransaction) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
 
apply(DOMStoreWriteTransaction) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
apply(DOMStoreWriteTransaction) - Method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
 
apply(DOMStoreWriteTransaction) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
Apply the modification to the specified transaction.
apply(DOMStoreWriteTransaction) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
apply(DOMStoreWriteTransaction) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
apply(DataTreeModification) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
apply(DataTreeModification) - Method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
 
apply(DataTreeModification) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
Apply the modification to the specified transaction.
apply(DataTreeModification) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
apply(DataTreeModification) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
apply(T, YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in interface org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils.Applier
 
applyCurrentLogRecoveryBatch() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorRecoveryCohort
This method is called during recovery at the end of a batch to apply the current batched log entries.
ApplyJournalEntries - Class in org.opendaylight.controller.cluster.raft.persisted
This is an internal message that is stored in the akka's persistent journal.
ApplyJournalEntries(long) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.ApplyJournalEntries
 
applyLogToStateMachine(long) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Applies the log entries up to the specified index that is known to be committed to the state machine.
applyModificationToStateBeforeConsensus() - Method in class org.opendaylight.controller.cluster.datastore.policy.TestOnlyRaftPolicy
 
applyModificationToStateBeforeConsensus() - Method in class org.opendaylight.controller.cluster.datastore.policy.TwoNodeClusterRaftPolicy
 
applyModificationToStateBeforeConsensus() - Method in class org.opendaylight.controller.cluster.raft.policy.DefaultRaftPolicy
 
applyModificationToStateBeforeConsensus() - Method in class org.opendaylight.controller.cluster.raft.policy.DisableElectionsRaftPolicy
 
applyModificationToStateBeforeConsensus() - Method in interface org.opendaylight.controller.cluster.raft.policy.RaftPolicy
According to Raft consensus on a Raft entry is achieved only after a Leader replicates a log entry to a majority of it's followers.
applyRecoverySnapshot(Snapshot.State) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorRecoveryCohort
This method is called during recovery to reconstruct the state of the actor.
applySnapshot(Snapshot.State) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorSnapshotCohort
This method is called to apply a snapshot installed by the leader.
applySnapshot(Snapshot.State) - Method in class org.opendaylight.controller.cluster.raft.NoopRaftActorSnapshotCohort
 
ApplySnapshot - Class in org.opendaylight.controller.cluster.raft.base.messages
Internal message, issued by follower to its actor.
ApplySnapshot(Snapshot) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.ApplySnapshot
 
ApplySnapshot(Snapshot, ApplySnapshot.Callback) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.ApplySnapshot
 
ApplySnapshot.Callback - Interface in org.opendaylight.controller.cluster.raft.base.messages
 
applyState(ActorRef, Identifier, Object) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
applyState(ActorRef, Identifier, Object) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
The applyState method will be called by the RaftActor when some data needs to be applied to the actor's state.
ApplyState - Class in org.opendaylight.controller.cluster.raft.base.messages
Local message sent by a RaftActor to itself to signal state has been applied to the state machine.
ApplyState(ActorRef, Identifier, ReplicatedLogEntry) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.ApplyState
 
applyToCursor(DataTreeModificationCursor) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
 
Arguments - Class in org.opendaylight.controller.sal.common.util
 
asByteSource() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
Returns a readable ByteSource view of the data that has been written to this stream.
ask(ActorRef, Function<ActorRef, ?>, Timeout) - Static method in class org.opendaylight.controller.cluster.common.actor.ExplicitAsk
 
ask(ActorRef, Function1<ActorRef, ?>, Timeout) - Static method in class org.opendaylight.controller.cluster.common.actor.ExplicitAsk
 
ask(ActorSelection, Function<ActorRef, ?>, Timeout) - Static method in class org.opendaylight.controller.cluster.common.actor.ExplicitAsk
 
ask(ActorSelection, Function1<ActorRef, ?>, Timeout) - Static method in class org.opendaylight.controller.cluster.common.actor.ExplicitAsk
 
assembledMessageCallback(BiConsumer<Object, ActorRef>) - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler.Builder
Sets the Consumer callback for assembled messages.
AssembledMessageState - Class in org.opendaylight.controller.cluster.messaging
Maintains the state of an assembled message.
AssembledMessageState(Identifier, int, FileBackedOutputStreamFactory, String) - Constructor for class org.opendaylight.controller.cluster.messaging.AssembledMessageState
Constructor.
AssemblerClosedException - Exception in org.opendaylight.controller.cluster.messaging
A MessageSliceException indicating the message assembler has already been closed.
AssemblerClosedException(Identifier) - Constructor for exception org.opendaylight.controller.cluster.messaging.AssemblerClosedException
Constructs an instance.
AssemblerSealedException - Exception in org.opendaylight.controller.cluster.messaging
A MessageSliceException indicating the message assembler has already been sealed.
AssemblerSealedException(String) - Constructor for exception org.opendaylight.controller.cluster.messaging.AssemblerSealedException
Constructs an instance.
asVersion(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
asyncClose() - Method in class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSourceBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
 
AutoCloseableEventExecutor - Interface in org.opendaylight.controller.config.yang.netty.eventexecutor
 
AutoCloseableEventExecutor.CloseableEventExecutorMixin - Class in org.opendaylight.controller.config.yang.netty.eventexecutor
 
automaticElectionsEnabled() - Method in class org.opendaylight.controller.cluster.datastore.policy.TestOnlyRaftPolicy
 
automaticElectionsEnabled() - Method in class org.opendaylight.controller.cluster.datastore.policy.TwoNodeClusterRaftPolicy
 
automaticElectionsEnabled() - Method in class org.opendaylight.controller.cluster.raft.policy.DefaultRaftPolicy
 
automaticElectionsEnabled() - Method in class org.opendaylight.controller.cluster.raft.policy.DisableElectionsRaftPolicy
 
automaticElectionsEnabled() - Method in interface org.opendaylight.controller.cluster.raft.policy.RaftPolicy
According to Raft a Follower which does not receive a heartbeat (aka AppendEntries) in a given period should become a Candidate and trigger an election.
awaitReadiness() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
Deprecated.
awaitReadiness(long, TimeUnit) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
Deprecated.
awaitReadiness(Duration) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
Deprecated.
awaitResolution() - Method in exception org.opendaylight.controller.cluster.access.client.InversibleLockException
 
awaitTermination(long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 

B

backendAlivenessTimerIntervalInSeconds(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
BackendInfo - Class in org.opendaylight.controller.cluster.access.client
Basic information about how to talk to the backend.
BackendInfo(ActorRef, String, long, ABIVersion, int) - Constructor for class org.opendaylight.controller.cluster.access.client.BackendInfo
 
BackendInfoResolver<T extends BackendInfo> - Class in org.opendaylight.controller.cluster.access.client
Caching resolver which resolves a cookie to a leader ActorRef.
BackendInfoResolver() - Constructor for class org.opendaylight.controller.cluster.access.client.BackendInfoResolver
 
backupDatastore(BackupDatastoreInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
backupDatastore(BackupDatastoreInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Creates a backup file of the datastore state
BackupDatastoreInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
BackupDatastoreInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds BackupDatastoreInputBuilder instances.
BackupDatastoreInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
BackupDatastoreInputBuilder(BackupDatastoreInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
BackupDatastoreOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
BackupDatastoreOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds BackupDatastoreOutputBuilder instances.
BackupDatastoreOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
 
BackupDatastoreOutputBuilder(BackupDatastoreOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
 
BASE_HELIUM_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
Deprecated.
BASE_JMX_PREFIX - Static variable in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
 
BatchedModifications - Class in org.opendaylight.controller.cluster.datastore.messages
Message used to batch write, merge, delete modification operations to the ShardTransaction actor.
BatchedModifications() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
BatchedModifications(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
BatchedModificationsReply - Class in org.opendaylight.controller.cluster.datastore.messages
The reply for the BatchedModifications message.
BatchedModificationsReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
 
BatchedModificationsReply(int) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
 
beforeSendHeartbeat() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
beforeSendHeartbeat() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Leader
 
begin() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker
 
BORON - org.opendaylight.controller.cluster.access.ABIVersion
Initial ABI version, as shipped with Boron Simultaneous release.
BORON - org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Initial ABI version, as shipped with Boron Simultaneous release.
BORON_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
 
BORON_VERSION - Static variable in class org.opendaylight.controller.cluster.raft.RaftVersions
 
BOUNDED_MAILBOX - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
boundedMailboxCapacity() - Method in annotation type org.opendaylight.controller.remote.rpc.OSGiRemoteOpsProvider.Config
 
boundedMailboxCapacity(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
broadcast(Function<Short, Object>, Class<?>) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Send the message to each and every shard.
Bucket<T extends BucketData<T>> - Interface in org.opendaylight.controller.remote.rpc.registry.gossip
 
BucketData<T extends BucketData<T>> - Interface in org.opendaylight.controller.remote.rpc.registry.gossip
Marker interface for data which is able to be held in a Bucket.
BucketStoreAccess - Class in org.opendaylight.controller.remote.rpc.registry.gossip
Convenience access to BucketStoreActor.
BucketStoreAccess(ActorRef, ExecutionContext, Timeout) - Constructor for class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess
 
BucketStoreAccess.Singletons - Enum in org.opendaylight.controller.remote.rpc.registry.gossip
 
BucketStoreActor<T extends BucketData<T>> - Class in org.opendaylight.controller.remote.rpc.registry.gossip
A store that syncs its data across nodes in the cluster.
BucketStoreActor(RemoteOpsProviderConfig, String, T) - Constructor for class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
build() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
build() - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig.Builder
 
build() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig.Builder
 
build() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
build() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier.Builder
 
build() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier.Builder
 
build() - Method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState.Builder
 
build() - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler.Builder
Builds a new MessageAssembler instance.
build() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer.Builder
Builds a new MessageSlicer instance.
build() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Builds a new SliceOptions instance.
build() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
build() - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardModificationFactoryBuilder
 
build() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig.Builder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.Node1Builder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSourceBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1Builder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Node1Builder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Topology1Builder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeConnectorBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNodeBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopologyBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1Builder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
 
builder() - Static method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier
 
builder() - Static method in class org.opendaylight.controller.cluster.datastore.Shard
 
builder() - Static method in class org.opendaylight.controller.cluster.messaging.MessageAssembler
Returns a new Builder for creating MessageAssembler instances.
builder() - Static method in class org.opendaylight.controller.cluster.messaging.MessageSlicer
Returns a new Builder for creating MessageSlicer instances.
builder() - Static method in class org.opendaylight.controller.cluster.messaging.SliceOptions
Returns a new Builder for creating MessageSlicer instances.
builder() - Static method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
builder(String) - Static method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
builder(ModuleConfig) - Static method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
Builder() - Constructor for class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier.Builder
 
Builder() - Constructor for class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier.Builder
 
Builder() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState.Builder
 
Builder() - Constructor for class org.opendaylight.controller.cluster.messaging.MessageAssembler.Builder
 
Builder() - Constructor for class org.opendaylight.controller.cluster.messaging.MessageSlicer.Builder
 
Builder() - Constructor for class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
 
Builder() - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.Builder
 
Builder(String) - Constructor for class org.opendaylight.controller.cluster.common.actor.AbstractConfig.Builder
 
Builder(String) - Constructor for class org.opendaylight.controller.cluster.common.actor.CommonConfig.Builder
 
Builder(String) - Constructor for class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig.Builder
 
BundleClassLoaderFactory - Class in org.opendaylight.controller.cluster.akka.osgi.impl
 

C

callbackPoolSize() - Method in annotation type org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker.Config
 
callbackQueueSize() - Method in annotation type org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker.Config
 
CAN_COMMIT_COMPLETE - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
CAN_COMMIT_PENDING - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
cancel() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerWriteTransaction
 
cancelSlicing(Predicate<Identifier>) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer
Cancels all in-progress sliced message state that matches the given filter.
canCommit() - Method in class org.opendaylight.controller.cluster.datastore.ThreePhaseCommitCohortProxy
 
canCommit(FutureCallback<Void>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
 
CanCommitTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
 
CanCommitTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
 
CanCommitTransaction(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
 
CanCommitTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
CanCommitTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
Candidate - Class in org.opendaylight.controller.cluster.raft.behaviors
The behavior of a RaftActor when it is in the Candidate raft state.
Candidate - org.opendaylight.controller.cluster.raft.RaftState
 
Candidate(RaftActorContext) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
canGrantVote(RequestVote) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
canRetry() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Determines if the slicing can be retried.
canStartElection() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
capture(ReplicatedLogEntry, long) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
capture(ReplicatedLogEntry, long) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Initiates a capture snapshot.
captureSnapshot() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
captureSnapshot() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
CaptureSnapshot - Class in org.opendaylight.controller.cluster.raft.base.messages
 
CaptureSnapshot(long, long, long, long, long, long, List<ReplicatedLogEntry>, boolean) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
captureSnapshotIfReady(ReplicatedLogEntry) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Determines if a snapshot needs to be captured based on the count/memory consumed and initiates the capture.
CaptureSnapshotReply - Class in org.opendaylight.controller.cluster.raft.base.messages
 
CaptureSnapshotReply(Snapshot.State, Optional<OutputStream>) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshotReply
 
captureToInstall(ReplicatedLogEntry, long, String) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
captureToInstall(ReplicatedLogEntry, long, String) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Initiates a capture snapshot for the purposing of installing the snapshot on a follower.
captureWithForcedTrim(ReplicatedLogEntry, long) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
captureWithForcedTrim(ReplicatedLogEntry, long) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Initiates a capture snapshot, while enforcing trimming of the log up to lastAppliedIndex.
CDSDataTreeProducer - Interface in org.opendaylight.controller.cluster.dom.api
An extension to DOMDataTreeProducer, which allows users access to information about the backing shard.
CDSShardAccess - Interface in org.opendaylight.controller.cluster.dom.api
Unprivileged access interface to shard information.
changeCurrentBehavior(RaftActorBehavior) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
changeMemberVotingStatesForAllShards(ChangeMemberVotingStatesForAllShardsInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
changeMemberVotingStatesForAllShards(ChangeMemberVotingStatesForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Changes the voting states, either voting or non-voting, of cluster members for all shards.
ChangeMemberVotingStatesForAllShardsInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
ChangeMemberVotingStatesForAllShardsInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
ChangeMemberVotingStatesForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
 
ChangeMemberVotingStatesForAllShardsInputBuilder(ChangeMemberVotingStatesForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
 
ChangeMemberVotingStatesForAllShardsInputBuilder(MemberVotingStatesInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
 
ChangeMemberVotingStatesForAllShardsOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
ChangeMemberVotingStatesForAllShardsOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
ChangeMemberVotingStatesForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
 
ChangeMemberVotingStatesForAllShardsOutputBuilder(ChangeMemberVotingStatesForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
 
ChangeMemberVotingStatesForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
 
changeMemberVotingStatesForShard(ChangeMemberVotingStatesForShardInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
changeMemberVotingStatesForShard(ChangeMemberVotingStatesForShardInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Changes the voting states, either voting or non-voting, of cluster members for a shard.
ChangeMemberVotingStatesForShardInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
ChangeMemberVotingStatesForShardInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
ChangeMemberVotingStatesForShardInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
ChangeMemberVotingStatesForShardInputBuilder(ChangeMemberVotingStatesForShardInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
ChangeMemberVotingStatesForShardInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
ChangeMemberVotingStatesForShardInputBuilder(MemberVotingStatesInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
ChangeMemberVotingStatesForShardOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
ChangeMemberVotingStatesForShardOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
ChangeMemberVotingStatesForShardOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
 
ChangeMemberVotingStatesForShardOutputBuilder(ChangeMemberVotingStatesForShardOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
 
ChangeServersVotingStatus - Class in org.opendaylight.controller.cluster.raft.messages
Message sent to change the raft voting status for servers.
ChangeServersVotingStatus(Map<String, Boolean>) - Constructor for class org.opendaylight.controller.cluster.raft.messages.ChangeServersVotingStatus
 
ChangeServersVotingStatus(Map<String, Boolean>, Collection<String>) - Constructor for class org.opendaylight.controller.cluster.raft.messages.ChangeServersVotingStatus
 
ChangeShardMembersVotingStatus - Class in org.opendaylight.controller.cluster.datastore.messages
A local message sent to the ShardManager to change the raft voting status for members of a shard.
ChangeShardMembersVotingStatus(String, Map<String, Boolean>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ChangeShardMembersVotingStatus
 
CheckConsensusReached - Class in org.opendaylight.controller.cluster.raft.base.messages
Internal message sent to the leader after persistence is complete to check if replication consensus has been reached.
checkedApply(Object) - Method in class org.opendaylight.controller.cluster.datastore.TransactionReadyReplyMapper
 
checkExpiredAssembledMessageState() - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler
Checks for and removes assembled message state that has expired due to inactivity from the slicing component on the other end.
checkExpiredSlicedMessageState() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer
Checks for and removes sliced message state that has expired due to inactivity from the assembling component on the other end.
checkInstanceOf(Object, Class<T>) - Static method in class org.opendaylight.controller.sal.common.util.Arguments
Checks if value is instance of provided class.
checkNotClosed() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
Checks if instance is not closed.
checkSealed() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
checkSealed() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
checkSealed() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
 
cleanup() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
Calls FileBackedOutputStream.close() if not already closed and, if data was buffered to a file, deletes the file.
cleanup() - Method in class org.opendaylight.controller.cluster.io.SharedFileBackedOutputStream
Overridden to decrement the usage count.
clear(int, int) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
clear(int, int) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Clears the journal entries with startIndex (inclusive) and endIndex (exclusive).
clearLeaderInstallSnapshotState() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Clears the LeaderInstallSnapshotState when an install snapshot is complete.
clearStats() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBean
Clears the current stats to their defaults.
clearStats() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBeanImpl
 
Client - org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
 
CLIENT_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
ClientActorBehavior<T extends BackendInfo> - Class in org.opendaylight.controller.cluster.access.client
A behavior, which handles messages sent to a AbstractClientActor.
ClientActorBehavior(ClientActorContext, BackendInfoResolver<T>) - Constructor for class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
 
ClientActorBehavior.ConnectionConnectCohort - Interface in org.opendaylight.controller.cluster.access.client
Connection reconnect cohort, driven by this class.
ClientActorConfig - Interface in org.opendaylight.controller.cluster.access.client
Interface for client actor configuration parameters.
ClientActorContext - Class in org.opendaylight.controller.cluster.access.client
An actor context associated with this AbstractClientActor.
ClientBackedDataStore - Class in org.opendaylight.controller.cluster.databroker
Implements a distributed DOMStore using ClientActor.
ClientBackedDataStore(ActorSystem, ClusterWrapper, Configuration, DatastoreContextFactory, DatastoreSnapshot) - Constructor for class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
 
ClientGeneration - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
 
ClientGeneration(BigInteger) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link ClientGeneration(Uint64)} instead.
ClientGeneration(ClientGeneration) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
Creates a copy from Source Object.
ClientGeneration(Uint64) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
 
ClientIdentifier - Class in org.opendaylight.controller.cluster.access.concepts
A cluster-wide unique identifier of a frontend instance.
ClientIdentifier - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
Identifier of a particular client.
ClientLocalHistory - Class in org.opendaylight.controller.cluster.databroker.actors.dds
Client-side view of a local history.
ClientRequestTracker - Interface in org.opendaylight.controller.cluster.raft
 
ClientRequestTrackerImpl - Class in org.opendaylight.controller.cluster.raft
 
ClientRequestTrackerImpl(ActorRef, Identifier, long) - Constructor for class org.opendaylight.controller.cluster.raft.ClientRequestTrackerImpl
 
ClientSnapshot - Class in org.opendaylight.controller.cluster.databroker.actors.dds
Snapshot of the datastore state.
ClientTransaction - Class in org.opendaylight.controller.cluster.databroker.actors.dds
Client-side view of a transaction.
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.concepts.Message
Create a copy of this message which will serialize to a stream corresponding to the specified method.
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.AbstractLocalTransactionRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientFailure
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.CreateLocalHistoryRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.DestroyLocalHistoryRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ExistsTransactionRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ExistsTransactionSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.LocalHistoryFailure
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.LocalHistorySuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.PurgeLocalHistoryRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ReadTransactionRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ReadTransactionSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionAbortRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionAbortSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionCanCommitSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionCommitSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionDoCommitRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionFailure
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPreCommitRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPreCommitSuccess
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPurgeRequest
 
cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPurgeResponse
 
close() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActorBehavior
 
close() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfoResolver
 
close() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
 
close() - Method in class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
 
close() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker.Context
 
close() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBroker
 
close() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
 
close() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientLocalHistory
 
close() - Method in interface org.opendaylight.controller.cluster.databroker.actors.dds.DataStoreClient
 
close() - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerReadOnlyTransaction
 
close() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
close() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextPropertiesUpdater
 
close() - Method in class org.opendaylight.controller.cluster.datastore.DistributedDataStore
 
close() - Method in class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
close() - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
close() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
 
close() - Method in class org.opendaylight.controller.cluster.messaging.AssembledMessageState
 
close() - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler
 
close() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer
Closes and removes all in-progress sliced message state.
close() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
 
close() - Method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotifier
 
close() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
close() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
close() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
close() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Leader
 
close() - Method in class org.opendaylight.controller.cluster.raft.behaviors.LeaderInstallSnapshotState
 
close() - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
 
close() - Method in class org.opendaylight.controller.cluster.reporting.MetricsReporter
 
close() - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardModificationCursor
 
close() - Method in interface org.opendaylight.controller.cluster.sharding.DistributedShardRegistration
Removes the shard from the system, this removal is done asynchronously, the future completes once the backend shard is no longer present.
close() - Method in class org.opendaylight.controller.cluster.sharding.PrefixedShardConfigUpdateHandler
 
close() - Method in class org.opendaylight.controller.config.threadpool.util.FixedThreadPoolWrapper
 
close() - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
close() - Method in class org.opendaylight.controller.config.threadpool.util.NamingThreadPoolFactory
 
close() - Method in class org.opendaylight.controller.config.threadpool.util.ScheduledThreadPoolWrapper
 
close() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.AutoCloseableEventExecutor.CloseableEventExecutorMixin
 
close() - Method in class org.opendaylight.controller.config.yang.netty.threadgroup.NioEventLoopGroupCloseable
 
close() - Method in class org.opendaylight.controller.config.yang.netty.timer.HashedWheelTimerCloseable
 
close() - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopic
 
close() - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopology
 
close() - Method in class org.opendaylight.controller.messagebus.app.impl.OSGiEventSourceRegistry
 
close() - Method in interface org.opendaylight.controller.messagebus.spi.EventSourceRegistration
 
close() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProvider
 
close() - Method in class org.opendaylight.controller.sal.common.util.NoopAutoCloseable
 
close(FiniteDuration) - Method in class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
 
CloseableEventExecutorMixin(EventExecutor) - Constructor for class org.opendaylight.controller.config.yang.netty.eventexecutor.AutoCloseableEventExecutor.CloseableEventExecutorMixin
 
CloseDataTreeNotificationListenerRegistration - Class in org.opendaylight.controller.cluster.datastore.messages
 
CloseDataTreeNotificationListenerRegistrationReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
ClosedTransactionException - Exception in org.opendaylight.controller.cluster.access.commands
A RequestException indicating that the backend has received a request for a transaction which has already been closed, either via a successful commit or abort (which is indicated via ClosedTransactionException.isSuccessful().
ClosedTransactionException(boolean) - Constructor for exception org.opendaylight.controller.cluster.access.commands.ClosedTransactionException
 
CloseLocalHistoryPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
Payload persisted when a local history is closed cleanly.
closeSubtransactions() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
 
closeTransaction() - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
CloseTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
 
CloseTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransaction
 
CloseTransaction(short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransaction
 
CloseTransactionChain - Class in org.opendaylight.controller.cluster.datastore.messages
 
CloseTransactionChain() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
 
CloseTransactionChain(LocalHistoryIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
 
CloseTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
CloseTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionReply
 
cluster(ClusterWrapper) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
ClusterAdminRpcService - Class in org.opendaylight.controller.cluster.datastore.admin
Implements the yang RPCs defined in the generated ClusterAdminService interface.
ClusterAdminRpcService(DistributedDataStoreInterface, DistributedDataStoreInterface, BindingNormalizedNodeSerializer) - Constructor for class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
ClusterAdminService - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Interface for implementing the following YANG RPCs defined in module cluster-admin
ClusterUtils - Class in org.opendaylight.controller.cluster.datastore.utils
Utils for encoding prefix shard name.
ClusterWrapper - Interface in org.opendaylight.controller.cluster.datastore
 
ClusterWrapperImpl - Class in org.opendaylight.controller.cluster.datastore
 
ClusterWrapperImpl(ActorSystem) - Constructor for class org.opendaylight.controller.cluster.datastore.ClusterWrapperImpl
 
commit() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerWriteTransaction
 
commit() - Method in class org.opendaylight.controller.cluster.datastore.ThreePhaseCommitCohortProxy
 
commit(long, long) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
commit(long, long) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Commit the snapshot by trimming the log.
commit(FutureCallback<UnsignedLong>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
 
commit(DOMDataTreeWriteTransaction, Collection<DOMStoreThreePhaseCommitCohort>) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
Submits a transaction asynchronously for commit.
commit(DOMDataTreeWriteTransaction, Collection<DOMStoreThreePhaseCommitCohort>) - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
 
COMMIT - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
COMMIT_PENDING - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
commitCohortActors(Collection<ActorRef>) - Method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState.Builder
 
commitIndex(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
CommitLocalTransactionRequest - Class in org.opendaylight.controller.cluster.access.commands
Request to commit a local transaction.
CommitLocalTransactionRequest(TransactionIdentifier, long, ActorRef, DataTreeModification, Exception, boolean) - Constructor for class org.opendaylight.controller.cluster.access.commands.CommitLocalTransactionRequest
 
CommitStatsMXBean - Interface in org.opendaylight.controller.cluster.datastore.jmx.mbeans
MXBean interface for retrieving write Tx commit statistics.
CommitStatsMXBeanImpl - Class in org.opendaylight.controller.cluster.datastore.jmx.mbeans
Implementation of the CommitStatsMXBean interface.
CommitStatsMXBeanImpl(DurationStatisticsTracker, String) - Constructor for class org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBeanImpl
Constructor.
COMMITTED - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
CommitTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
 
CommitTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
 
CommitTransaction(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
 
CommitTransactionPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
Payload persisted when a transaction commits.
CommitTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
CommitTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
 
CommonConfig - Class in org.opendaylight.controller.cluster.common.actor
 
CommonConfig(Config) - Constructor for class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
CommonConfig.Builder<T extends CommonConfig.Builder<T>> - Class in org.opendaylight.controller.cluster.common.actor
 
compareTo(FrontendType) - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
compareTo(MemberName) - Method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
complete(Response<?, ?>) - Method in class org.opendaylight.controller.cluster.access.client.ConnectionEntry
 
COMPOSITE - Static variable in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
CompositeModification - Interface in org.opendaylight.controller.cluster.datastore.modification
CompositeModification contains a list of modifications that need to be applied to the DOMStore.
CompositeOnComplete<T> - Class in org.opendaylight.controller.cluster.datastore.utils
An OnComplete implementation that aggrgates other OnComplete tasks.
CompositeOnComplete() - Constructor for class org.opendaylight.controller.cluster.datastore.utils.CompositeOnComplete
 
ConcurrentDOMDataBroker - Class in org.opendaylight.controller.cluster.databroker
ConcurrentDOMDataBroker commits transactions concurrently.
ConcurrentDOMDataBroker(Map<LogicalDatastoreType, DOMStore>, Executor) - Constructor for class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
 
ConcurrentDOMDataBroker(Map<LogicalDatastoreType, DOMStore>, Executor, DurationStatisticsTracker) - Constructor for class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
 
config() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
 
Config - org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
 
configHolder - Variable in class org.opendaylight.controller.cluster.common.actor.AbstractConfig.Builder
 
ConfigParams - Interface in org.opendaylight.controller.cluster.raft
Configuration Parameter interface for configuring the Raft consensus system.
configuration(Configuration) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
Configuration - Interface in org.opendaylight.controller.cluster.datastore.config
 
ConfigurationImpl - Class in org.opendaylight.controller.cluster.datastore.config
 
ConfigurationImpl(String, String) - Constructor for class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
ConfigurationImpl(ModuleShardConfigProvider) - Constructor for class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
configurationReader(AkkaConfigurationReader) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ConnectClientFailure - Class in org.opendaylight.controller.cluster.access.commands
A RequestFailure reported when ConnectClientRequest fails.
ConnectClientRequest - Class in org.opendaylight.controller.cluster.access.commands
Request to connect a frontend instance to the backend.
ConnectClientRequest(ClientIdentifier, ActorRef, ABIVersion, ABIVersion) - Constructor for class org.opendaylight.controller.cluster.access.commands.ConnectClientRequest
 
ConnectClientSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to an ConnectClientRequest.
ConnectClientSuccess(ClientIdentifier, long, ActorRef, List<ActorSelection>, ReadOnlyDataTree, int) - Constructor for class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
 
ConnectedClientConnection<T extends BackendInfo> - Class in org.opendaylight.controller.cluster.access.client
 
ConnectingClientConnection<T extends BackendInfo> - Class in org.opendaylight.controller.cluster.access.client
 
ConnectionEntry - Class in org.opendaylight.controller.cluster.access.client
Single entry in a AbstractClientConnection.
connectionUp(ConnectedClientConnection<T>) - Method in class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
Callback invoked when a new connection has been established.
contains(long) - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
contains(UnsignedLong) - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
contains(I) - Method in class org.opendaylight.controller.remote.rpc.registry.AbstractRoutingTable
 
context - Variable in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Information about the RaftActor whose behavior this class represents.
context() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActorBehavior
Return an AbstractClientActorContext associated with this AbstractClientActor.
context() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
 
convertPendingTransactionsToMessages() - Method in class org.opendaylight.controller.cluster.datastore.Shard
Clears all pending transactions and converts them to messages to be forwarded to a new leader.
convertSnapshot(ByteSource) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
cookie() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
 
copy() - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
copyOf(ElectionTerm) - Static method in class org.opendaylight.controller.cluster.raft.ImmutableElectionTerm
 
create() - Static method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
create(RangeSet<UnsignedLong>) - Static method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
create(String, MemberName, String) - Static method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
create(Executor) - Static method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
Creates a new bean if the backing executor is a ThreadPoolExecutor.
create(Executor, String, String) - Static method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
Creates a new bean if the backing executor is a ThreadPoolExecutor and registers it.
create(Executor, String, String, String) - Static method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
Creates a new bean if the backing executor is a ThreadPoolExecutor and registers it.
create(ClientIdentifier, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.DisableTrackingPayload
 
create(FrontendIdentifier, long) - Static method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
create(LocalHistoryIdentifier, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.CloseLocalHistoryPayload
 
create(LocalHistoryIdentifier, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.CreateLocalHistoryPayload
 
create(LocalHistoryIdentifier, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.PurgeLocalHistoryPayload
 
create(MemberName, FrontendType) - Static method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
create(TransactionIdentifier, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.AbortTransactionPayload
 
create(TransactionIdentifier, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.PurgeTransactionPayload
 
create(TransactionIdentifier, DataTreeCandidate) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
 
create(TransactionIdentifier, DataTreeCandidate, PayloadVersion) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
 
create(TransactionIdentifier, DataTreeCandidate, PayloadVersion, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
 
create(Snapshot.State, List<ReplicatedLogEntry>, long, long, long, long, long, String, ServerConfigurationPayload) - Static method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
create(NotificationPattern, String, EventSourceTopology) - Static method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopic
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class org.opendaylight.controller.cluster.common.actor.MeteredBoundedMailbox
 
create(Option<ActorRef>, Option<ActorSystem>) - Method in class org.opendaylight.controller.cluster.common.actor.UnboundedDequeBasedControlAwareMailbox
 
createAkkaConfig(AkkaConfigurationReader) - Static method in class org.opendaylight.controller.cluster.akka.impl.AkkaConfigFactory
 
createBehavior(RaftActorContext, RaftState) - Static method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
createClassLoader(BundleContext) - Static method in class org.opendaylight.controller.cluster.akka.osgi.impl.BundleClassLoaderFactory
 
createDistributedShard(DOMDataTreeIdentifier, Collection<MemberName>) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardedDOMDataTree
 
createDistributedShard(DOMDataTreeIdentifier, Collection<MemberName>) - Method in interface org.opendaylight.controller.cluster.sharding.DistributedShardFactory
Register a new shard that is rooted at the desired prefix with replicas on the provided members.
createDistributedShard(DOMDataTreeIdentifier, Collection<MemberName>) - Method in class org.opendaylight.controller.cluster.sharding.OSGiDistributedShardedDOMDataTree
 
createFailure(T, long, RequestException) - Method in class org.opendaylight.controller.cluster.access.concepts.AbstractRequestFailureProxy
 
createInputStream(ByteSource) - Method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
 
createInputStream(File) - Method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
 
createInstance(ActorSystemProvider, DatastoreContext, DatastoreContextIntrospector, DatastoreSnapshotRestore, Configuration) - Static method in class org.opendaylight.controller.cluster.datastore.DistributedDataStoreFactory
 
createInstance(DOMRpcProviderService, DOMRpcService, ActorSystem, RemoteOpsProviderConfig, DOMActionProviderService, DOMActionService) - Static method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderFactory
 
createInstance(DOMSchemaService, DatastoreContext, DatastoreSnapshotRestore, ActorSystemProvider, DatastoreContextIntrospector, DatastoreContextPropertiesUpdater) - Static method in class org.opendaylight.controller.cluster.datastore.DistributedDataStoreFactory
 
createInstance(DOMSchemaService, DatastoreContext, DatastoreSnapshotRestore, ActorSystemProvider, DatastoreContextIntrospector, DatastoreContextPropertiesUpdater, Configuration) - Static method in class org.opendaylight.controller.cluster.datastore.DistributedDataStoreFactory
 
createLocalHistory() - Method in interface org.opendaylight.controller.cluster.databroker.actors.dds.DataStoreClient
Create a new local history.
CreateLocalHistoryPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
Payload persisted when a local history is created.
CreateLocalHistoryRequest - Class in org.opendaylight.controller.cluster.access.commands
Request to create a new local history.
CreateLocalHistoryRequest(LocalHistoryIdentifier, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.CreateLocalHistoryRequest
 
createMergingTransactionChain(DOMTransactionChainListener) - Method in class org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker
 
createObject(T, byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.AbstractProxy
 
createOperation(DOMDataTreeWriteCursor) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardModification
 
createOutputStream(File) - Method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
 
createProducer(Collection<DOMDataTreeIdentifier>) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardedDOMDataTree
 
createProducer(Collection<DOMDataTreeIdentifier>) - Method in class org.opendaylight.controller.cluster.sharding.OSGiDistributedShardedDOMDataTree
 
createProps(BundleContext, Config) - Static method in class org.opendaylight.controller.cluster.akka.osgi.impl.QuarantinedMonitorActorPropsFactory
 
createReceive() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActor
 
createReceive() - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
 
createReceive() - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
createReceiveRecover() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActor
 
createReceiveRecover() - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
createRequest(T, long, ActorRef) - Method in class org.opendaylight.controller.cluster.access.concepts.AbstractRequestProxy
 
CreateShard - Class in org.opendaylight.controller.cluster.datastore.messages
A message sent to the ShardManager to dynamically create a new shard.
CreateShard(ModuleShardConfiguration, Shard.AbstractBuilder<?, ?>, DatastoreContext) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateShard
Constructor.
createSnapshot() - Method in interface org.opendaylight.controller.cluster.databroker.actors.dds.DataStoreClient
Create a new free-standing snapshot.
createSnapshot(ActorRef, Optional<OutputStream>) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorSnapshotCohort
This method is called by the RaftActor when a snapshot needs to be created.
createSnapshot(ActorRef, Optional<OutputStream>) - Method in class org.opendaylight.controller.cluster.raft.NoopRaftActorSnapshotCohort
 
createSuccess(T, long) - Method in class org.opendaylight.controller.cluster.access.concepts.AbstractSuccessProxy
 
createTopic(CreateTopicInput) - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopology
 
createTopic(CreateTopicInput) - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.EventAggregatorService
Create a new topic.
CreateTopicInput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
This class represents the following YANG schema fragment defined in module event-aggregator
CreateTopicInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Class that builds CreateTopicInputBuilder instances.
CreateTopicInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
CreateTopicInputBuilder(CreateTopicInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
CreateTopicOutput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
This class represents the following YANG schema fragment defined in module event-aggregator
CreateTopicOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Class that builds CreateTopicOutputBuilder instances.
CreateTopicOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
 
CreateTopicOutputBuilder(CreateTopicOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
 
createTransaction() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractClientHistory
Allocate a new ClientTransaction.
createTransaction() - Method in interface org.opendaylight.controller.cluster.databroker.actors.dds.DataStoreClient
Create a new free-standing transaction.
createTransaction(LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
 
createTransaction(LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerReadOnlyTransaction
 
createTransaction(LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerReadWriteTransaction
 
createTransaction(LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerWriteOnlyTransaction
 
CreateTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
 
CreateTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
CreateTransaction(TransactionIdentifier, int, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
createTransactionChain() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
 
createTransactionChain() - Method in class org.opendaylight.controller.cluster.datastore.DistributedDataStore
 
createTransactionChain() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
createTransactionChain(DOMTransactionChainListener) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBroker
 
createTransactionChain(DOMTransactionChainListener) - Method in class org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker
 
CreateTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
CreateTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
CreateTransactionReply(String, TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
current() - Static method in enum org.opendaylight.controller.cluster.access.ABIVersion
Return the codebase-native ABI version.
current() - Static method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Return the codebase-native persistence version.
current() - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
CURRENT_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
 
CURRENT_VERSION - Static variable in class org.opendaylight.controller.cluster.raft.RaftVersions
 
currentTerm() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the current election term.
currentTerm(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
currentTime() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
 
customRaftPolicyClassName(String) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
customRaftPolicyImplementation(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 

D

dataExists(AbstractShardDataTreeTransaction<?>, DataExists) - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
dataExists(DataExists) - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
 
DataExists - Class in org.opendaylight.controller.cluster.datastore.messages
 
DataExists() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExists
 
DataExists(YangInstanceIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExists
 
DataExistsReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
DataExistsReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
 
DataExistsReply(boolean, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
 
DataPersistenceProvider - Interface in org.opendaylight.controller.cluster
DataPersistenceProvider provides methods to persist data and is an abstraction of the akka-persistence persistence API.
dataSize() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
dataSize() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Returns the size of the data in the log (in bytes).
DataStoreClient - Interface in org.opendaylight.controller.cluster.databroker.actors.dds
Client interface for interacting with the frontend actor.
DatastoreConfigurationMXBean - Interface in org.opendaylight.controller.cluster.datastore.jmx.mbeans
MXBean interface for data store configuration.
DatastoreConfigurationMXBeanImpl - Class in org.opendaylight.controller.cluster.datastore.jmx.mbeans
Implementation of DatastoreConfigurationMXBean.
DatastoreConfigurationMXBeanImpl(String) - Constructor for class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
datastoreContext(DatastoreContext) - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
DatastoreContext - Class in org.opendaylight.controller.cluster.datastore
Contains contextual data for a data store.
DatastoreContext.Builder - Class in org.opendaylight.controller.cluster.datastore
 
datastoreContextFactory(DatastoreContextFactory) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
DatastoreContextFactory - Class in org.opendaylight.controller.cluster.datastore
Factory for creating DatastoreContext instances.
DatastoreContextFactory(DatastoreContextIntrospector) - Constructor for class org.opendaylight.controller.cluster.datastore.DatastoreContextFactory
 
DatastoreContextIntrospector - Class in org.opendaylight.controller.cluster.datastore
Introspects on a DatastoreContext instance to set its properties via reflection.
DatastoreContextIntrospector(DatastoreContext, DataStorePropertiesContainer) - Constructor for class org.opendaylight.controller.cluster.datastore.DatastoreContextIntrospector
 
DatastoreContextIntrospectorFactory - Interface in org.opendaylight.controller.cluster.datastore
Factory for creating DatastoreContextIntrospector instances.
DatastoreContextPropertiesUpdater - Class in org.opendaylight.controller.cluster.datastore
Update DatastoreContext settings on invoke update method.
DatastoreContextPropertiesUpdater(DatastoreContextIntrospector, Map<String, Object>) - Constructor for class org.opendaylight.controller.cluster.datastore.DatastoreContextPropertiesUpdater
Base init of updater for DatastoreContext settings with base properties.
DatastoreContextPropertiesUpdater.Listener - Interface in org.opendaylight.controller.cluster.datastore
 
DatastoreInfoMXBean - Interface in org.opendaylight.controller.cluster.datastore.jmx.mbeans
JMX bean for general datastore info.
DatastoreInfoMXBeanImpl - Class in org.opendaylight.controller.cluster.datastore.jmx.mbeans
Implementation of DatastoreInfoMXBean.
DatastoreInfoMXBeanImpl(String, ActorUtils) - Constructor for class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBeanImpl
 
dataStoreMXBeanType(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
dataStoreName(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
DataStoreProperties - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
DataStorePropertiesContainer - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
DataStorePropertiesContainerBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
Class that builds DataStorePropertiesContainerBuilder instances.
DataStorePropertiesContainerBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
DataStorePropertiesContainerBuilder(DataStoreProperties) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
DataStorePropertiesContainerBuilder(DataStorePropertiesContainer) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
DatastoreShardId - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Grouping holding combined identifiers of a shard -- its name and datastore type
DatastoreSnapshot - Class in org.opendaylight.controller.cluster.datastore.persisted
Stores a snapshot of the internal state of a data store.
DatastoreSnapshot(String, ShardManagerSnapshot, List<DatastoreSnapshot.ShardSnapshot>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot
 
DatastoreSnapshot.ShardSnapshot - Class in org.opendaylight.controller.cluster.datastore.persisted
 
DatastoreSnapshotList - Class in org.opendaylight.controller.cluster.datastore.persisted
Stores a list of DatastoreSnapshot instances.
DatastoreSnapshotList() - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshotList
 
DatastoreSnapshotList(List<DatastoreSnapshot>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshotList
 
DatastoreSnapshotRestore - Interface in org.opendaylight.controller.cluster.datastore
This class looks for a previously saved data store backup file in a directory and, if found, de-serializes the DatastoreSnapshot instances.
DataStoreType - Enum in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
DataStoreVersions - Class in org.opendaylight.controller.cluster.datastore
Defines version numbers where ask-based protocol is concerned.
dataTree(DataTree) - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
DataTreeCandidateInputOutput - Class in org.opendaylight.controller.cluster.datastore.persisted
Utility serialization/deserialization for DataTreeCandidate.
DataTreeCandidateInputOutput.DataTreeCandidateWithVersion - Class in org.opendaylight.controller.cluster.datastore.persisted
 
DataTreeCandidateWithVersion(DataTreeCandidate, NormalizedNodeStreamVersion) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
 
DataTreeChanged - Class in org.opendaylight.controller.cluster.datastore.messages
A message about a DataTree having been changed.
DataTreeChanged(Collection<DataTreeCandidate>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataTreeChanged
 
DataTreeChangedReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
DataTreeCohortRegistrationProxy<C extends DOMDataTreeCommitCohort> - Class in org.opendaylight.controller.cluster.datastore
 
DataTreeListenerInfo - Class in org.opendaylight.controller.cluster.datastore.messages
Response to a GetInfo query from a data tree listener actor.
DataTreeListenerInfo(String, String, boolean, long) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataTreeListenerInfo
 
DataTreeModificationOutput - Class in org.opendaylight.controller.cluster.datastore.utils
Utility class to output DataTreeModifications in readable format.
DataTreeNotificationListenerRegistrationActor - Class in org.opendaylight.controller.cluster.datastore.actors
Actor co-located with a shard.
DataTreeNotificationListenerRegistrationActor() - Constructor for class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor
 
DataTreeNotificationListenerRegistrationActor.SetRegistration - Class in org.opendaylight.controller.cluster.datastore.actors
 
Deactive - org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
 
DeadHistoryException - Exception in org.opendaylight.controller.cluster.access.commands
A RequestException indicating that the backend has received a request to create a history which has already been retired.
DeadHistoryException(RangeSet<UnsignedLong>) - Constructor for exception org.opendaylight.controller.cluster.access.commands.DeadHistoryException
 
DeadTransactionException - Exception in org.opendaylight.controller.cluster.access.commands
A RequestException indicating that the backend has received a request to create a transaction which has already been purged.
DeadTransactionException(RangeSet<UnsignedLong>) - Constructor for exception org.opendaylight.controller.cluster.access.commands.DeadTransactionException
 
decrNextIndex(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Decrements the value of the follower's next index, taking into account its reported last log index.
DEFAULT_BACKEND_ALIVE_TIMEOUT_NANOS - Static variable in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
Backend aliveness timer.
DEFAULT_CONFIGURATION_READER - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
DEFAULT_HEARTBEAT_INTERVAL_IN_MILLIS - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_INITIAL_PAYLOAD_SERIALIZED_BUFFER_CAPACITY - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_INITIAL_SETTLE_TIMEOUT_MULTIPLIER - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_ISOLATED_LEADER_CHECK_INTERVAL_IN_MILLIS - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_JOURNAL_RECOVERY_BATCH_SIZE - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_MAX_MESSAGE_SLICE_SIZE - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_MAX_SLICING_TRIES - Static variable in class org.opendaylight.controller.cluster.messaging.MessageSlicer
 
DEFAULT_NAME - Static variable in class org.opendaylight.controller.cluster.datastore.Shard
 
DEFAULT_NO_PROGRESS_TIMEOUT_NANOS - Static variable in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
No progress timeout.
DEFAULT_OPERATION_TIMEOUT_IN_MS - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_PERSISTENT - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_RECOVERY_SNAPSHOT_INTERVAL_SECONDS - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_REQUEST_TIMEOUT_NANOS - Static variable in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
Request timeout.
DEFAULT_SHARD - Static variable in class org.opendaylight.controller.cluster.datastore.shardstrategy.DefaultShardStrategy
 
DEFAULT_SHARD_BATCHED_MODIFICATION_COUNT - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_CANDIDATE_ELECTION_TIMEOUT_DIVISOR - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_COMMIT_QUEUE_EXPIRY_TIMEOUT_IN_MS - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_ELECTION_TIMEOUT_FACTOR - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_INITIALIZATION_TIMEOUT - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_LEADER_ELECTION_TIMEOUT - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_SNAPSHOT_DATA_THRESHOLD - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_SNAPSHOT_DATA_THRESHOLD_PERCENTAGE - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_TRANSACTION_IDLE_TIMEOUT - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_TX_COMMIT_QUEUE_CAPACITY - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHARD_TX_COMMIT_TIMEOUT_IN_SECONDS - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SHUTDOWN_SECONDS - Static variable in class org.opendaylight.controller.config.yang.netty.eventexecutor.AutoCloseableEventExecutor.CloseableEventExecutorMixin
 
DEFAULT_SNAPSHOT_BATCH_COUNT - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SNAPSHOT_ON_ROOT_OVERWRITE - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_SYNC_INDEX_THRESHOLD - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DEFAULT_TX_CREATION_INITIAL_RATE_LIMIT - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
DefaultConfigParamsImpl - Class in org.opendaylight.controller.cluster.raft
Default implementation of the ConfigParams.
DefaultConfigParamsImpl() - Constructor for class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
DefaultDatastoreContextIntrospectorFactory - Class in org.opendaylight.controller.cluster.datastore
 
DefaultDatastoreContextIntrospectorFactory(BindingNormalizedNodeSerializer) - Constructor for class org.opendaylight.controller.cluster.datastore.DefaultDatastoreContextIntrospectorFactory
 
DefaultDatastoreSnapshotRestore - Class in org.opendaylight.controller.cluster.datastore
This class looks for a previously saved data store backup file in a directory and, if found, de-serializes the DatastoreSnapshot instances.
DefaultDatastoreSnapshotRestore() - Constructor for class org.opendaylight.controller.cluster.datastore.DefaultDatastoreSnapshotRestore
 
DefaultDatastoreSnapshotRestore(String) - Constructor for class org.opendaylight.controller.cluster.datastore.DefaultDatastoreSnapshotRestore
 
DefaultRaftPolicy - Class in org.opendaylight.controller.cluster.raft.policy
 
DefaultRaftPolicy() - Constructor for class org.opendaylight.controller.cluster.raft.policy.DefaultRaftPolicy
 
DefaultShardStrategy - Class in org.opendaylight.controller.cluster.datastore.shardstrategy
The DefaultShardStrategy basically puts all data into the default shard.
delegate() - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
 
DelegatingPersistentDataProvider - Class in org.opendaylight.controller.cluster
A DataPersistenceProvider implementation that delegates to another implementation.
DelegatingPersistentDataProvider(DataPersistenceProvider) - Constructor for class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
delete(LogicalDatastoreType, YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerWriteTransaction
 
delete(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
 
delete(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
delete(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
 
delete(YangInstanceIdentifier.PathArgument) - Method in class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
 
DELETE - Static variable in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
DeleteEntries - Class in org.opendaylight.controller.cluster.raft.persisted
Internal message that is stored in the akka's persistent journal to delete journal entries.
DeleteEntries(long) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.DeleteEntries
 
deleteMessages(long) - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
Deletes journal entries up to the given sequence number.
deleteMessages(long) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
deleteMessages(long) - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
deleteMessages(long) - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
 
DeleteModification - Class in org.opendaylight.controller.cluster.datastore.modification
DeleteModification store all the parameters required to delete a path from the data tree.
DeleteModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
DeleteModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
DeleteModification(YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
deleteSnapshots(SnapshotSelectionCriteria) - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
Deletes snapshots based on the given criteria.
deleteSnapshots(SnapshotSelectionCriteria) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
deleteSnapshots(SnapshotSelectionCriteria) - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
deleteSnapshots(SnapshotSelectionCriteria) - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
 
deserialize(ObjectInput) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.ShardDataTreeSnapshot
 
deserializeSnapshot(ByteSource) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorSnapshotCohort
This method is called to de-serialize snapshot data that was previously serialized via RaftActorSnapshotCohort.createSnapshot(akka.actor.ActorRef, java.util.Optional<java.io.OutputStream>) to a State instance.
deserializeSnapshot(ByteSource) - Method in class org.opendaylight.controller.cluster.raft.NoopRaftActorSnapshotCohort
 
DestroyLocalHistoryRequest - Class in org.opendaylight.controller.cluster.access.commands
Request to destroy a local history.
DestroyLocalHistoryRequest(LocalHistoryIdentifier, long, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.DestroyLocalHistoryRequest
 
destroyTopic(DestroyTopicInput) - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopology
 
destroyTopic(DestroyTopicInput) - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.EventAggregatorService
Destroy a topic.
DestroyTopicInput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
This class represents the following YANG schema fragment defined in module event-aggregator
DestroyTopicInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Class that builds DestroyTopicInputBuilder instances.
DestroyTopicInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
 
DestroyTopicInputBuilder(DestroyTopicInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
 
DestroyTopicOutput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
 
DestroyTopicOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Class that builds DestroyTopicOutputBuilder instances.
DestroyTopicOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutputBuilder
 
DestroyTopicOutputBuilder(DestroyTopicOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutputBuilder
 
directCommit(Boolean) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
DisableElectionsRaftPolicy - Class in org.opendaylight.controller.cluster.raft.policy
DisableElectionsRaftPolicy can be used for actors that does not participate in shard election.
DisableElectionsRaftPolicy() - Constructor for class org.opendaylight.controller.cluster.raft.policy.DisableElectionsRaftPolicy
 
DisableTrackingPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
 
disJoinTopic(DisJoinTopicInput) - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceService
 
DisJoinTopicInput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
This class represents the following YANG schema fragment defined in module event-source
DisJoinTopicInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Class that builds DisJoinTopicInputBuilder instances.
DisJoinTopicInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
DisJoinTopicInputBuilder(DisJoinTopicInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
DisJoinTopicOutput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
 
DisJoinTopicOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Class that builds DisJoinTopicOutputBuilder instances.
DisJoinTopicOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutputBuilder
 
DisJoinTopicOutputBuilder(DisJoinTopicOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutputBuilder
 
dispatchers() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
 
Dispatchers - Class in org.opendaylight.controller.cluster.common.actor
 
Dispatchers(Dispatchers) - Constructor for class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
Dispatchers.DispatcherType - Enum in org.opendaylight.controller.cluster.common.actor
 
distributedDataStore(AbstractDataStore) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
DistributedDataStore - Class in org.opendaylight.controller.cluster.datastore
Implements a distributed DOMStore using Akka Patterns.ask().
DistributedDataStore(ActorSystem, ClusterWrapper, Configuration, DatastoreContextFactory, DatastoreSnapshot) - Constructor for class org.opendaylight.controller.cluster.datastore.DistributedDataStore
 
DistributedDataStoreClientActor - Class in org.opendaylight.controller.cluster.databroker.actors.dds
A AbstractClientActor which acts as the point of contact for DistributedDataStore.
DistributedDataStoreFactory - Class in org.opendaylight.controller.cluster.datastore
 
DistributedDataStoreInterface - Interface in org.opendaylight.controller.cluster.datastore
The public interface exposed by an AbstractDataStore via the OSGi registry.
DistributedDatastoreProviderData - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
This module contains the base YANG definitions for the distributed datastore provider implementation
DistributedShardChangePublisher - Class in org.opendaylight.controller.cluster.sharding
 
DistributedShardChangePublisher(DataStoreClient, DistributedDataStoreInterface, DOMDataTreeIdentifier, Map<DOMDataTreeIdentifier, ChildShardContext>) - Constructor for class org.opendaylight.controller.cluster.sharding.DistributedShardChangePublisher
 
DistributedShardedDOMDataTree - Class in org.opendaylight.controller.cluster.sharding
A layer on top of DOMDataTreeService that distributes producer/shard registrations to remote nodes via ShardedDataTreeActor.
DistributedShardedDOMDataTree(ActorSystemProvider, DistributedDataStoreInterface, DistributedDataStoreInterface) - Constructor for class org.opendaylight.controller.cluster.sharding.DistributedShardedDOMDataTree
 
DistributedShardFactory - Interface in org.opendaylight.controller.cluster.sharding
A factory that handles addition of new clustered shard's based on a prefix.
DistributedShardModification - Class in org.opendaylight.controller.cluster.sharding
Shard modification that consists of the whole shard context, provides cursors which correctly delegate to subshards if any are present.
DistributedShardModification(DistributedShardModificationContext, Map<YangInstanceIdentifier.PathArgument, WriteableModificationNode>, Map<DOMDataTreeIdentifier, ForeignShardModificationContext>) - Constructor for class org.opendaylight.controller.cluster.sharding.DistributedShardModification
 
DistributedShardModificationContext - Class in org.opendaylight.controller.cluster.sharding
The context for a single shards modification, keeps a ClientTransaction so it can route requests correctly.
DistributedShardModificationContext(ClientTransaction, DOMDataTreeIdentifier) - Constructor for class org.opendaylight.controller.cluster.sharding.DistributedShardModificationContext
 
DistributedShardModificationCursor - Class in org.opendaylight.controller.cluster.sharding
Internal cursor implementation consisting of WriteCursorStrategies which forwards writes to foreign modifications if any.
DistributedShardModificationCursor(DistributedShardModification, ShardProxyTransaction) - Constructor for class org.opendaylight.controller.cluster.sharding.DistributedShardModificationCursor
 
DistributedShardModificationFactory - Class in org.opendaylight.controller.cluster.sharding
DistributedShardModificationFactoryBuilder - Class in org.opendaylight.controller.cluster.sharding
DistributedShardModificationFactoryBuilder(DOMDataTreeIdentifier) - Constructor for class org.opendaylight.controller.cluster.sharding.DistributedShardModificationFactoryBuilder
 
DistributedShardRegistration - Interface in org.opendaylight.controller.cluster.sharding
Registration of the CDS shard that allows you to remove the shard from the system by closing the registration.
doAsk(ActorRef, Object, Timeout) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
doAsk(ActorSelection, Object, Timeout) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
doDeleteAsync(SnapshotMetadata) - Method in class org.opendaylight.controller.cluster.persistence.LocalSnapshotStore
 
doDeleteAsync(String, SnapshotSelectionCriteria) - Method in class org.opendaylight.controller.cluster.persistence.LocalSnapshotStore
 
DOES_NOT_EXIST - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
For a RemoveServer request, the server to remove does not exist.
doLoadAsync(String, SnapshotSelectionCriteria) - Method in class org.opendaylight.controller.cluster.persistence.LocalSnapshotStore
 
DOMAIN - Static variable in class org.opendaylight.controller.cluster.common.actor.MeteringBehavior
 
DOMBrokerReadOnlyTransaction - Class in org.opendaylight.controller.cluster.databroker
 
DOMBrokerReadOnlyTransaction(Object, Map<LogicalDatastoreType, ? extends DOMStoreTransactionFactory>) - Constructor for class org.opendaylight.controller.cluster.databroker.DOMBrokerReadOnlyTransaction
Creates new composite Transactions.
DOMBrokerReadWriteTransaction - Class in org.opendaylight.controller.cluster.databroker
 
DOMBrokerReadWriteTransaction(Object, Map<LogicalDatastoreType, ? extends DOMStoreTransactionFactory>, AbstractDOMTransactionFactory<?>) - Constructor for class org.opendaylight.controller.cluster.databroker.DOMBrokerReadWriteTransaction
Constructs an instance.
DOMBrokerWriteOnlyTransaction - Class in org.opendaylight.controller.cluster.databroker
 
DOMBrokerWriteOnlyTransaction(Object, Map<LogicalDatastoreType, ? extends DOMStoreTransactionFactory>, AbstractDOMTransactionFactory<?>) - Constructor for class org.opendaylight.controller.cluster.databroker.DOMBrokerWriteOnlyTransaction
Constructs an instance.
DOMDataTreeShardCreationFailedException - Exception in org.opendaylight.controller.cluster.sharding
Exception thrown when there was a at any point during the creation of a shard via DistributedShardFactory.
DOMDataTreeShardCreationFailedException(String) - Constructor for exception org.opendaylight.controller.cluster.sharding.DOMDataTreeShardCreationFailedException
 
DOMDataTreeShardCreationFailedException(String, Throwable) - Constructor for exception org.opendaylight.controller.cluster.sharding.DOMDataTreeShardCreationFailedException
 
doSaveAsync(SnapshotMetadata, Object) - Method in class org.opendaylight.controller.cluster.persistence.LocalSnapshotStore
 
Down - org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
 
duplicate() - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
Return a new instance, which is backed but the same DataSchemaContextTree, but does not share any state and is uninitialized.

E

electionDuration() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns a duration for election with an additional variance for randomness.
electionDuration() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
ElectionTerm - Interface in org.opendaylight.controller.cluster.raft
ElectionTerm contains information about a RaftActors election term.
ElectionTimeout - Class in org.opendaylight.controller.cluster.raft.base.messages
Local message sent to indicate the current election term has timed out.
EmptyExternalizable - Class in org.opendaylight.controller.cluster.datastore.messages
Externalizable with no data.
EmptyExternalizable() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.EmptyExternalizable
 
EmptyExternalizableProxy - Class in org.opendaylight.controller.cluster.raft.base.messages
Abstract base that implements Externalizable with no-op methods that is intended for classes that use the externalizable proxy pattern but have no data to serialize and read-resolve to a static instance.
EmptyExternalizableProxy(Object) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.EmptyExternalizableProxy
 
EmptyState - Class in org.opendaylight.controller.cluster.raft.persisted
Empty Snapshot State implementation.
Emulated - org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
 
enableMetricCapture(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
EnableNotification - Class in org.opendaylight.controller.cluster.datastore.messages
 
EnableNotification(boolean, String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.EnableNotification
 
enqueueEntry(ConnectionEntry, long) - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
Enqueue an entry, possibly also transmitting it.
enqueueRequest(Request<?, ?>, Consumer<Response<?, ?>>, long) - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
Send a request to the backend and invoke a specified callback when it finishes.
enter(Iterable<YangInstanceIdentifier.PathArgument>) - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
enter(YangInstanceIdentifier.PathArgument) - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
enter(YangInstanceIdentifier.PathArgument...) - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
Envelope<T extends Message<?,​?>> - Class in org.opendaylight.controller.cluster.access.concepts
 
equals(Object) - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
equals(Object) - Method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
equals(Object) - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
equals(Object) - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
equals(Object) - Method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
equals(Object) - Method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
equals(Object) - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
equals(Object) - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
equals(Object) - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier
 
equals(Object) - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
 
equals(Object) - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
 
equals(Object) - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.Pattern
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicId
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorKey
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRef
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierKey
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.MemberName
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsKey
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultKey
 
equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardKey
 
error() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker.Context
 
estimatedSerializedSize() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
EventAggregatorListener - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Interface for implementing the following YANG notifications defined in module event-aggregator
EventAggregatorService - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Interface for implementing the following YANG RPCs defined in module event-aggregator
EventSource - Interface in org.opendaylight.controller.messagebus.spi
Event source is a node in topology which is able to produce notifications.
EventSourceListener - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Interface for implementing the following YANG notifications defined in module event-source
EventSourceRegistration<T extends EventSource> - Interface in org.opendaylight.controller.messagebus.spi
Instance of EventSourceRegistration is returned by EventSourceRegistry.registerEventSource(EventSource) and it is used to unregister EventSource.
EventSourceRegistry - Interface in org.opendaylight.controller.messagebus.spi
EventSourceRegistry is used to register EventSource.
EventSourceService - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Interface for implementing the following YANG RPCs defined in module event-source
EventSourceStatus - Enum in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
 
EventSourceStatusNotification - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Notification of change event source status.
EventSourceStatusNotificationBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Class that builds EventSourceStatusNotificationBuilder instances.
EventSourceStatusNotificationBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
 
EventSourceStatusNotificationBuilder(EventSourceStatusNotification) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
 
EventSourceTopic - Class in org.opendaylight.controller.messagebus.app.impl
 
EventSourceTopology - Class in org.opendaylight.controller.messagebus.app.impl
 
EventSourceTopology(DataBroker, RpcProviderService, RpcConsumerRegistry) - Constructor for class org.opendaylight.controller.messagebus.app.impl.EventSourceTopology
 
execute(ClientActorBehavior<T>) - Method in interface org.opendaylight.controller.cluster.access.client.InternalCommand
Run command actions.
execute(Runnable) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
ExecuteAction - Class in org.opendaylight.controller.remote.rpc.messages
 
executeDelete(YangInstanceIdentifier, Boolean) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
executeInActor(InternalCommand<T>) - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
Execute a command in the context of the client actor.
executeInActor(InternalCommand<T>, FiniteDuration) - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
 
executeInSelf(Runnable) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
 
executeInSelf(Runnable) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
executeInSelf(Runnable) - Method in interface org.opendaylight.controller.cluster.common.actor.ExecuteInSelfActor
Run a Runnable in the context of this actor.
ExecuteInSelfActor - Interface in org.opendaylight.controller.cluster.common.actor
Interface implemented by Actors, who can schedule invocation of a Procedure in their context.
executeMerge(YangInstanceIdentifier, NormalizedNode<?, ?>, Boolean) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
executeOperation(ActorRef, Object) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Executes an operation on a local actor and wait for it's response.
executeOperation(ActorSelection, Object) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Execute an operation on a remote actor and wait for it's response.
executeOperationAsync(ActorRef, Object, Timeout) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
executeOperationAsync(ActorSelection, Object) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Execute an operation on a remote actor asynchronously.
executeOperationAsync(ActorSelection, Object, Timeout) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Execute an operation on a remote actor asynchronously.
executeRead(AbstractRead<T>, SettableFuture<T>, Boolean) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
ExecuteRpc - Class in org.opendaylight.controller.remote.rpc.messages
 
executeWrite(YangInstanceIdentifier, NormalizedNode<?, ?>, Boolean) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
exists() - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
 
exists(LogicalDatastoreType, YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerReadOnlyTransaction
 
exists(LogicalDatastoreType, YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerReadWriteTransaction
 
exists(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientSnapshot
 
exists(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
 
exists(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
ExistsTransactionRequest - Class in org.opendaylight.controller.cluster.access.commands
A transaction request to query if a particular path exists in the current view of a particular transaction.
ExistsTransactionRequest(TransactionIdentifier, long, ActorRef, YangInstanceIdentifier, boolean) - Constructor for class org.opendaylight.controller.cluster.access.commands.ExistsTransactionRequest
 
ExistsTransactionSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to an ExistsTransactionRequest.
ExistsTransactionSuccess(TransactionIdentifier, long, boolean) - Constructor for class org.opendaylight.controller.cluster.access.commands.ExistsTransactionSuccess
 
exit() - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
exit(int) - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
expandQname(List<SchemaPath>, Pattern) - Static method in class org.opendaylight.controller.messagebus.app.util.Util
Method filters qnames based on wildcard strings.
expireStateAfterInactivity(long, TimeUnit) - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler.Builder
Sets the duration and time unit whereby assembled message state is purged from the cache due to inactivity from the slicing component on the other end.
expireStateAfterInactivity(long, TimeUnit) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer.Builder
Sets the duration and time unit whereby sliced message state is purged from the cache and the associated failure callback is notified due to inactivity from the assembling component on the other end.
ExplicitAsk - Class in org.opendaylight.controller.cluster.common.actor
Unfortunately Akka's explicit ask pattern does not work with its Java API, as it fails to invoke passed message.
externalizableProxy() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendShardDataTreeSnapshotMetadata
 
externalizableProxy() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardDataTreeSnapshotMetadata
Return an Externalizable proxy.
externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbortTransactionPayload
 
externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.CloseLocalHistoryPayload
 
externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.CreateLocalHistoryPayload
 
externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.DisableTrackingPayload
 
externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.PurgeLocalHistoryPayload
 
externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.PurgeTransactionPayload
 
externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.AbstractLocalTransactionRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.AbstractReadPathTransactionRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.AbstractReadTransactionRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientFailure
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.CreateLocalHistoryRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.DestroyLocalHistoryRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ExistsTransactionRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ExistsTransactionSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.LocalHistoryFailure
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.LocalHistoryRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.LocalHistorySuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.PurgeLocalHistoryRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ReadTransactionRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.ReadTransactionSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionAbortRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionAbortSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionCanCommitSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionCommitSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionDoCommitRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionFailure
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPreCommitRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPreCommitSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPurgeRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionPurgeResponse
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionRequest
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionSuccess
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.concepts.Request
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.concepts.RequestFailure
 
externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.concepts.RequestSuccess
 
extractCohortPathFrom(ReadyTransactionReply) - Method in class org.opendaylight.controller.cluster.datastore.TransactionReadyReplyMapper
 

F

failed(Identifier, MessageSliceException, ActorRef) - Static method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
 
FAILED - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
failure() - Method in class org.opendaylight.controller.cluster.datastore.TransactionRateLimitingCallback
 
FailureEnvelope - Class in org.opendaylight.controller.cluster.access.concepts
 
FailureEnvelope(RequestFailure<?, ?>, long, long, long) - Constructor for class org.opendaylight.controller.cluster.access.concepts.FailureEnvelope
 
fallback - Variable in class org.opendaylight.controller.cluster.common.actor.AbstractConfig.Builder
 
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1Builder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNodeBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopologyBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
Set fields from given grouping argument.
fieldsFrom(DataObject) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
Set fields from given grouping argument.
FileAkkaConfigurationReader - Class in org.opendaylight.controller.cluster.common.actor
 
FileAkkaConfigurationReader() - Constructor for class org.opendaylight.controller.cluster.common.actor.FileAkkaConfigurationReader
 
fileBackedOutputStream(FileBackedOutputStream) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Sets the FileBackedOutputStream containing the message data to slice.
FileBackedOutputStream - Class in org.opendaylight.controller.cluster.io
An OutputStream that starts buffering to a byte array, but switches to file buffering once the data reaches a configurable size.
FileBackedOutputStream(int, String) - Constructor for class org.opendaylight.controller.cluster.io.FileBackedOutputStream
Creates a new instance that uses the given file threshold, and does not reset the data when the ByteSource returned by FileBackedOutputStream.asByteSource() is finalized.
FileBackedOutputStreamFactory - Class in org.opendaylight.controller.cluster.io
A factory for creating FileBackedOutputStream instances.
FileBackedOutputStreamFactory(int, String) - Constructor for class org.opendaylight.controller.cluster.io.FileBackedOutputStreamFactory
Constructor.
fileBackedStreamFactory(FileBackedOutputStreamFactory) - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler.Builder
Sets the factory for creating FileBackedOutputStream instances used for streaming messages.
fileBackedStreamFactory(FileBackedOutputStreamFactory) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer.Builder
Sets the factory for creating FileBackedOutputStream instances used for streaming messages.
fileBackedStreamingThresholdInMegabytes(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
FileModuleShardConfigProvider - Class in org.opendaylight.controller.cluster.datastore.config
Implementation of ModuleShardConfigProvider that reads the module and shard configuration from files.
FileModuleShardConfigProvider() - Constructor for class org.opendaylight.controller.cluster.datastore.config.FileModuleShardConfigProvider
 
FileModuleShardConfigProvider(String, String) - Constructor for class org.opendaylight.controller.cluster.datastore.config.FileModuleShardConfigProvider
 
findActionByName(String) - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBean
 
findActionByName(String) - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBeanImpl
 
findActionByRoute(String) - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBean
 
findActionByRoute(String) - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBeanImpl
 
FindLeader - Class in org.opendaylight.controller.cluster.raft.client.messages
Request to locate the leader raft actor.
FindLeaderReply - Class in org.opendaylight.controller.cluster.raft.client.messages
Reply to FindLeader message, containing the address of the leader actor, as known to the raft actor which sent the message.
FindLeaderReply(String) - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.FindLeaderReply
 
findLocalShard(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Finds a local shard given its shard name and return it's ActorRef.
FindLocalShard - Class in org.opendaylight.controller.cluster.datastore.messages
FindLocalShard is a message that should be sent to the org.opendaylight.controller.cluster.datastore.shardmanager.ShardManager when we need to find a reference to a LocalShard.
FindLocalShard(String, boolean) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.FindLocalShard
 
findLocalShardAsync(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Finds a local shard async given its shard name and return a Future from which to obtain the ActorRef.
FindPrimary - Class in org.opendaylight.controller.cluster.datastore.messages
The FindPrimary message is used to locate the primary of any given shard.
FindPrimary(String, boolean) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.FindPrimary
 
findPrimaryShardAsync(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
findRpcByName(String) - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBean
 
findRpcByName(String) - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBeanImpl
 
findRpcByRoute(String) - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBean
 
findRpcByRoute(String) - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBeanImpl
 
findShard(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.shardstrategy.DefaultShardStrategy
 
findShard(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.shardstrategy.ModuleShardStrategy
 
findShard(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.shardstrategy.PrefixShardStrategy
 
findShard(YangInstanceIdentifier) - Method in interface org.opendaylight.controller.cluster.datastore.shardstrategy.ShardStrategy
Find the name of the shard in which the data pointed to by the specified path belongs in.
finishReconnect(Collection<ConnectionEntry>) - Method in interface org.opendaylight.controller.cluster.access.client.ClientActorBehavior.ConnectionConnectCohort
Finish the connection by replaying previous messages onto the new connection.
FixedThreadPoolWrapper - Class in org.opendaylight.controller.config.threadpool.util
Implementation of ThreadPool using fixed number of threads wraps ExecutorService.
FixedThreadPoolWrapper(int, ThreadFactory) - Constructor for class org.opendaylight.controller.config.threadpool.util.FixedThreadPoolWrapper
 
FlexibleThreadPoolWrapper - Class in org.opendaylight.controller.config.threadpool.util
Implementation of ThreadPool using flexible number of threads wraps ExecutorService.
FlexibleThreadPoolWrapper(int, int, long, TimeUnit, ThreadFactory) - Constructor for class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
FlexibleThreadPoolWrapper(int, int, long, TimeUnit, ThreadFactory, OptionalInt) - Constructor for class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
flipMemberVotingStatesForAllShards(FlipMemberVotingStatesForAllShardsInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
flipMemberVotingStatesForAllShards(FlipMemberVotingStatesForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Flips the voting states of all cluster members for all shards, such that if a member was voting it becomes non-voting and vice versa.
FlipMemberVotingStatesForAllShardsInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
FlipMemberVotingStatesForAllShardsInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
FlipMemberVotingStatesForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
 
FlipMemberVotingStatesForAllShardsInputBuilder(FlipMemberVotingStatesForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
 
FlipMemberVotingStatesForAllShardsOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
FlipMemberVotingStatesForAllShardsOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
FlipMemberVotingStatesForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
 
FlipMemberVotingStatesForAllShardsOutputBuilder(FlipMemberVotingStatesForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
 
FlipMemberVotingStatesForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
 
FlipShardMembersVotingStatus - Class in org.opendaylight.controller.cluster.datastore.messages
A local message sent to the ShardManager to flip the raft voting states for members of a shard.
FlipShardMembersVotingStatus(String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.FlipShardMembersVotingStatus
 
FLUORINE_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
 
FLUORINE_VERSION - Static variable in class org.opendaylight.controller.cluster.raft.RaftVersions
 
flush() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
 
Follower - Class in org.opendaylight.controller.cluster.raft.behaviors
The behavior of a RaftActor in the Follower raft state.
Follower - org.opendaylight.controller.cluster.raft.RaftState
 
Follower(RaftActorContext) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
Follower(RaftActorContext, String, short) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
FollowerInfo - Class in org.opendaylight.controller.cluster.raft.client.messages
A bean class containing a snapshot of information for a follower returned from GetOnDemandRaftStats.
FollowerInfo(String, long, long, boolean, String, boolean) - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.FollowerInfo
 
followerInfoList(List<FollowerInfo>) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
FollowerInitialSyncUpStatus - Class in org.opendaylight.controller.cluster.raft.base.messages
The FollowerInitialSyncUpStatus is sent by a Follower to inform any RaftActor subclass whether the Follower is at least at the same commitIndex as the Leader was when it sent the follower the very first heart beat.
FollowerInitialSyncUpStatus(boolean, String) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.FollowerInitialSyncUpStatus
 
FollowerLogInformation - Class in org.opendaylight.controller.cluster.raft
The state of the followers log as known by the Leader.
FollowerLogInformation(PeerInfo, RaftActorContext) - Constructor for class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Constructs an instance with no matching index.
followerLogSize() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
forDataSchemaContext(DataSchemaContextTree) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
Create a new pruner bound to a DataSchemaContextTree.
forName(String) - Static method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
Return a FrontendType corresponding to a string representation.
forName(String) - Static method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
forName(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
Return the enumeration member whose EventSourceStatus.getName() matches specified value.
forName(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
Return the enumeration member whose JoinTopicStatus.getName() matches specified value.
forName(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
Return the enumeration member whose SupportType.getName() matches specified value.
forName(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
Return the enumeration member whose DataStoreType.getName() matches specified value.
forSchemaContext(SchemaContext) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
Create a new pruner bound to a SchemaContext.
forShardList(List<String>) - Static method in class org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerSnapshot
Deprecated.
This method is for migration only and should me removed once org.opendaylight.controller.cluster.datastore.ShardManagerSnapshot is removed.
forValue(int) - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
Return the enumeration member whose EventSourceStatus.getIntValue() matches specified value.
forValue(int) - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
Return the enumeration member whose JoinTopicStatus.getIntValue() matches specified value.
forValue(int) - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
Return the enumeration member whose SupportType.getIntValue() matches specified value.
forValue(int) - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
Return the enumeration member whose DataStoreType.getIntValue() matches specified value.
ForwardedReadyTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
Transaction ReadyTransaction message that is forwarded to the local Shard from the ShardTransaction.
ForwardedReadyTransaction(TransactionIdentifier, short, ReadWriteShardDataTreeTransaction, boolean, Optional<SortedSet<String>>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
 
forwardEntry(ConnectionEntry, long) - Method in class org.opendaylight.controller.cluster.access.client.ReconnectForwarder
 
from(DOMRpcIdentifier, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.remote.rpc.messages.ExecuteRpc
 
from(SchemaPath, DOMDataTreeIdentifier, ContainerNode) - Static method in class org.opendaylight.controller.remote.rpc.messages.ExecuteAction
 
fromBinaryJava(byte[], Class<?>) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
 
fromBinaryJava(byte[], Class<?>) - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntrySerializer
 
fromInt(int) - Static method in enum org.opendaylight.controller.cluster.datastore.TransactionType
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
fromShardIdString(String) - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier.Builder
 
fromShardIdString(String) - Static method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
fromStream(NormalizedNodeDataInput, short) - Static method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
fromStream(NormalizedNodeDataInput, short, ReusableStreamReceiver) - Static method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
 
fromStream(NormalizedNodeDataInput, short, ReusableStreamReceiver) - Static method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
FrontendClientMetadata - Class in org.opendaylight.controller.cluster.datastore.persisted
 
FrontendClientMetadata(ClientIdentifier, RangeSet<UnsignedLong>, Collection<FrontendHistoryMetadata>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
 
FrontendHistoryMetadata - Class in org.opendaylight.controller.cluster.datastore.persisted
 
FrontendHistoryMetadata(long, long, boolean, Map<UnsignedLong, Boolean>, RangeSet<UnsignedLong>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
FrontendIdentifier - Class in org.opendaylight.controller.cluster.access.concepts
A cluster-wide unique identifier of a frontend type located at a cluster member.
FrontendIdentifier - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
Identifier of a particular frontend.
frontendNoProgressTimeoutInSeconds(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
frontendRequestTimeoutInSeconds(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
FrontendShardDataTreeSnapshotMetadata - Class in org.opendaylight.controller.cluster.datastore.persisted
 
FrontendShardDataTreeSnapshotMetadata(Collection<FrontendClientMetadata>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.FrontendShardDataTreeSnapshotMetadata
 
FrontendType - Class in org.opendaylight.controller.cluster.access.concepts
An Identifier identifying a data store frontend type, which is able to access the data store backend.
FrontendType - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
 
FrontendType(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
 
FrontendType(FrontendType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
Creates a copy from Source Object.
FutureVersionException - Exception in org.opendaylight.controller.cluster.access
Exception thrown from ABIVersion.valueOf(short) when the specified version is too new to be supported by the codebase.
FutureVersionException - Exception in org.opendaylight.controller.cluster.datastore.persisted
Exception thrown from PayloadVersion.valueOf(short) when the specified version is too new to be supported by the codebase.

G

get() - Method in class org.opendaylight.controller.cluster.common.actor.AbstractConfig
 
get() - Method in interface org.opendaylight.controller.cluster.common.actor.UnifiedConfig
Returns an immutable instance of unified configuration.
get(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
get(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Return the replicated log entry at the specified index.
GET_ALL_BUCKETS - org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
 
GET_BUCKET_VERSIONS - org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
 
getAbortTransactionsCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getAbortTransactionsCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getActionEndpoints() - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry.Messages.UpdateRemoteActionEndpoints
 
getActionRegistryName() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getActionRegistryPath() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getActionRegistryPersistenceId() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getActions() - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry.RemoteActionEndpoint
 
getActiveThreadCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getActiveThreadCount() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the active thread count.
getActiveThreadCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getActor() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
getActor() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.ShardInformation
 
getActor() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the reference to the RaftActor.
getActor() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getActorNameOverride() - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActorWithMetering
 
getActorRef() - Method in class org.opendaylight.controller.cluster.common.actor.Monitor
 
getActorSystem() - Method in interface org.opendaylight.controller.cluster.ActorSystemProvider
Returns the ActorSystem.
getActorSystem() - Method in class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
 
getActorSystem() - Method in class org.opendaylight.controller.cluster.akka.osgi.impl.OSGiActorSystemProvider
 
getActorSystem() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getActorSystem() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the The ActorSystem associated with this context.
getActorSystem() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getActorSystem() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
getActorSystemName() - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
getActorUtils() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
getActorUtils() - Method in interface org.opendaylight.controller.cluster.datastore.DistributedDataStoreInterface
 
getActorUtils() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
getActorUtils() - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
getActorUtils() - Method in class org.opendaylight.controller.cluster.datastore.TransactionReadyReplyMapper
 
getAddress() - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
 
getAllPrefixShardConfigurations() - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns the configuration for all configured prefix shards.
getAllPrefixShardConfigurations() - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getAllShardNames() - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns all the configured shard names.
getAllShardNames() - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getAlternates() - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
Return the list of known alternate backends.
getAndClearPendingTransactions() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTree
 
getAndRemove(String) - Method in interface org.opendaylight.controller.cluster.datastore.DatastoreSnapshotRestore
 
getAndRemove(String) - Method in class org.opendaylight.controller.cluster.datastore.DefaultDatastoreSnapshotRestore
 
getApplyStateConsumer() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the consumer of ApplyState operations.
getApplyStateConsumer() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getAskDuration() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getAskTimeoutExceptionCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBean
Return the number of AskTimeoutExceptions encountered by the datastore.
getAskTimeoutExceptionCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBeanImpl
 
getAskTimeoutExceptionCount() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getAssembledBytes() - Method in class org.opendaylight.controller.cluster.messaging.AssembledMessageState
Returns the assembled bytes as a ByteSource.
getAvailableNotifications() - Method in interface org.opendaylight.controller.messagebus.spi.EventSource
List the types of notifications which source can produce.
getAverageCommitTime() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBean
Returns a string representing average commit time duration, in the appropriate scaled units.
getAverageCommitTime() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBeanImpl
 
getBackend() - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
 
getBackendAlivenessTimerInterval() - Method in interface org.opendaylight.controller.cluster.access.client.ClientActorConfig
Returns the timer interval whereby, on expiration after response inactivity from the back-end, the connection to the back-end is torn down and reconnection is attempted.
getBackendAlivenessTimerInterval() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getBackendAlivenessTimerIntervalInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The timer interval whereby, on expiration after response inactivity from the back-end, the connection to the back-end is torn down and reconnection is attempted.
getBackendAlivenessTimerIntervalInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getBackendInfo() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
 
getBackendInfo() - Method in class org.opendaylight.controller.cluster.access.client.ConnectingClientConnection
 
getBackendInfo(Long) - Method in class org.opendaylight.controller.cluster.access.client.BackendInfoResolver
Request resolution of a particular backend identified by a cookie.
getBaseDatastoreContext() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextFactory
 
getBody() - Method in class org.opendaylight.controller.messagebus.app.util.TopicDOMNotification
 
getBoundedMailboxCapacity() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Max queue size that an actor's mailbox can reach
getBoundedMailboxCapacity() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getBucketVersions() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess
 
getBucketVersions() - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBean
 
getBucketVersions() - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBeanImpl
 
getBucketVersions() - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBean
 
getBucketVersions() - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBeanImpl
 
getCallback() - Method in class org.opendaylight.controller.cluster.access.client.ConnectionEntry
 
getCallback() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.RegisterForShardAvailabilityChanges
 
getCallback() - Method in class org.opendaylight.controller.cluster.raft.base.messages.ApplySnapshot
 
getCanCommit() - Method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
getCandidate() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
 
getCandidate() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
 
getCandidate(ReusableStreamReceiver) - Method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
 
getCandidateElectionTimeoutDivisor() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the number by which a candidate should divide the election timeout it has calculated.
getCandidateElectionTimeoutDivisor() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getCandidateId() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestVote
 
getCaptureSnapshot() - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
getCause() - Method in class org.opendaylight.controller.cluster.access.concepts.RequestFailure
Return the failure cause.
getChanges() - Method in class org.opendaylight.controller.cluster.datastore.messages.DataTreeChanged
Return the data changes.
getChunkIndex() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getChunkIndex() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshotReply
 
getCleanShardName(YangInstanceIdentifier) - Static method in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
Returns an encoded shard name based on the provided path that should doesn't contain characters that cannot be present in akka actor paths.
getClient() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
getClientActor() - Method in class org.opendaylight.controller.cluster.raft.base.messages.ApplyState
 
getClientActor() - Method in class org.opendaylight.controller.cluster.raft.base.messages.Replicate
 
getClientActor() - Method in interface org.opendaylight.controller.cluster.raft.ClientRequestTracker
Returns the client actor that should be sent a response when consensus is achieved.
getClientActor() - Method in class org.opendaylight.controller.cluster.raft.ClientRequestTrackerImpl
 
getClientActorConfig() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActor
 
getClientActorConfig() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractDataStoreClientActor
 
getClientDispatcher() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
An akka dispatcher that is meant to be used when processing ask Futures which were triggered by client code on the datastore.
getClientId() - Method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
getClients() - Method in class org.opendaylight.controller.cluster.datastore.messages.GetKnownClientsReply
 
getClients() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendShardDataTreeSnapshotMetadata
 
getClientType() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
getClosedTransactions() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
getClosestVersion() - Method in exception org.opendaylight.controller.cluster.access.AbstractVersionException
Return the closest version supported by this codebase.
getClosestVersion() - Method in exception org.opendaylight.controller.cluster.datastore.persisted.AbstractVersionException
Return the closest version supported by this codebase.
getCluster() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
The akka Cluster singleton for the actor system if one is configured.
getCluster() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getClusterWrapper() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getClusterWrapper() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
getCohortCacheSize() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
getCohortPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
getCommitCohortActors() - Method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState
 
getCommitIndex() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getCommitIndex() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getCommitIndex() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getCommitIndex() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the index of highest log entry known to be committed.
getCommitIndex() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getCommitStatsTracker() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
 
getCommittedTransactionsCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getCommittedTransactionsCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getCompletedTaskCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getCompletedTaskCount() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the completed task count.
getCompletedTaskCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getConfig() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
getConfigParams() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the ConfigParams instance.
getConfigParams() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getConfiguration() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getConfiguration() - Method in class org.opendaylight.controller.cluster.sharding.messages.PrefixShardCreated
 
getConfigurationReader() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getConnection(Long) - Method in class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
Get a connection to a shard.
getContext() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextIntrospector
 
getCookie() - Method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
getCookie() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
getCount() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
 
getCurrentBehavior() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
getCurrentBehavior() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the current behavior attached to the RaftActor.
getCurrentBehavior() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getCurrentExpectedMessage() - Method in interface org.opendaylight.controller.cluster.common.actor.MessageTracker.Error
 
getCurrentHistories() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
 
getCurrentMemberName() - Method in interface org.opendaylight.controller.cluster.datastore.ClusterWrapper
 
getCurrentMemberName() - Method in class org.opendaylight.controller.cluster.datastore.ClusterWrapperImpl
 
getCurrentMemberName() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getCurrentQueueSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getCurrentQueueSize() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the current queue size.
getCurrentQueueSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getCurrentSliceIndex() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Returns the current slice index that has been sent.
getCurrentTerm() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getCurrentTerm() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getCurrentTerm() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getCurrentTerm() - Method in interface org.opendaylight.controller.cluster.raft.ElectionTerm
Returns the current leader's Raft term.
getCurrentTerm() - Method in class org.opendaylight.controller.cluster.raft.ImmutableElectionTerm
 
getCurrentTerm() - Method in class org.opendaylight.controller.cluster.raft.persisted.UpdateElectionTerm
 
getCurrentTerm() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
getCurrentThreadPoolSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getCurrentThreadPoolSize() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the current thread pool size.
getCurrentThreadPoolSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getCustomRaftPolicyClassName() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getCustomRaftPolicyImplementation() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
A fully qualified java class name.
getCustomRaftPolicyImplementation() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getCustomRaftPolicyImplementationClass() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the custom RaftPolicy class name.
getCustomRaftPolicyImplementationClass() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getData() - Method in class org.opendaylight.controller.cluster.access.commands.ReadTransactionSuccess
 
getData() - Method in class org.opendaylight.controller.cluster.access.commands.TransactionDataModification
 
getData() - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
getData() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlice
 
getData() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getData() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
getData() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
Returns the payload/data to be replicated.
getData() - Method in interface org.opendaylight.controller.remote.rpc.registry.gossip.Bucket
 
getDataStore() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
getDatastoreContext() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateShard
 
getDatastoreContext() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
getDatastoreContext() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
getDatastoreContext() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getDataStoreMXBeanType() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getDataStoreName() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getDataStoreName() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Get the name of the data store to which this ActorContext belongs.
getDataStorePropertiesContainer() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DistributedDatastoreProviderData
 
getDataStoreType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInput
The type of the data store to which the replica belongs
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
getDataStoreType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
The type of the data store to which the shard belongs
getDataStoreType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInput
The type of the data store to which the replica belongs
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
getDataStoreType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInput
The type of the data store to which the replica belongs
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultKey
 
getDataTree() - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
 
getDataTree() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
getDataTree() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTree
 
getDataTreeChangeListenerInfo() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardDataTreeListenerInfoMXBean
 
getDataTreeChangeListenerInfo() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardDataTreeListenerInfoMXBeanImpl
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.NotificationPattern
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.Pattern
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicId
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorId
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.MemberName
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
 
getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
 
getDelayedFailure() - Method in class org.opendaylight.controller.cluster.access.commands.CommitLocalTransactionRequest
Return the delayed error detected on the frontend.
getDelegate() - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
getDispatcher(Dispatchers.DispatcherType) - Method in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
getDispatcherPath(Dispatchers.DispatcherType) - Method in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
getDistributedConfigDatastore() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
getDistributedDataStoreClient(ActorRef, long, TimeUnit) - Static method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractDataStoreClientActor
 
getDistributedOperDatastore() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
getDOMStoreTransaction() - Method in class org.opendaylight.controller.cluster.datastore.ShardReadTransaction
 
getDOMStoreTransaction() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
getDOMStoreTransaction() - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
 
getElapsedTimeInNanos() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker.MessageProcessingTime
 
getElectionTerm() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getElectionTimeoutFactor() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the multiplication factor to be used to determine the shard election timeout.
getElectionTimeoutFactor() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getElectionTimeOutInterval() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the interval after which a new election should be triggered if no leader is available.
getElectionTimeOutInterval() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getElectionTimeVariance() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the maximum election time variance.
getElectionTimeVariance() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getElectionVotedFor() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getEnqueuedTicks() - Method in class org.opendaylight.controller.cluster.access.client.ConnectionEntry
 
getEntries() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getErrorMessage() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
getErrorMessage() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
 
getErrors() - Method in class org.opendaylight.controller.remote.rpc.messages.ActionResponse
 
getEventSourceNode() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.Node1
 
getEventSourceNode() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.Node1Builder
 
getExecutionTimeNanos() - Method in class org.opendaylight.controller.cluster.access.concepts.ResponseEnvelope
Return the time the request took to execute in nanoseconds.
getExecutor() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Return an Executor which is guaranteed to run tasks in the context of RaftActorContext.getActor().
getExecutor() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getExecutor() - Method in interface org.opendaylight.controller.config.threadpool.ScheduledThreadPool
 
getExecutor() - Method in interface org.opendaylight.controller.config.threadpool.ThreadPool
 
getExecutor() - Method in class org.opendaylight.controller.config.threadpool.util.FixedThreadPoolWrapper
 
getExecutor() - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
getExecutor() - Method in class org.opendaylight.controller.config.threadpool.util.ScheduledThreadPoolWrapper
 
getExists() - Method in class org.opendaylight.controller.cluster.access.commands.ExistsTransactionSuccess
 
getExtensions() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBroker
 
getExtensions() - Method in class org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker
 
getExtensions() - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardedDOMDataTree
 
getExtensions() - Method in class org.opendaylight.controller.cluster.sharding.OSGiDistributedShardedDOMDataTree
 
getFailedReadTransactionsCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getFailedReadTransactionsCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getFailedTransactionsCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getFailedTransactionsCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getFailure() - Method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
 
getFileBackedOutputStreamFactory() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the FileBackedOutputStreamFactory instance with a common configuration.
getFileBackedOutputStreamFactory() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getFileBackedStream() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions
 
getFileBackedStreamingThreshold() - Method in interface org.opendaylight.controller.cluster.access.client.ClientActorConfig
Returns the threshold in bytes before switching from storing in memory to buffering to a file when streaming large amounts of data.
getFileBackedStreamingThreshold() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getFileBackedStreamingThreshold() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the threshold in terms of number of bytes when streaming data before it should switch from storing in memory to buffering to a file.
getFileBackedStreamingThreshold() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getFileBackedStreamingThresholdInMegabytes() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
When streaming large amounts of data, eg when sending a snapshot to a follower, this is the threshold in terms of number of megabytes before it should switch from storing in memory to buffering to a file.
getFileBackedStreamingThresholdInMegabytes() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getFilePath() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
The path and name of the file in which to store the backup.
getFilePath() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
getFollower(String) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
getFollowerId() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
getFollowerId() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshotReply
 
getFollowerId() - Method in class org.opendaylight.controller.cluster.raft.messages.UnInitializedFollowerSnapshotReply
 
getFollowerIds() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
Return an immutable collection of follower identifiers.
getFollowerInfo() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getFollowerInfo() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getFollowerInfoList() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getFollowerInitialSyncStatus() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getFollowerInitialSyncStatus() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getFrom(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
getFrom(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Returns a list of log entries starting from the given index to the end of the log.
getFrom(long, int, long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
getFrom(long, int, long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Returns a list of log entries starting from the given index up to the given maximum of entries or the given maximum accumulated size, whichever comes first.
getFromIndex() - Method in class org.opendaylight.controller.cluster.raft.persisted.DeleteEntries
 
getFrontendId() - Method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
getFrontendNoProgressTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The timeout interval whereby the client front-end hasn't made progress with the back-end on any request and terminates.
getFrontendNoProgressTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getFrontendRequestTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The timeout interval whereby client frontend transaction requests are failed.
getFrontendRequestTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getGeneration() - Method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
getGeneration() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientIdentifier
 
getGeneration() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
getGlobalDatastoreNames() - Static method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getGlobalRpc() - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBean
 
getGlobalRpc() - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBeanImpl
 
getGossipTickInterval() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getHeartBeatInterval() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the interval at which a heart beat message should be sent to remote followers.
getHeartBeatInterval() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getHistoryId() - Method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
getHistoryId() - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
getHistoryId() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
getId() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
getId() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
getId() - Method in class org.opendaylight.controller.cluster.raft.client.messages.FollowerInfo
 
getId() - Method in class org.opendaylight.controller.cluster.raft.client.messages.GetSnapshotReply
 
getId() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Returns the identifier of the follower.
getId() - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
 
getId() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
 
getId() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
getId() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the identifier for the RaftActor.
getId() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getId() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Node
The unique identifier for the node.
getId() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
getId() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorKey
 
getId() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnector
The unique identifier for the node-connector.
getId() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
getId() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
getId() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey
 
getId() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractClientHandle
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractClientHistory
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.messaging.AssembledMessageState
Returns the identifier of this instance.
getIdentifier() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlice
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Returns the identifier of this instance.
getIdentifier() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.raft.base.messages.ApplyState
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.raft.base.messages.Replicate
 
getIdentifier() - Method in interface org.opendaylight.controller.cluster.raft.ClientRequestTracker
Returns the identifier of the object that is to be replicated.
getIdentifier() - Method in class org.opendaylight.controller.cluster.raft.ClientRequestTrackerImpl
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardModification
 
getIdentifier() - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardModificationContext
 
getIdentifier() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifier
 
getIdentifier() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
getIdentifier() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierKey
 
getIfPresent(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.PrimaryShardInfoFutureCache
 
getIncrement() - Method in class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceRequest
Return the sequence increment beyond this request's sequence.
getIndex() - Method in interface org.opendaylight.controller.cluster.raft.ClientRequestTracker
Returns the index of the log entry that is to be replicated.
getIndex() - Method in class org.opendaylight.controller.cluster.raft.ClientRequestTrackerImpl
 
getIndex() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
getIndex() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
Returns the index of the entry.
GetInfo - Class in org.opendaylight.controller.cluster.datastore.messages
Local message sent to an actor to retrieve internal information for reporting.
getInitialPayloadSerializedBufferCapacity() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getInitialPayloadSerializedBufferCapacity() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The initial buffer capacity, in bytes, to use when serializing message payloads.
getInitialPayloadSerializedBufferCapacity() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getInitialSettleTimeoutMultiplier() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
Return the multiplier of DatastoreContext.getShardLeaderElectionTimeout() which the frontend will wait for all shards on the local node to settle.
getInitialSettleTimeoutMultiplier() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Multiplier for the maximum amount of time to wait for a shard to elect a leader.
getInitialSettleTimeoutMultiplier() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getInMemoryJournalDataSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getInMemoryJournalDataSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getInMemoryJournalDataSize() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getInMemoryJournalLogSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getInMemoryJournalLogSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getInMemoryJournalLogSize() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getInput() - Method in class org.opendaylight.controller.remote.rpc.messages.AbstractExecute
 
getInstallSnapshotState() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Returns the LeaderInstallSnapshotState for the in progress install snapshot.
getInstallSnapshotStream() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshotReply
 
getInstance() - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseDataTreeNotificationListenerRegistration
 
getInstance() - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseDataTreeNotificationListenerRegistrationReply
 
getInstance() - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataTreeChangedReply
 
getInstance() - Static method in class org.opendaylight.controller.cluster.datastore.shardstrategy.DefaultShardStrategy
 
getInstance(String) - Static method in class org.opendaylight.controller.cluster.reporting.MetricsReporter
 
getIntValue() - Method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
 
getIntValue() - Method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
 
getIntValue() - Method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
 
getIntValue() - Method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
 
getInventoryNodeConnectorRef() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeConnector
 
getInventoryNodeConnectorRef() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeConnectorBuilder
 
getInventoryNodeRef() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNode
 
getInventoryNodeRef() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeBuilder
 
getIsolatedCheckIntervalInMillis() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the interval in which the leader needs to check if its isolated.
getIsolatedCheckIntervalInMillis() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getItems() - Method in class org.opendaylight.controller.remote.rpc.registry.AbstractRoutingTable
 
getJournalRecoveryLogBatchSize() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the maximum number of journal log entries to batch on recovery before applying.
getJournalRecoveryLogBatchSize() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getKeepAliveMillis() - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
getKnownClients() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1
 
getKnownClients() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1Builder
 
GetKnownClients - Class in org.opendaylight.controller.cluster.datastore.messages
Request a shard to report the clients it knows about.
getKnownClientsForAllShards(GetKnownClientsForAllShardsInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
getKnownClientsForAllShards(GetKnownClientsForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Request all shards to report their known frontend clients.
GetKnownClientsForAllShardsInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
GetKnownClientsForAllShardsInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds GetKnownClientsForAllShardsInputBuilder instances.
GetKnownClientsForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
 
GetKnownClientsForAllShardsInputBuilder(GetKnownClientsForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
 
GetKnownClientsForAllShardsOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
GetKnownClientsForAllShardsOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds GetKnownClientsForAllShardsOutputBuilder instances.
GetKnownClientsForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
 
GetKnownClientsForAllShardsOutputBuilder(GetKnownClientsForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
 
GetKnownClientsForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
 
GetKnownClientsReply - Class in org.opendaylight.controller.cluster.datastore.messages
Reply to GetKnownClients.
GetKnownClientsReply(ImmutableSet<ClientIdentifier>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.GetKnownClientsReply
 
getLargestQueueSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getLargestQueueSize() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the largest queue size, if available.
getLargestQueueSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getLargestThreadPoolSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getLargestThreadPoolSize() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the largest thread pool size.
getLargestThreadPoolSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getLastApplied() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLastApplied() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLastApplied() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getLastApplied() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns index of highest log entry applied to state machine.
getLastApplied() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getLastAppliedIndex() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
getLastAppliedIndex() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getLastAppliedTerm() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
getLastAppliedTerm() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getLastChunkHashCode() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getLastCommittedTransactionTime() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLastCommittedTransactionTime() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLastExpectedMessage() - Method in interface org.opendaylight.controller.cluster.common.actor.MessageTracker.Error
 
getLastIncludedIndex() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getLastIncludedTerm() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getLastIndex() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLastIndex() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLastIndex() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
getLastIndex() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getLastIndex() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getLastLeadershipChangeTime() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLastLeadershipChangeTime() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLastLogIndex() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLastLogIndex() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLastLogIndex() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getLastLogIndex() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestVote
 
getLastLogTerm() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLastLogTerm() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLastLogTerm() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getLastLogTerm() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestVote
 
getLastSequenceNumber() - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
Returns the last sequence number contained in the journal.
getLastSequenceNumber() - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
getLastSequenceNumber() - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
getLastSequenceNumber() - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
 
getLastSequenceNumber() - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
getLastSliceHashCode() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlice
 
getLastSliceHashCode() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Returns the hash code of the last slice that was sent.
getLastTerm() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLastTerm() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLastTerm() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
getLastTerm() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getLastTerm() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getLeader() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLeader() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getLeader() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getLeader() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Derived actor can call getLeader if they need a reference to the Leader.
getLeaderActor() - Method in class org.opendaylight.controller.cluster.raft.client.messages.FindLeaderReply
 
getLeaderActorRef() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRef
Actor reference to the actor which is currently acting as the leader.
getLeaderActorRef() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
 
getLeaderAddress() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getLeaderCommit() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getLeaderHint() - Method in class org.opendaylight.controller.cluster.raft.messages.AbstractServerChangeReply
 
getLeaderId() - Method in class org.opendaylight.controller.cluster.notifications.LeaderStateChanged
 
getLeaderId() - Method in class org.opendaylight.controller.cluster.raft.base.messages.LeaderTransitioning
 
getLeaderId() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
getLeaderId() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
getLeaderId() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
getLeaderId() - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
Returns the id of the leader.
getLeaderId() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getLeaderId() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getLeaderId() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Returns the id of the current leader.
getLeaderLocation() - Method in interface org.opendaylight.controller.cluster.dom.api.CDSShardAccess
Return the shard leader location relative to the local node.
getLeaderPayloadVersion() - Method in class org.opendaylight.controller.cluster.notifications.LeaderStateChanged
 
getLeaderPayloadVersion() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
getLeaderPayloadVersion() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
getLeaderPayloadVersion() - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
getLeaderPayloadVersion() - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
Returns the leader's payload data version.
getLeaderRaftVersion() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getLeadershipChangeCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getLeadershipChangeCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getListener() - Method in class org.opendaylight.controller.cluster.datastore.messages.DataTreeListenerInfo
 
getListenerActorPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
getListenerRegistrationPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeNotificationListenerReply
 
getLocal() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.Local
Local node is the best node to talk to when it comes from efficiency perspective of underlying implementation.
getLocal() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
 
getLocalData() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess
 
getLocalData() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
getLocalRegisteredAction() - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBean
 
getLocalRegisteredAction() - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBeanImpl
 
getLocalRegisteredRoutedRpc() - Method in interface org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBean
 
getLocalRegisteredRoutedRpc() - Method in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBeanImpl
 
getLocalShardDataTree() - Method in class org.opendaylight.controller.cluster.datastore.messages.LocalPrimaryShardFound
 
getLocalShardDataTree() - Method in class org.opendaylight.controller.cluster.datastore.messages.PrimaryShardInfo
Returns an Optional whose value contains the primary shard's DataTree if the primary shard is local to the caller.
getLocalShardDataTree() - Method in class org.opendaylight.controller.cluster.datastore.messages.ShardLeaderStateChanged
 
getLocalShards() - Method in interface org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerInfoMBean
Returns the list of all the local shard names.
getLogContext() - Method in class org.opendaylight.controller.cluster.datastore.messages.EnableNotification
 
getLogEntryIndex(long) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the actual index of the entry in replicated log for the given index or -1 if not found.
getLogEntryOrSnapshotTerm(long) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the actual term of the entry in the replicated log for the given index or, if not present, returns the snapshot term if the given index is in the snapshot or -1 otherwise.
getLogEntryTerm(long) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the actual term of the entry in the replicated log for the given index or -1 if not found.
getLogger() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the logger to be used for logging messages.
getLogger() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getLogicalStoreType() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getLogLastIndex() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
getLogLastTerm() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
getLongestCommitTime() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBean
Returns a string representing the time duration of the longest commit, in the appropriate scaled units, along with the date/time that it occurred.
getLongestCommitTime() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBeanImpl
 
getLookupTaskMaxRetries() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
getMailBoxCapacity() - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
getMailBoxName() - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
getMailBoxPushTimeout() - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
getMajorityVoteCount(int) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
getMatchIndex() - Method in class org.opendaylight.controller.cluster.raft.client.messages.FollowerInfo
 
getMatchIndex() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Returns the index of highest log entry known to be replicated on the follower.
getMaximumMessageSliceSize() - Method in interface org.opendaylight.controller.cluster.access.client.ClientActorConfig
Returns the maximum size in bytes for a message slice when fragmenting messages thru the akka remoting framework.
getMaximumMessageSliceSize() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getMaximumMessageSliceSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getMaximumMessageSliceSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getMaximumMessageSliceSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
When fragmenting messages thru the akka remoting framework, this is the maximum size in bytes for a message slice.
getMaximumMessageSliceSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getMaxMessages() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
getMaxMessages() - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
 
getMaxQueueSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getMaxQueueSize() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the maximum queue size.
getMaxQueueSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getMaxShardDataChangeExecutorPoolSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataChangeExecutorPoolSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataChangeExecutorPoolSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum thread pool size for each shard's data store data change notification executor.
getMaxShardDataChangeExecutorPoolSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getMaxShardDataChangeExecutorQueueSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataChangeExecutorQueueSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataChangeExecutorQueueSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum queue size for each shard's data store data change notification executor.
getMaxShardDataChangeExecutorQueueSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getMaxShardDataChangeListenerQueueSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataChangeListenerQueueSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataChangeListenerQueueSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum queue size for each shard's data store data change listener.
getMaxShardDataChangeListenerQueueSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getMaxShardDataStoreExecutorQueueSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataStoreExecutorQueueSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getMaxShardDataStoreExecutorQueueSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum queue size for each shard's data store executor.
getMaxShardDataStoreExecutorQueueSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getMaxThreadCount() - Method in interface org.opendaylight.controller.config.threadpool.ThreadPool
 
getMaxThreadCount() - Method in class org.opendaylight.controller.config.threadpool.util.FixedThreadPoolWrapper
 
getMaxThreadCount() - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
getMaxThreadCount() - Method in class org.opendaylight.controller.config.threadpool.util.ScheduledThreadPoolWrapper
 
getMaxThreadPoolSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getMaxThreadPoolSize() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the maximum thread pool size.
getMaxThreadPoolSize() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getMaxVersion() - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientRequest
 
getMBeanCategory() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
Returns the Category property of the bean's ObjectName.
getMBeanName() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
Returns the name property of the bean's ObjectName.
getMBeanType() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
Returns the type property of the bean's ObjectName.
getMeberVotingStatusMap() - Method in class org.opendaylight.controller.cluster.datastore.messages.ChangeShardMembersVotingStatus
 
getMember() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendIdentifier
 
getMember() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
getMember() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsKey
 
getMemberId() - Method in class org.opendaylight.controller.cluster.notifications.LeaderStateChanged
 
getMemberId() - Method in class org.opendaylight.controller.cluster.notifications.RoleChanged
 
getMemberId() - Method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotification
 
getMemberName() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
getMemberName() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
getMemberName() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerDown
 
getMemberName() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerUp
 
getMemberName() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemovePrefixShardReplica
 
getMemberName() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemoveShardReplica
 
getMemberName() - Method in interface org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerInfoMBean
Returns the name of the local member.
getMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingState
 
getMemberName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
getMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
The cluster member from which the shard replicas should be removed
getMemberName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
 
getMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInput
The cluster member from which the shard replica should be removed
getMemberName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
getMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
The cluster member from which the shard replica should be removed
getMemberName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
getMemberNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
Location of the hypothetical cluster member node.
getMemberNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
 
getMembersFromShardName(String) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns the member replicas for the given shard name.
getMembersFromShardName(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getMemberShardNames(MemberName) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns all the shard names that belong on the member by the given name.
getMemberShardNames(MemberName) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getMemberVotingState() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
 
getMemberVotingState() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
getMemberVotingState() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MemberVotingStatesInput
The list of member voting states
getMessage() - Method in class org.opendaylight.controller.cluster.access.concepts.Envelope
Get the enclosed message.
getMessage() - Method in exception org.opendaylight.controller.cluster.datastore.exceptions.UnknownMessageException
 
getMessage() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions
 
getMessageClass() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker.MessageProcessingTime
 
getMessageProcessingTimesSinceLastExpectedMessage() - Method in interface org.opendaylight.controller.cluster.common.actor.MessageTracker.Error
 
getMessagesSinceLastExpectedMessage() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker
 
getMetadata() - Method in class org.opendaylight.controller.cluster.datastore.persisted.MetadataShardDataTreeSnapshot
 
getMetricsRegistry() - Method in class org.opendaylight.controller.cluster.reporting.MetricsReporter
 
getMinIsolatedLeaderPeerCount() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
getMinThreadCount() - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
getMinVersion() - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientRequest
 
getModification() - Method in class org.opendaylight.controller.cluster.access.commands.CommitLocalTransactionRequest
 
getModification() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
 
getModifications() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequest
 
getModifications() - Method in interface org.opendaylight.controller.cluster.datastore.modification.CompositeModification
Get a list of modifications contained by this composite.
getModifications() - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
getModifications() - Method in class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
 
getModuleName() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
 
getModuleNameFromNameSpace(String) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns the module name for the given namespace name or null if not found.
getModuleNameFromNameSpace(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getModuleShardConfig() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateShard
 
getName() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
getName() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
getName() - Method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
getName() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
getName() - Method in class org.opendaylight.controller.cluster.datastore.config.ShardConfig
 
getName() - Method in class org.opendaylight.controller.cluster.datastore.messages.GetShardRole
 
getName() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot.ShardSnapshot
 
getName() - Method in class org.opendaylight.controller.cluster.raft.base.messages.FollowerInitialSyncUpStatus
 
getName() - Method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
 
getName() - Method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
 
getName() - Method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
 
getName() - Method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
 
getNamePrefix() - Method in class org.opendaylight.controller.config.threadpool.util.NamingThreadPoolFactory
 
getNamespace() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
getNamespace() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
 
getNewRole() - Method in class org.opendaylight.controller.cluster.notifications.RoleChanged
 
getNewRole() - Method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotification
 
getNewServerAddress() - Method in class org.opendaylight.controller.cluster.raft.messages.AddServer
 
getNewServerId() - Method in class org.opendaylight.controller.cluster.raft.messages.AddServer
 
getNewState() - Method in class org.opendaylight.controller.cluster.raft.base.messages.SwitchBehavior
 
getNewTerm() - Method in class org.opendaylight.controller.cluster.raft.base.messages.SwitchBehavior
 
getNextIndex() - Method in class org.opendaylight.controller.cluster.raft.client.messages.FollowerInfo
 
getNextIndex() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Returns the index of the next log entry to send to the follower.
getNextSlice() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Reads and returns the next slice of data.
getNode() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInput
 
getNode() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
getNode() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInput
 
getNode() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
getNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeContextRef
A reference to a particular node.
getNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Nodes
A list of nodes (as defined by the 'grouping node').
getNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
 
getNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNode
 
getNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
getNodeConnector() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Node
A list of node connectors that belong this node.
getNodeConnector() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
getNodeConnector() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
getNodeConnectorRef() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemoved
Deprecated.
A reference to the node-connector that was removed.
getNodeConnectorRef() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
 
getNodeConnectorRef() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdated
Deprecated.
A reference to the node-connector which changed.
getNodeConnectorRef() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
getNodeId() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotification
Node ID of the node which generated the event.
getNodeId() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
getNodeIdentifier() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
 
getNodeIdentifier() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.NodeIdentifiers
 
getNodeIdPattern() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInput
Pattern for matching candidate event source nodes when looking for contributors to the topic.
getNodeIdPattern() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
getNodeIdRegexPattern() - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopic
 
getNodeRef() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemoved
Deprecated.
A reference to the node that was removed.
getNodeRef() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
 
getNodeRef() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdated
Deprecated.
A reference to the node which changed.
getNodeRef() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
getNodes() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.OpendaylightInventoryData
The root container of all nodes.
getNoProgressTimeout() - Method in interface org.opendaylight.controller.cluster.access.client.ClientActorConfig
Returns the timeout interval whereby the client front-end hasn't made progress with the back-end on any request and terminates.
getNoProgressTimeout() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getNormalizedNode() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
 
getNotificationCount() - Method in class org.opendaylight.controller.cluster.datastore.messages.DataTreeListenerInfo
 
getNotificationDispatcherPath() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getNotificationPattern() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInput
Pattern matching notification which should be forwarded into this topic.
getNotificationPattern() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
getNotificationPattern() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInput
 
getNotificationPattern() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
getNumBatched() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
 
getOldRole() - Method in class org.opendaylight.controller.cluster.notifications.RoleChanged
 
getOldRole() - Method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotification
 
GetOnDemandRaftState - Class in org.opendaylight.controller.cluster.raft.client.messages
Local message sent to a RaftActor to obtain a snapshot of statistical information.
getOnFailureCallback() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Returns the callback to notify on failure.
getOnFailureCallback() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions
 
getOperationDuration() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getOperationTimeout() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getOperationTimeoutInMillis() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getOperationTimeoutInSeconds() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getOperationTimeoutInSeconds() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getOperationTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum amount of time for akka operations (remote or local) to complete before failing.
getOperationTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getOperationTimer(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
This is a utility method that lets us get a Timer object for any operation.
getOperationTimer(String, String) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getOriginalNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNodeBuilder
 
getOriginalNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregateNode
 
getOriginalTopology() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopologyBuilder
 
getOriginalTopology() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregateTopology
 
getOutput() - Method in class org.opendaylight.controller.remote.rpc.messages.AbstractResponse
 
getParticipatingShardNames() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
getParticipatingShardNames() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
 
getParticipatingShardNames() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
 
getPath() - Method in class org.opendaylight.controller.cluster.access.commands.AbstractReadPathTransactionRequest
 
getPath() - Method in class org.opendaylight.controller.cluster.access.commands.TransactionModification
 
getPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
getPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.LocalShardFound
 
getPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
getPath() - Method in class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
 
getPath() - Method in class org.opendaylight.controller.remote.rpc.messages.ExecuteAction
 
getPayload() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotification
Encapsulated notification.
getPayload() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
getPayloadVersion() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Returns the log entry payload data version of the follower.
getPayloadVersion() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getPayloadVersion() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
getPayloadVersion() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the payload version to be used when replicating data.
getPayloadVersion() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPeerActorSelection(String) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns an ActorSelection for a peer.
getPeerActorSelection(String) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPeerAddress() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerAddressResolved
 
getPeerAddress(String) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Gets the address of a peer as a String.
getPeerAddress(String) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPeerAddresses() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getPeerAddresses() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getPeerAddresses() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
getPeerAddresses() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getPeerAddressResolver() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the PeerAddressResolver.
getPeerAddressResolver() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getPeerId() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerAddressResolved
 
getPeerId() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerDown
 
getPeerId() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerUp
 
getPeerIds() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the id's for each peer.
getPeerIds() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPeerInfo(String) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the PeerInfo for the given peer.
getPeerInfo(String) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPeers() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the PeerInfo instances for each peer.
getPeers() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPeerServerInfo(boolean) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the peer information as a ServerConfigurationPayload if dynamic server configurations have been applied.
getPeerServerInfo(boolean) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPeerVotingStates() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getPeerVotingStates() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getPeerVotingStates() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getPendingTxCommitQueueSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getPendingTxCommitQueueSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getPendingTxCommitQueueSize() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
getPersistenceProtocol() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequest
 
getPersistenceProvider() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the DataPersistenceProvider instance.
getPersistenceProvider() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getPrefix() - Method in class org.opendaylight.controller.cluster.datastore.config.PrefixShardConfiguration
 
getPrefix() - Method in class org.opendaylight.controller.cluster.sharding.messages.LookupPrefixShard
 
getPrefix() - Method in class org.opendaylight.controller.cluster.sharding.messages.PrefixShardRemovalLookup
 
getPrefix() - Method in class org.opendaylight.controller.cluster.sharding.messages.PrefixShardRemoved
 
getPrefix() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.Shard
Prefix that this shard is rooted at.
getPrefix() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
getPrefix() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardKey
 
getPrefixForPath(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.shardstrategy.DefaultShardStrategy
 
getPrefixForPath(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.shardstrategy.ModuleShardStrategy
 
getPrefixForPath(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.shardstrategy.PrefixShardStrategy
 
getPrefixForPath(YangInstanceIdentifier) - Method in interface org.opendaylight.controller.cluster.datastore.shardstrategy.ShardStrategy
Get the prefix of the shard that contains the data pointed to by the specified path.
getPrefixShardRole(GetPrefixShardRoleInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
getPrefixShardRole(GetPrefixShardRoleInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Returns the current role for the requested module shard.
GetPrefixShardRoleInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
GetPrefixShardRoleInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds GetPrefixShardRoleInputBuilder instances.
GetPrefixShardRoleInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
GetPrefixShardRoleInputBuilder(GetPrefixShardRoleInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
GetPrefixShardRoleOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
GetPrefixShardRoleOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds GetPrefixShardRoleOutputBuilder instances.
GetPrefixShardRoleOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
 
GetPrefixShardRoleOutputBuilder(GetPrefixShardRoleOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
 
getPrefixShards() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardConfigurationData
 
getPrevLogIndex() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getPrevLogTerm() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getPrimaryPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.LocalPrimaryShardFound
 
getPrimaryPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemotePrimaryShardFound
 
getPrimaryShardActor() - Method in class org.opendaylight.controller.cluster.datastore.messages.PrimaryShardInfo
Returns an ActorSelection representing the primary shard actor.
getPrimaryShardInfoCache() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getPrimaryShardVersion() - Method in class org.opendaylight.controller.cluster.datastore.messages.PrimaryShardInfo
Returns the version of the primary shard.
getPrimaryVersion() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemotePrimaryShardFound
 
getProps(String) - Static method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotifier
 
getProvidedSources() - Method in class org.opendaylight.controller.cluster.schema.provider.impl.RemoteYangTextSourceProviderImpl
 
getProvidedSources() - Method in interface org.opendaylight.controller.cluster.schema.provider.RemoteYangTextSourceProvider
 
getPurgedHistories() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
 
getPurgedIdentifier() - Method in exception org.opendaylight.controller.cluster.access.commands.DeadTransactionException
 
getPurgedTransactions() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
getRaftActorContext() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
getRaftActorLeadershipTransferCohort() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the RaftActorLeadershipTransferCohort if leadership transfer is in progress.
getRaftActorLeadershipTransferCohort() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getRaftActorRecoveryCohort() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
getRaftActorRecoveryCohort() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Returns the RaftActorRecoveryCohort to participate in persistence recovery.
getRaftActorSnapshotCohort() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
getRaftActorSnapshotCohort() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Returns the RaftActorSnapshotCohort to participate in snapshot captures.
getRaftPolicy() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the RaftPolicy used to determine certain Raft behaviors.
getRaftPolicy() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getRaftPolicy() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the RaftPolicy used to determine certain Raft behaviors.
getRaftPolicy() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getRaftState() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getRaftState() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getRaftState() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getRaftState() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
getRaftVersion() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Returns the the raft version of the follower.
getRaftVersion() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
getReadOnlyTransactionCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getReadOnlyTransactionCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getReadWriteTransactionCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getReadWriteTransactionCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getRecoverySnapshotIntervalSeconds() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the interval(in seconds) after which a snapshot should be taken during recovery.
getRecoverySnapshotIntervalSeconds() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getRecoverySnapshotIntervalSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Interval after which a snapshot should be taken during the recovery process.
getRecoverySnapshotIntervalSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getRegisteredPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.DataTreeListenerInfo
 
getRejectedTaskCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getRejectedTaskCount() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the rejected task count, if available.
getRejectedTaskCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getRemoteBuckets() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess
 
getRemoteBuckets() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
getRemoteVersion() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
 
getReplica() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.Replicas
 
getReplica() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
 
getReplicas() - Method in class org.opendaylight.controller.cluster.datastore.config.ShardConfig
 
getReplicas() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.Shard
List of cluster member nodes that this shard is replicated on
getReplicas() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
getReplicatedLog() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the ReplicatedLog instance.
getReplicatedLog() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getReplicatedLogEntry() - Method in class org.opendaylight.controller.cluster.raft.base.messages.ApplyState
 
getReplicatedLogEntry() - Method in class org.opendaylight.controller.cluster.raft.base.messages.Replicate
 
getReplicatedToAllIndex() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getReplicatedToAllIndex() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getReplicatedToAllIndex() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
getReplicatedToAllIndex() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
getReplicatedToAllIndex() - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
Returns the index of the last log entry that has been replicated to all peers.
getReplicatedToAllIndex() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getReplicatedToAllIndex() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
getReplicatedToAllTerm() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
getReplyTarget() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Returns the user-defined target for sliced message replies.
getReplyTo() - Method in class org.opendaylight.controller.cluster.access.concepts.Request
Return the return address where responses to this request should be directed to.
getReplyTo() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlice
 
getReplyTo() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions
 
getReplyTo() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestLeadership
 
getRepresentation() - Method in class org.opendaylight.controller.cluster.schema.provider.impl.YangTextSchemaSourceSerializationProxy
 
getRequest() - Method in class org.opendaylight.controller.cluster.access.client.ConnectionEntry
 
getRequestedFollowerId() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestLeadership
 
getRequestedFollowerId() - Method in class org.opendaylight.controller.cluster.raft.RaftActorLeadershipTransferCohort
 
getRequestTimeout() - Method in interface org.opendaylight.controller.cluster.access.client.ClientActorConfig
Returns the timeout interval whereby requests are failed.
getRequestTimeout() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getRestoreFromSnapshot() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
getRestoreFromSnapshot() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorRecoveryCohort
Returns the snapshot to restore from on recovery.
getRole() - Method in class org.opendaylight.controller.cluster.datastore.messages.GetShardRoleReply
 
getRole() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutput
Current role for the given shard, if not present the shard currently does not have a role
getRole() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
 
getRole() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
Current role for the given shard, if not present the shard currently does not have a role
getRole() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
 
getRoleChangeNotifier() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
getRoleChangeNotifier() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Notifier Actor for this RaftActor to notify when a role change happens.
getRootNode() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardDataTreeSnapshot
Get the root data node contained in this snapshot.
getRootOperation(DistributedShardModification) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardModificationCursor
 
getRouter() - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry.RemoteActionEndpoint
 
getRouter() - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.RemoteRpcEndpoint
 
getRpcBrokerName() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcBrokerPath() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcEndpoints() - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.Messages.UpdateRemoteEndpoints
 
getRpcErrors() - Method in exception org.opendaylight.controller.remote.rpc.RpcErrorsException
 
getRpcManagerName() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcManagerPath() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcRegistrarName() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcRegistryName() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcRegistryPath() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcRegistryPersistenceId() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
getRpcs() - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.RemoteRpcEndpoint
 
getSchemaContext() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
getSchemaContext() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getSchemaContext() - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
 
getSelfAddress() - Method in interface org.opendaylight.controller.cluster.datastore.ClusterWrapper
 
getSelfAddress() - Method in class org.opendaylight.controller.cluster.datastore.ClusterWrapperImpl
 
getSendTo() - Method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
 
getSendToRef() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions
 
getSendToSelection() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions
 
getSequence() - Method in class org.opendaylight.controller.cluster.access.concepts.Message
Get the logical sequence number.
getServerConfig() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getServerConfig() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
 
getServerConfiguration() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getServerId() - Method in class org.opendaylight.controller.cluster.raft.messages.RemoveServer
 
getServerId() - Method in class org.opendaylight.controller.cluster.raft.messages.ServerRemoved
 
getServersVisited() - Method in class org.opendaylight.controller.cluster.raft.messages.ChangeServersVotingStatus
 
getServerVotingStatusMap() - Method in class org.opendaylight.controller.cluster.raft.messages.ChangeServersVotingStatus
 
getSessionId() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
getSessionId() - Method in class org.opendaylight.controller.cluster.access.concepts.Envelope
Get the session identifier.
getShard() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShards
List of prefix-based shards configured.
getShard() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
 
getShardAccess(DOMDataTreeIdentifier) - Method in interface org.opendaylight.controller.cluster.dom.api.CDSDataTreeProducer
Return a CDSShardAccess handle.
getShardActor() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
getShardBatchedModificationCount() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardBatchedModificationCount() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The number of transaction modification operations (put, merge, delete) to batch before sending to the shard transaction actor.
getShardBatchedModificationCount() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardBuilder() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateShard
 
getShardCommitQueueExpiryTimeoutInMillis() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardCommitQueueExpiryTimeoutInSeconds() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardCommitQueueExpiryTimeoutInSeconds() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardCommitQueueExpiryTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum amount of time a transaction can remain in a shard's commit queue waiting to begin the CanCommit phase as coordinated by the broker front-end.
getShardCommitQueueExpiryTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardConfig(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
getShardConfigs() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
getShardDatastoreContext(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextFactory
 
getShardDatastoreContext(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextIntrospector
 
GetShardDataTree - Class in org.opendaylight.controller.cluster.datastore.messages
Local message sent to a Shard to retrieve its data tree instance.
getShardElectionTimeoutFactor() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardElectionTimeoutFactor() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardElectionTimeoutFactor() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardElectionTimeoutFactor() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The multiplication factor to be used to determine shard election timeout.
getShardElectionTimeoutFactor() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardHeartbeatIntervalInMillis() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardHeartbeatIntervalInMillis() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardHeartbeatIntervalInMillis() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The interval at which a shard will send a heart beat message to its remote shard.
getShardHeartbeatIntervalInMillis() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardIdentifier() - Method in interface org.opendaylight.controller.cluster.dom.api.CDSShardAccess
Return the shard identifier.
getShardIdentifier(MemberName, DOMDataTreeIdentifier) - Static method in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
getShardingService() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
getShardInitializationTimeout() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardInitializationTimeoutInSeconds() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardInitializationTimeoutInSeconds() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardInitializationTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum amount of time to wait for a shard to initialize from persistence on startup before failing an operation (eg transaction create and change listener registration).
getShardInitializationTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardIsolatedLeaderCheckIntervalInMillis() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardIsolatedLeaderCheckIntervalInMillis() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardIsolatedLeaderCheckIntervalInMillis() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The interval at which the leader of the shard will check if its majority followers are active and term itself as isolated
getShardIsolatedLeaderCheckIntervalInMillis() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardJournalRecoveryLogBatchSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardJournalRecoveryLogBatchSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardJournalRecoveryLogBatchSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum number of journal log entries to batch on recovery for a shard before committing to the data store.
getShardJournalRecoveryLogBatchSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardLeaderElectionTimeout() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardLeaderElectionTimeoutInSeconds() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardLeaderElectionTimeoutInSeconds() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardLeaderElectionTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum amount of time to wait for a shard to elect a leader before failing an operation (eg transaction create).
getShardLeaderElectionTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardList() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardManagerSnapshot
 
getShardList() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerSnapshot
Deprecated.
 
getShardManager() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getShardManagerCreator() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
getShardManagerPersistenceId() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardManagerSnapshot() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot
 
getShardMemberNames() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
 
getShardMemberNames() - Method in class org.opendaylight.controller.cluster.datastore.config.PrefixShardConfiguration
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getShardName() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.messages.AddShardReplica
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.messages.ChangeShardMembersVotingStatus
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.messages.FindLocalShard
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.messages.FindPrimary
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.messages.FlipShardMembersVotingStatus
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.messages.LocalShardNotFound
 
getShardName() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemoveShardReplica
 
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
getShardName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
The name of the shard.
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultKey
 
getShardNameForModule(String) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns the first shard name corresponding to the given module name or null if none is configured.
getShardNameForModule(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getShardNameForPrefix(DOMDataTreeIdentifier) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Return the shard name corresponding to the prefix, or null if none is configured.
getShardNameForPrefix(DOMDataTreeIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getShardNames() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
getShardPrefix() - Method in class org.opendaylight.controller.cluster.datastore.messages.AddPrefixShardReplica
 
getShardPrefix() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemovePrefixShardReplica
 
getShardPrefix() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInput
 
getShardPrefix() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
getShardPrefix() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInput
 
getShardPrefix() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
getShardPrefix() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInput
 
getShardPrefix() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
getShardRaftConfig() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
 
getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
 
getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
 
getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
 
getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
 
getShardResult() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardResultOutput
The list of results, one per shard
getShardRole(GetShardRoleInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
getShardRole(GetShardRoleInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Returns the current role for the requested module shard.
GetShardRole - Class in org.opendaylight.controller.cluster.datastore.messages
Message sent to the local ShardManager to request the current role for the given shard.
GetShardRole(String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.GetShardRole
 
GetShardRoleInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
GetShardRoleInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds GetShardRoleInputBuilder instances.
GetShardRoleInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
GetShardRoleInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
GetShardRoleInputBuilder(GetShardRoleInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
GetShardRoleOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
GetShardRoleOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds GetShardRoleOutputBuilder instances.
GetShardRoleOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
 
GetShardRoleOutputBuilder(GetShardRoleOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
 
GetShardRoleReply - Class in org.opendaylight.controller.cluster.datastore.messages
Reply to GetShardRole, containing the current role of the shard if present on the ShardManager.
GetShardRoleReply(String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.GetShardRoleReply
 
getShardSnapshotBatchCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardSnapshotBatchCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardSnapshotBatchCount() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The minimum number of entries to be present in the in-memory journal log before a snapshot is to be taken.
getShardSnapshotBatchCount() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardSnapshotChunkSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Deprecated.
getShardSnapshotChunkSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardSnapshotDataThreshold() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardSnapshotDataThreshold() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardSnapshotDataThreshold() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The threshold of in-memory journal size before a snapshot is to be taken.
getShardSnapshotDataThreshold() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardSnapshotDataThresholdPercentage() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardSnapshotDataThresholdPercentage() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardSnapshotDataThresholdPercentage() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The percentage of Runtime.maxMemory() used by the in-memory journal log before a snapshot is to be taken.
getShardSnapshotDataThresholdPercentage() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardSnapshots() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot
 
getShardStatsMBean(String, String, Shard) - Static method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardMBeanFactory
 
getShardStrategy() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
 
getShardStrategyFactory() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
getShardStrategyName() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
 
getShardStrategyName() - Method in class org.opendaylight.controller.cluster.datastore.config.PrefixShardConfiguration
 
getShardTransactionCommitQueueCapacity() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardTransactionCommitQueueCapacity() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardTransactionCommitQueueCapacity() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardTransactionCommitQueueCapacity() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum allowed capacity for each shard's transaction commit queue.
getShardTransactionCommitQueueCapacity() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardTransactionCommitTimeoutInSeconds() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardTransactionCommitTimeoutInSeconds() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardTransactionCommitTimeoutInSeconds() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShardTransactionCommitTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum amount of time a shard transaction three-phase commit can be idle without receiving the next messages before it aborts the transaction
getShardTransactionCommitTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardTransactionIdleTimeout() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getShardTransactionIdleTimeoutInMinutes() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The maximum amount of time a shard transaction can be idle without receiving any messages before it self-destructs.
getShardTransactionIdleTimeoutInMinutes() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getShardTransactionIdleTimeoutInSeconds() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getShardTransactionIdleTimeoutInSeconds() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getShortestCommitTime() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBean
Returns a string representing the time duration of the shortest commit, in the appropriate scaled units, along with the date/time that it occurred.
getShortestCommitTime() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBeanImpl
 
getSliceIndex() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlice
 
getSliceIndex() - Method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
 
getSnapshot() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot.ShardSnapshot
 
getSnapshot() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardSnapshotState
 
getSnapshot() - Method in class org.opendaylight.controller.cluster.raft.base.messages.ApplySnapshot
 
getSnapshot() - Method in class org.opendaylight.controller.cluster.raft.base.messages.SendInstallSnapshot
 
getSnapshot() - Method in class org.opendaylight.controller.cluster.raft.client.messages.GetSnapshotReply
 
GetSnapshot - Class in org.opendaylight.controller.cluster.raft.client.messages
Internal client message to get a snapshot of the current state based on whether or not persistence is enabled.
GetSnapshot(Timeout) - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.GetSnapshot
 
getSnapshotBatchCount() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the minimum number of entries to be present in the in-memory Raft log for a snapshot to be taken.
getSnapshotBatchCount() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getSnapshotBytes() - Method in class org.opendaylight.controller.cluster.raft.base.messages.SendInstallSnapshot
 
getSnapshotChunkSize() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the maximum size (in bytes) for the snapshot chunk sent from a Leader.
getSnapshotChunkSize() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getSnapshotDataThreshold() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the max size of memory used in the in-memory Raft log before a snapshot should be taken.
getSnapshotDataThreshold() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getSnapshotDataThresholdPercentage() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the percentage of total memory used in the in-memory Raft log before a snapshot should be taken.
getSnapshotDataThresholdPercentage() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getSnapshotIndex() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getSnapshotIndex() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getSnapshotIndex() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
getSnapshotIndex() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getSnapshotIndex() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Returns the index of the snapshot.
getSnapshotManager() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the SnapshotManager instance.
getSnapshotManager() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
GetSnapshotReply - Class in org.opendaylight.controller.cluster.raft.client.messages
Reply to GetSnapshot that returns a serialized Snapshot instance.
GetSnapshotReply(String, Snapshot) - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.GetSnapshotReply
 
getSnapshotState() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshotReply
 
getSnapshotTerm() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getSnapshotTerm() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getSnapshotTerm() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
getSnapshotTerm() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getSnapshotTerm() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Returns the term of the snapshot.
getSource(SourceIdentifier) - Method in class org.opendaylight.controller.cluster.schema.provider.impl.RemoteSchemaProvider
 
getSourceNodeKey() - Method in interface org.opendaylight.controller.messagebus.spi.EventSource
Identifier of node associated with event source.
getState() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
 
getState() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getStatRetrievalError() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getStatRetrievalError() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getStatRetrievalTime() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getStatRetrievalTime() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getStatus() - Method in class org.opendaylight.controller.cluster.raft.messages.AbstractServerChangeReply
 
getStatus() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotification
Current status of event source.
getStatus() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
 
getStatus() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutput
 
getStatus() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
 
getStoreRoot() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getStrategy(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.shardstrategy.ShardStrategyFactory
 
getStrategyForModule(String) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns the ShardStrategy for the given module name or null if the module is not found.
getStrategyForModule(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getStrategyForPrefix(DOMDataTreeIdentifier) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns the ShardStrategy for the given prefix or null if the prefix is not found.
getStrategyForPrefix(DOMDataTreeIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getStreamVersion() - Method in enum org.opendaylight.controller.cluster.access.ABIVersion
Return the NormalizedNode stream version corresponding to this particular ABI.
getStreamVersion() - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
getStreamVersion() - Method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Return the NormalizedNode stream version corresponding to this particular ABI.
getSubtransaction(LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
Returns subtransaction associated with supplied key.
getSubtransactions() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
Returns immutable Iterable of all subtransactions.
getSubtrees() - Method in class org.opendaylight.controller.cluster.sharding.messages.NotifyProducerCreated
 
getSubtrees() - Method in class org.opendaylight.controller.cluster.sharding.messages.NotifyProducerRemoved
 
getSubtrees() - Method in class org.opendaylight.controller.cluster.sharding.messages.ProducerCreated
 
getSubtrees() - Method in class org.opendaylight.controller.cluster.sharding.messages.ProducerRemoved
 
getSyncIndexThreshold() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the threshold in terms of number journal entries that we can lag behind a leader until we raise a 'not synced' transition.
getSyncIndexThreshold() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getSyncIndexThreshold() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Permitted synchronization lag, expressed in terms of RAFT entry count.
getSyncIndexThreshold() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getSyncStatus() - Method in interface org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerInfoMBean
Returns the overall sync status for all shards.
getTarget() - Method in class org.opendaylight.controller.cluster.access.concepts.Message
Get the target identifier for this message.
getTempFileDirectory() - Method in interface org.opendaylight.controller.cluster.access.client.ClientActorConfig
Returns the directory in which to create temporary files.
getTempFileDirectory() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getTempFileDirectory() - Method in interface org.opendaylight.controller.cluster.raft.ConfigParams
Returns the directory in which to create temp files.
getTempFileDirectory() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
getTerm() - Method in class org.opendaylight.controller.cluster.raft.messages.AbstractRaftRPC
 
getTerm() - Method in interface org.opendaylight.controller.cluster.raft.messages.RaftRPC
Return the term in which this call is being made.
getTerm() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
getTerm() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
Returns the term of the entry.
getTermInformation() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the current ElectionTerm information.
getTermInformation() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getTimeout() - Method in class org.opendaylight.controller.cluster.raft.client.messages.GetSnapshot
 
getTimeout() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
Optional timeout in seconds for the backup operation which will override all the different timeouts that are being hit on the backend.
getTimeout() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
getTimeSinceLastActivity() - Method in class org.opendaylight.controller.cluster.raft.client.messages.FollowerInfo
 
getToIndex() - Method in class org.opendaylight.controller.cluster.raft.persisted.ApplyJournalEntries
 
getTopicId() - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopic
 
getTopicId() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutput
 
getTopicId() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
 
getTopicId() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInput
 
getTopicId() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
 
getTopicId() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotification
Topic to which this event is being delivered.
getTopicId() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
getTopicId() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInput
identifier of topic to be disjoin
getTopicId() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
getTopicId() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInput
in current implementation notification-pattern is defined by topic-id.
getTopicId() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
getTopology() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNode
 
getTopology() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
getTopologyEventSource() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyEventSourceType
 
getTopologyEventSource() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1Builder
 
getTotalChunks() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
getTotalCommits() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBean
Returns the total number of commits that have occurred.
getTotalCommits() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.CommitStatsMXBeanImpl
 
getTotalMemory() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Returns the total available memory for use in calculations.
getTotalMemory() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
getTotalMessagesSent() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
getTotalSlices() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlice
 
getTotalSlices() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Returns the total number of slices to send.
getTotalTaskCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
getTotalTaskCount() - Method in interface org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBean
Returns the total task count.
getTotalTaskCount() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
 
getTransaction() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
 
getTransactionCommitOperationTimeout() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Returns the operation timeout to be used when committing transactions.
getTransactionContextDebugEnabled() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getTransactionContextDebugEnabled() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getTransactionCreationInitialRateLimit() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
getTransactionCreationInitialRateLimit() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
getTransactionCreationInitialRateLimit() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
getTransactionCreationInitialRateLimit() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
The initial number of transactions per second that are allowed before the data store should begin applying back pressure.
getTransactionCreationInitialRateLimit() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
getTransactionCreationRateLimit() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBean
 
getTransactionCreationRateLimit() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBeanImpl
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
 
getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
getTransactionPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
getTransactionType() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
getTreeChangeListenerActors() - Method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState
 
getTreeType() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
getTxCohortCacheSize() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getTxCohortCacheSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getTxCreationLimit() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Get the current transaction creation rate limit.
getTxCreationLimit() - Method in class org.opendaylight.controller.cluster.datastore.utils.TransactionRateLimiter
 
getTxFactories() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
Convenience accessor of backing factories intended to be used only by finalization of this class.
getTxFactory(LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
 
getTxnClientVersion() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
 
getTxSequence() - Method in class org.opendaylight.controller.cluster.access.concepts.Envelope
Get the message transmission sequence of this envelope.
getType() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
getType() - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
getType() - Method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
 
getType() - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
getType() - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
getType() - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
getType() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot
 
getType() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendShardDataTreeSnapshotMetadata
 
getType() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardDataTreeSnapshotMetadata
 
getType() - Method in class org.opendaylight.controller.cluster.sharding.messages.StartConfigShardLookup
 
getType() - Method in class org.opendaylight.controller.messagebus.app.util.TopicDOMNotification
 
getType() - Method in class org.opendaylight.controller.remote.rpc.messages.AbstractExecute
 
getType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifier
 
getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierKey
 
getType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendIdentifier
 
getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsKey
 
getUnAppliedEntries() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
getUnAppliedEntries() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
getUniqueMemberNamesForAllShards() - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Returns a unique set of all member names configured for all shards.
getUniqueMemberNamesForAllShards() - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
getUsageCount() - Method in class org.opendaylight.controller.cluster.io.SharedFileBackedOutputStream
Returns the current usage count.
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.Pattern
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicId
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRef
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.MemberName
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
 
getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
 
getVersion() - Method in exception org.opendaylight.controller.cluster.access.AbstractVersionException
Return the numeric version which has caused this exception.
getVersion() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
getVersion() - Method in class org.opendaylight.controller.cluster.access.concepts.Message
 
getVersion() - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
getVersion() - Method in class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
 
getVersion() - Method in exception org.opendaylight.controller.cluster.datastore.persisted.AbstractVersionException
Return the numeric version which has caused this exception.
getVersion() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
 
getVersion() - Method in interface org.opendaylight.controller.remote.rpc.registry.gossip.Bucket
 
getVersions() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
getVisitedAddresses() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemoteFindPrimary
 
getVotedFor() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
getVotedFor() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
getVotedFor() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
getVotedFor() - Method in interface org.opendaylight.controller.cluster.raft.ElectionTerm
Returns the id of the candidate that this server voted for in current term.
getVotedFor() - Method in class org.opendaylight.controller.cluster.raft.ImmutableElectionTerm
 
getVotedFor() - Method in class org.opendaylight.controller.cluster.raft.persisted.UpdateElectionTerm
 
getVotingState() - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
 
getWatchActor() - Method in class org.opendaylight.controller.remote.rpc.registry.AbstractRoutingTable
 
getWatchActor() - Method in interface org.opendaylight.controller.remote.rpc.registry.gossip.Bucket
 
getWatchActor() - Method in interface org.opendaylight.controller.remote.rpc.registry.gossip.BucketData
Return the ActorRef which should be tracked as the authoritative source of this bucket's data.
getYangGeneration() - Method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
getYangTextSchemaSource(SourceIdentifier) - Method in interface org.opendaylight.controller.cluster.schema.provider.RemoteYangTextSourceProvider
 
getYangTextSchemaSource(SourceIdentifier) - Method in class org.opendaylight.controller.cluster.schema.provider.impl.RemoteYangTextSourceProviderImpl
 
globalEventExecutor() - Static method in interface org.opendaylight.controller.config.yang.netty.eventexecutor.AutoCloseableEventExecutor
 
Gossiper - Class in org.opendaylight.controller.remote.rpc.registry.gossip
Gossiper that syncs bucket store across nodes in the cluster.
gossipTickInterval(String) - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig.Builder
 

H

haltClient(Throwable) - Method in class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
Halt And Catch Fire.
handleAppendEntries(ActorRef, AppendEntries) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
handleAppendEntries(ActorRef, AppendEntries) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Derived classes should not directly handle AppendEntries messages it should let the base class handle it first.
handleAppendEntries(ActorRef, AppendEntries) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
handleAppendEntries(ActorRef, AppendEntries) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
handleAppendEntriesReply(ActorRef, AppendEntriesReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
handleAppendEntriesReply(ActorRef, AppendEntriesReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Derived classes should not directly handle AppendEntriesReply messages it should let the base class handle it first.
handleAppendEntriesReply(ActorRef, AppendEntriesReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
handleAppendEntriesReply(ActorRef, AppendEntriesReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
handleAppendEntriesReply(ActorRef, AppendEntriesReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.IsolatedLeader
 
handleAppendEntriesReply(ActorRef, AppendEntriesReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Leader
 
handleBatchedModificationsLocal(BatchedModifications, ActorRef) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
handleCommand(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
handleCommand(Object) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Deprecated.
This method is not final for testing purposes. DO NOT OVERRIDE IT, override RaftActor.handleNonRaftCommand(Object) instead.
handleCommand(Object) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor
 
handleCommand(Object) - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry
 
handleCommand(Object) - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
handleCommand(Object) - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry
 
handleMessage(ActorRef, Object) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
handleMessage(ActorRef, Object) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
handleMessage(ActorRef, Object) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
handleMessage(ActorRef, Object) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
handleMessage(ActorRef, Object) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Leader
 
handleMessage(ActorRef, Object) - Method in class org.opendaylight.controller.cluster.raft.behaviors.PreLeader
 
handleMessage(ActorRef, Object) - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
Handle a message.
handleMessage(Object) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer
Invoked to handle messages pertaining to this class.
handleMessage(Object, ActorRef) - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler
Invoked to handle message slices and other messages pertaining to this class.
handleNonRaftCommand(Object) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
handleNonRaftCommand(Object) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Method exposed for subclasses to plug-in their logic.
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
Receive and handle an incoming message.
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.actors.ShardSnapshotActor
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeChangePublisherActor
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeNotificationPublisherActor
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardReadTransaction
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardReadWriteTransaction
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotifier
 
handleReceive(Object) - Method in class org.opendaylight.controller.cluster.sharding.RoleChangeListenerActor
 
handleReceive(Object) - Method in class org.opendaylight.controller.remote.rpc.OpsManager
 
handleReceive(Object) - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.Gossiper
 
handleRecover(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
handleRecover(Object) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
handleRecover(Object) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
handleRecover(Object) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor
 
handleRecover(Object) - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
handleRequestVoteReply(ActorRef, RequestVoteReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
handleRequestVoteReply(ActorRef, RequestVoteReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Derived classes should not directly handle RequestVoteReply messages it should let the base class handle it first.
handleRequestVoteReply(ActorRef, RequestVoteReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Candidate
 
handleRequestVoteReply(ActorRef, RequestVoteReply) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
hasFollowers() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
hasFollowers() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Determines if there are any peer followers.
hasFollowers() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
hashCode() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
hashCode() - Method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
hashCode() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
hashCode() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
hashCode() - Method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
hashCode() - Method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
hashCode() - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
hashCode() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
hashCode() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier
 
hashCode() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
 
hashCode() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
 
hashCode() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.Pattern
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicId
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorKey
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRef
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierKey
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.MemberName
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsKey
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultKey
 
hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardKey
 
HashedWheelTimerCloseable - Class in org.opendaylight.controller.config.yang.netty.timer
 
hasStaleCommitIndex(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
 
HEART_BEAT_INTERVAL - Static variable in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
The interval at which a heart beat message will be sent to the remote RaftActor.
HeartbeatIntervalType - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
 
HeartbeatIntervalType(Integer) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link HeartbeatIntervalType(Uint16)} instead.
HeartbeatIntervalType(HeartbeatIntervalType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
Creates a copy from Source Object.
HeartbeatIntervalType(Uint16) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
 
HELIUM_1_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
Deprecated.
HELIUM_2_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
Deprecated.
HELIUM_VERSION - Static variable in class org.opendaylight.controller.cluster.raft.RaftVersions
 
HybridModuleShardConfigProvider - Class in org.opendaylight.controller.cluster.datastore.config
 
HybridModuleShardConfigProvider(Config, String) - Constructor for class org.opendaylight.controller.cluster.datastore.config.HybridModuleShardConfigProvider
 

I

id(ShardIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
IdentifiableNode - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
 
IdentifiableNodeBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
Class that builds IdentifiableNodeBuilder instances.
IdentifiableNodeBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
 
IdentifiableNodeBuilder(IdentifiableNode) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
 
IdentifiableNodeBuilder(NodeIdentifiers) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
 
IdentifiablePayload<T extends Identifier> - Class in org.opendaylight.controller.cluster.raft.protobuff.client.messages
 
IdentifiablePayload() - Constructor for class org.opendaylight.controller.cluster.raft.protobuff.client.messages.IdentifiablePayload
 
identifier() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
 
identifier() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntrySerializer
 
identifier(Identifier) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Sets the identifier of the component to slice.
ignoreMessage(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
 
ignoreMessage(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
IMMEDIATE_BOOLEAN_SUCCESS - Static variable in class org.opendaylight.controller.cluster.datastore.AbstractThreePhaseCommitCohort
 
IMMEDIATE_VOID_SUCCESS - Static variable in class org.opendaylight.controller.cluster.datastore.AbstractThreePhaseCommitCohort
 
immediateEventExecutor() - Static method in interface org.opendaylight.controller.config.yang.netty.eventexecutor.AutoCloseableEventExecutor
 
ImmutableElectionTerm - Class in org.opendaylight.controller.cluster.raft
Immutable implementation of ElectionTerm.
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.topic.notification.Payload
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotification
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotification
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.Node1
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSource
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyEventSourceType
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Node
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnector
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnector
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemoved
Deprecated.
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdated
Deprecated.
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeContextRef
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemoved
Deprecated.
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Nodes
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.Node
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdated
Deprecated.
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNode
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifier
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Node1
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.NodeIdentifiers
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Topology1
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNode
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeConnector
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNode
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNode
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopology
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregateNode
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregateTopology
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientIdentifier
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendIdentifier
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainer
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClients
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRef
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.Local
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingState
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MemberVotingStatesInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResult
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardResultOutput
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.Shard
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.Replicas
 
implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShards
 
Inactive - org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
 
includeManifest() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
 
includeManifest() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntrySerializer
 
increaseJournalLogCapacity(int) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
increaseJournalLogCapacity(int) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Optimization method to increase the capacity of the journal log prior to appending entries.
incrementAbortTransactionsCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
incrementCommittedTransactionCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
incrementFailedReadTransactionsCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
incrementFailedTransactionsCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
incrementLeadershipChangeCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
incrementReadOnlyTransactionCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
incrementReadWriteTransactionCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
IncrementTransactionSequenceRequest - Class in org.opendaylight.controller.cluster.access.commands
A blank transaction request.
IncrementTransactionSequenceRequest(TransactionIdentifier, long, ActorRef, boolean, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceRequest
 
IncrementTransactionSequenceSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to an IncrementTransactionSequenceRequest.
IncrementTransactionSequenceSuccess(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceSuccess
 
incrementUsageCount() - Method in class org.opendaylight.controller.cluster.io.SharedFileBackedOutputStream
Increments the usage count.
incrMatchIndex() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Increments the value of the follower's match index.
inEventLoop() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
inEventLoop(Thread) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
inexactReadFrom(DataInput) - Static method in enum org.opendaylight.controller.cluster.access.ABIVersion
 
init() - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardedDOMDataTree
This will try to initialize prefix configuration shards upon their successful start.
init(String) - Method in class org.opendaylight.controller.cluster.datastore.DataTreeCohortRegistrationProxy
 
InitConfigListener - Class in org.opendaylight.controller.cluster.sharding.messages
Message sent to the local ShardManager, once the shard configuration shard is ready and the ShardManager should start its listener.
initialBehavior(ClientActorContext) - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActor
 
initialBehavior(ClientActorContext) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractDataStoreClientActor
 
initializeForPath(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
Initialize this pruner for processing a node at specified path.
initialPayloadSerializedBufferCapacity(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
initialSettleFuture() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
Future which completes when all shards settle for the first time.
initialSettleTimeoutMultiplier(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
initiateCaptureSnapshot(String) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
Initiates a snapshot capture to install on a follower.
InitiateCaptureSnapshot - Class in org.opendaylight.controller.cluster.raft.base.messages
 
InitiateCaptureSnapshot() - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.InitiateCaptureSnapshot
 
initListener(DistributedDataStoreInterface, LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.sharding.PrefixedShardConfigUpdateHandler
 
inMemoryJournalDataSize(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
inMemoryJournalLogSize(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
InputOutputStreamFactory - Class in org.opendaylight.controller.cluster.io
 
InstallSnapshot - Class in org.opendaylight.controller.cluster.raft.messages
Message sent from a leader to install a snapshot chunk on a follower.
InstallSnapshot(long, String, long, long, byte[], int, int) - Constructor for class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
InstallSnapshot(long, String, long, long, byte[], int, int, OptionalInt, Optional<ServerConfigurationPayload>) - Constructor for class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
InstallSnapshotReply - Class in org.opendaylight.controller.cluster.raft.messages
 
InstallSnapshotReply(long, String, int, boolean) - Constructor for class org.opendaylight.controller.cluster.raft.messages.InstallSnapshotReply
 
instance() - Static method in class org.opendaylight.controller.cluster.raft.NoopProcedure
 
instance(short) - Static method in class org.opendaylight.controller.cluster.datastore.messages.AbortTransactionReply
 
instance(short) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.GetInfo
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.GetKnownClients
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.GetShardDataTree
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.MakeLeaderLocal
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.OnInitialData
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.SuccessReply
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.base.messages.CheckConsensusReached
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.base.messages.ElectionTimeout
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.base.messages.SendHeartBeat
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.base.messages.SnapshotComplete
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.base.messages.TimeoutNow
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.client.messages.FindLeader
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.client.messages.GetOnDemandRaftState
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.client.messages.GetSnapshot
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.client.messages.Shutdown
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.NoopPeerAddressResolver
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.NoopRaftActorSnapshotCohort
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.persisted.EmptyState
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.persisted.NoopPayload
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.raft.policy.DefaultRaftPolicy
 
INSTANCE - Static variable in class org.opendaylight.controller.cluster.sharding.messages.InitConfigListener
 
INSTANCE - Static variable in class org.opendaylight.controller.sal.common.util.NoopAutoCloseable
 
InternalCommand<T extends BackendInfo> - Interface in org.opendaylight.controller.cluster.access.client
This interface is used to pass the unit of work via the actors mailbox.
internalSwitchBehavior(RaftActorBehavior) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
internalSwitchBehavior(RaftState) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
INVALID_REQUEST - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
Some part of the request is invalid.
InventoryNode - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030
 
InventoryNodeBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030
Class that builds InventoryNodeBuilder instances.
InventoryNodeBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeBuilder
 
InventoryNodeBuilder(InventoryNode) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeBuilder
 
InventoryNodeConnector - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030
 
InventoryNodeConnectorBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030
Class that builds InventoryNodeConnectorBuilder instances.
InventoryNodeConnectorBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeConnectorBuilder
 
InventoryNodeConnectorBuilder(InventoryNodeConnector) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeConnectorBuilder
 
InversibleLock - Class in org.opendaylight.controller.cluster.access.client
A lock implementation which allows users to perform optimistic reads and validate them in a fashion similar to StampedLock.
InversibleLock() - Constructor for class org.opendaylight.controller.cluster.access.client.InversibleLock
 
InversibleLockException - Exception in org.opendaylight.controller.cluster.access.client
Exception thrown from InversibleLock.optimisticRead() and can be used to wait for the racing write to complete using InversibleLockException.awaitResolution().
invokeAll(Collection<? extends Callable<T>>) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
isActive() - Method in class org.opendaylight.controller.cluster.raft.client.messages.FollowerInfo
 
isApplying() - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
isCapturing() - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
isCapturing() - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Returns whether or not a capture is in progress.
isClosed() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
isCoordinated() - Method in class org.opendaylight.controller.cluster.access.commands.CommitLocalTransactionRequest
Indicate if this is a coordinated, multi-backend request.
isDefinedAt(Object) - Method in class org.opendaylight.controller.cluster.common.actor.MeteringBehavior
 
isDoCommitOnReady() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
isDoCommitOnReady() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
 
isDoImmediateCommit() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
 
isDynamicServerConfigurationInUse() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Determines if there have been any dynamic server configuration changes applied.
isDynamicServerConfigurationInUse() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
isEnabled() - Method in class org.opendaylight.controller.cluster.datastore.messages.DataTreeListenerInfo
 
isEnabled() - Method in class org.opendaylight.controller.cluster.datastore.messages.EnableNotification
 
isEnableMetricCapture() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Enable or disable metric capture.
isEnableMetricCapture() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
isFailed() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
 
isFollowerActive() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Checks if the follower is active by comparing the time of the last activity with the election time out.
isForceInstallSnapshot() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
isHandledMessage(Object) - Static method in class org.opendaylight.controller.cluster.messaging.MessageAssembler
Checks if the given message is handled by this class.
isHandledMessage(Object) - Static method in class org.opendaylight.controller.cluster.messaging.MessageSlicer
Checks if the given message is handled by this class.
isHardFailure() - Method in class org.opendaylight.controller.cluster.access.concepts.RequestFailure
Return an indication of whether this a hard failure.
isInitialSyncDone() - Method in class org.opendaylight.controller.cluster.raft.base.messages.FollowerInitialSyncUpStatus
 
isInSnapshot(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
isInSnapshot(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Checks if the entry is present in a snapshot.
isIsolatedLeader() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
isLastSlice(int) - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Determines if the given index is the last slice to send.
isLeader() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Derived actors can call the isLeader method to check if the current RaftActor is the Leader or not.
isLeaderActive() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
isLeaderIsolated() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
isLeadershipTransferInProgress() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
isLogEntrySlicingInProgress() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Return whether or not log entry slicing is currently in progress.
isMandatoryTrim() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
isMetricCaptureEnabled() - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
isMigrated() - Method in interface org.opendaylight.controller.cluster.raft.persisted.MigratedSerializable
Return true if this object was created from a previous serialization format.
isNeedsLeaderAddress() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
IsolatedLeader - Class in org.opendaylight.controller.cluster.raft.behaviors
Leader which is termed as isolated.
IsolatedLeader - org.opendaylight.controller.cluster.raft.RaftState
 
IsolatedLeader(RaftActorContext) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.IsolatedLeader
 
isPathLocal(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
isPersistencePending() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
isPersistencePending() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
Checks if persistence is pending for this entry.
isPersistent() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
isPersistent() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
 
isPersistent() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
isPersistent() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Enable or disable data persistence
isPersistent() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
isPersisting() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
isPresent(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
isPresent(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Checks if the entry at the specified index is present or not.
isReady() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
isRecoveryApplicable() - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
Returns whether or not persistence recovery is applicable/enabled.
isRecoveryApplicable() - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
isRecoveryApplicable() - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
isRecoveryApplicable() - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
 
isRegisterOnAllInstances() - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.client.RequestTimeoutException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.commands.ClosedTransactionException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.commands.DeadHistoryException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.commands.DeadTransactionException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.commands.NotLeaderException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.commands.OutOfOrderRequestException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.commands.OutOfSequenceEnvelopeException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.commands.UnknownHistoryException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.concepts.RequestException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.concepts.RetiredGenerationException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.concepts.RuntimeRequestException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.access.concepts.UnsupportedRequestException
 
isRetriable() - Method in exception org.opendaylight.controller.cluster.messaging.MessageSliceException
Returns whether or not the original operation can be retried.
isSendImmediate() - Method in class org.opendaylight.controller.cluster.raft.base.messages.Replicate
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.AbortTransactionReply
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransaction
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
 
isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
isShardConfigured(String) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
 
isShardConfigured(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
isShutdown() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
isShuttingDown() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
isSnapshotCaptureInitiated() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
isSnapshotCaptureInitiated() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
isSnapshotCaptureInitiated() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
isSnapshotCaptureInitiated(boolean) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
isSnapshotOnly() - Method in class org.opendaylight.controller.cluster.access.commands.AbstractReadTransactionRequest
 
isSnapshotOnRootOverwrite() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
isSnapshotOnRootOverwrite() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Enable or disable capturing snapshots on DataTree root overwrites
isSnapshotOnRootOverwrite() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
isSucceeded() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
isSucceeded() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
 
isSuccess() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
isSuccess() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshotReply
 
isSuccessful() - Method in exception org.opendaylight.controller.cluster.access.commands.ClosedTransactionException
 
isTerminated() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
isTransactionDebugContextEnabled() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
isTransactionDebugContextEnabled() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Enable or disable transaction context debug.
isTransactionDebugContextEnabled() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
isUseLz4Compression() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
isUseLz4Compression() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Use lz4 compression for snapshots, sent from leader to follower, for snapshots stored by LocalSnapshotStore, use akka.conf configuration.
isUseLz4Compression() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
isUseTellBasedProtocol() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
isUseTellBasedProtocol() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
Use a newer protocol between the frontend and backend.
isUseTellBasedProtocol() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
isValidSender(ActorRef) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
 
isVoteGranted() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestVoteReply
 
isVoting() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
isVoting() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
isVoting() - Method in class org.opendaylight.controller.cluster.raft.client.messages.FollowerInfo
 
isVoting() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
isVoting() - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
 
isVoting() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
 
isVoting() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingState
 
isVoting() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
isVoting(boolean) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
isVotingMember() - Method in class org.opendaylight.controller.cluster.raft.messages.AddServer
 
isVotingMember() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Determines if this peer is a voting member of the cluster.
isVotingMember() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
isWaitUntilInitialized() - Method in class org.opendaylight.controller.cluster.datastore.messages.FindLocalShard
 
isWaitUntilReady() - Method in class org.opendaylight.controller.cluster.datastore.messages.FindPrimary
 
isWriteOnlyTransactionOptimizationsEnabled() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
iterator() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 

J

JMX_CATEGORY_CONFIGURATION - Static variable in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
JMX_CATEGORY_SHARD - Static variable in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
joinTopic(JoinTopicInput) - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceService
 
JoinTopicInput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
This class represents the following YANG schema fragment defined in module event-source
JoinTopicInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Class that builds JoinTopicInputBuilder instances.
JoinTopicInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
JoinTopicInputBuilder(JoinTopicInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
JoinTopicOutput - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
This class represents the following YANG schema fragment defined in module event-source
JoinTopicOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Class that builds JoinTopicOutputBuilder instances.
JoinTopicOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
 
JoinTopicOutputBuilder(JoinTopicOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
 
JoinTopicStatus - Enum in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
 
journalPluginId() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 

K

key() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnector
 
key() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
key() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.Node
 
key() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
key() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifier
 
key() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
key() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClients
 
key() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
key() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResult
 
key() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
key() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.Shard
 
key() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
KnownClients - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result
This class represents the following YANG schema fragment defined in module cluster-admin
KnownClientsBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result
Class that builds KnownClientsBuilder instances.
KnownClientsBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
KnownClientsBuilder(ClientIdentifier) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
KnownClientsBuilder(FrontendIdentifier) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
KnownClientsBuilder(KnownClients) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
KnownClientsKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result
 
KnownClientsKey(MemberName, FrontendType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsKey
 
KnownClientsKey(KnownClientsKey) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsKey
Creates a copy from Source Object.

L

last() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
last() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Return the last replicated log entry in the log or null of not found.
lastApplied(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
lastIndex() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
lastIndex() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the index of the last entry in the log.
lastIndex() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Return the index of the last entry in the log or -1 if the log is empty.
lastIndex(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
lastLogIndex(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
lastLogTerm(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
lastTerm() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
lastTerm() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the term of the last entry in the log.
lastTerm() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Return the term of the last entry in the log or -1 if the log is empty.
lastTerm(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
leader(String) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
Leader - Class in org.opendaylight.controller.cluster.raft.behaviors
The behavior of a RaftActor when it is in the Leader state.
Leader - org.opendaylight.controller.cluster.raft.RaftState
 
Leader(RaftActorContext) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.Leader
 
LeaderActorRef - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node
 
LeaderActorRefBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node
Class that builds LeaderActorRefBuilder instances.
LeaderActorRefBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
 
LeaderActorRefBuilder(LeaderActorRef) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
 
LeaderInstallSnapshotState - Class in org.opendaylight.controller.cluster.raft.behaviors
Encapsulates the leader state and logic for sending snapshot chunks to a follower.
LeaderLocation - Enum in org.opendaylight.controller.cluster.dom.api
Enumeration of possible shard leader locations relative to the local node.
LeaderLocationListener - Interface in org.opendaylight.controller.cluster.dom.api
Listener for shard leader location changes.
LeaderLocationListenerRegistration<T extends LeaderLocationListener> - Interface in org.opendaylight.controller.cluster.dom.api
Registration of a LeaderLocationListener.
LeadershipTransferFailedException - Exception in org.opendaylight.controller.cluster.raft
 
LeadershipTransferFailedException(String) - Constructor for exception org.opendaylight.controller.cluster.raft.LeadershipTransferFailedException
 
LeadershipTransferFailedException(String, Throwable) - Constructor for exception org.opendaylight.controller.cluster.raft.LeadershipTransferFailedException
 
LeaderStateChanged - Class in org.opendaylight.controller.cluster.notifications
A local message initiated internally from the RaftActor when some state of a leader has changed.
LeaderStateChanged(String, String, short) - Constructor for class org.opendaylight.controller.cluster.notifications.LeaderStateChanged
 
LeaderTransitioning - Class in org.opendaylight.controller.cluster.raft.base.messages
Message sent from a leader to its followers to indicate leadership transfer is starting.
LeaderTransitioning(String) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.LeaderTransitioning
 
LITHIUM_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
Deprecated.
LITHIUM_VERSION - Static variable in class org.opendaylight.controller.cluster.raft.RaftVersions
 
Local - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node
 
LOCAL - org.opendaylight.controller.cluster.dom.api.LeaderLocation
The leader is co-located on this node.
localActor() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
 
LocalBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node
Class that builds LocalBuilder instances.
LocalBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
 
LocalBuilder(Local) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
 
LocalHistoryFailure - Class in org.opendaylight.controller.cluster.access.commands
Generic RequestFailure involving a LocalHistoryRequest.
LocalHistoryIdentifier - Class in org.opendaylight.controller.cluster.access.concepts
Globally-unique identifier of a local history.
LocalHistoryIdentifier(ClientIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
LocalHistoryIdentifier(ClientIdentifier, long, long) - Constructor for class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
LocalHistoryRequest<T extends LocalHistoryRequest<T>> - Class in org.opendaylight.controller.cluster.access.commands
Abstract base class for Requests involving specific local history.
LocalHistorySuccess - Class in org.opendaylight.controller.cluster.access.commands
Success class for RequestSuccesses involving a specific local history.
LocalHistorySuccess(LocalHistoryIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.LocalHistorySuccess
 
LocalPrimaryShardFound - Class in org.opendaylight.controller.cluster.datastore.messages
Local message sent in reply to FindPrimaryShard to indicate the primary shard is local to the caller.
LocalPrimaryShardFound(String, ReadOnlyDataTree) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.LocalPrimaryShardFound
 
LocalShardFound - Class in org.opendaylight.controller.cluster.datastore.messages
LocalShardFound is a message that is sent by the org.opendaylight.controller.cluster.datastore.shardmanager.ShardManager when it finds a shard with the specified name in it's local shard registry.
LocalShardFound(ActorRef) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.LocalShardFound
 
LocalShardNotFound - Class in org.opendaylight.controller.cluster.datastore.messages
LocalShardNotFound is a message that is sent by the org.opendaylight.controller.cluster.datastore.shardmanager.ShardManager when it cannot locate a shard in it's local registry with the shardName specified.
LocalShardNotFound(String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.LocalShardNotFound
Constructs an instance.
LocalShardNotFoundException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
Exception thrown when attempting to find a local shard but it doesn't exist.
LocalShardNotFoundException(String) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.LocalShardNotFoundException
 
LocalSnapshotStore - Class in org.opendaylight.controller.cluster.persistence
Akka SnapshotStore implementation backed by the local file system.
LocalSnapshotStore(Config) - Constructor for class org.opendaylight.controller.cluster.persistence.LocalSnapshotStore
 
locateShard(LocateShardInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
locateShard(LocateShardInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Return the transport-level information about where a shard has a home.
LocateShardInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
LocateShardInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds LocateShardInputBuilder instances.
LocateShardInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
LocateShardInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
LocateShardInputBuilder(LocateShardInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
LocateShardOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
LocateShardOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds LocateShardOutputBuilder instances.
LocateShardOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
 
LocateShardOutputBuilder(LocateShardOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
 
log - Variable in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Used for message logging.
LOG - Variable in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
 
LOG - Variable in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
logContext() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeNotificationPublisherActor
 
logContext(String) - Method in class org.opendaylight.controller.cluster.messaging.MessageAssembler.Builder
Sets the context for log messages.
logContext(String) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer.Builder
Sets the context for log messages.
logicalStoreType(LogicalDatastoreType) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
logName() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
LookupPrefixShard - Class in org.opendaylight.controller.cluster.sharding.messages
Sent to the local ShardedDataTreeActor when there was a shard created on the local node.
LookupPrefixShard(DOMDataTreeIdentifier) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.LookupPrefixShard
 
lz4(String) - Static method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
 
lz4(LZ4FrameOutputStream.BLOCKSIZE) - Static method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
 

M

MAGNESIUM - org.opendaylight.controller.cluster.access.ABIVersion
Revised ABI version.
MAGNESIUM - org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Revised payload version.
MAGNESIUM_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
 
mailboxCapacity(int) - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig.Builder
 
mailboxPushTimeout(String) - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig.Builder
 
makeLeaderLocal() - Method in interface org.opendaylight.controller.cluster.dom.api.CDSShardAccess
Request the shard leader to be moved to the local node.
makeLeaderLocal(MakeLeaderLocalInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
makeLeaderLocal(MakeLeaderLocalInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Attempts to move the shard leader of the given module based shard to the local node.
MakeLeaderLocal - Class in org.opendaylight.controller.cluster.datastore.messages
Message sent to local shard to try to gain shard leadership.
MakeLeaderLocalInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
MakeLeaderLocalInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds MakeLeaderLocalInputBuilder instances.
MakeLeaderLocalInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
MakeLeaderLocalInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
MakeLeaderLocalInputBuilder(MakeLeaderLocalInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
MakeLeaderLocalOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
MakeLeaderLocalOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds MakeLeaderLocalOutputBuilder instances.
MakeLeaderLocalOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
 
MakeLeaderLocalOutputBuilder(MakeLeaderLocalOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
 
markFollowerActive() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Marks the follower as active.
markFollowerInActive() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Marks the follower as inactive.
maximumMessageSliceSize(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
maxShardDataChangeExecutorPoolSize(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
Deprecated, for removal: This API element is subject to removal in a future version.
maxShardDataChangeExecutorQueueSize(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
Deprecated, for removal: This API element is subject to removal in a future version.
maxShardDataChangeListenerQueueSize(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
Deprecated, for removal: This API element is subject to removal in a future version.
maxShardDataStoreExecutorQueueSize(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
Deprecated, for removal: This API element is subject to removal in a future version.
maxSlicingTries(int) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer.Builder
Sets the maximum number of tries for slicing a message.
MEGABYTE - Static variable in interface org.opendaylight.controller.cluster.raft.ConfigParams
 
memberName(MemberName) - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier.Builder
 
MemberName - Class in org.opendaylight.controller.cluster.access.concepts
Type-safe encapsulation of a cluster member name.
MemberName - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
 
MemberName(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.MemberName
 
MemberName(MemberName) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.MemberName
Creates a copy from Source Object.
MemberNode - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output
Location of the hypothetical cluster member node.
MemberVotingState - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input
The list of member voting states
MemberVotingStateBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input
Class that builds MemberVotingStateBuilder instances.
MemberVotingStateBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
MemberVotingStateBuilder(MemberVotingState) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
MemberVotingStatesInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
merge() - Method in class org.opendaylight.controller.cluster.common.actor.AbstractConfig.Builder
 
merge(LogicalDatastoreType, YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerWriteTransaction
 
merge(YangInstanceIdentifier.PathArgument, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
 
merge(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
 
merge(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
merge(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification.Proactive
 
merge(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification.Reactive
 
MERGE - Static variable in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
MergeModification - Class in org.opendaylight.controller.cluster.datastore.modification
MergeModification stores all the parameters required to merge data into the specified path.
MergeModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MergeModification
 
MergeModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MergeModification
 
MergeModification(YangInstanceIdentifier, NormalizedNode<?, ?>) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MergeModification
 
message(T) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Sets the message to slice.
Message<T extends WritableIdentifier,​C extends Message<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
An abstract concept of a Message.
MessageAssembler - Class in org.opendaylight.controller.cluster.messaging
This class re-assembles messages sliced into smaller chunks by MessageSlicer.
MessageAssembler.Builder - Class in org.opendaylight.controller.cluster.messaging
 
Messages() - Constructor for class org.opendaylight.controller.remote.rpc.registry.ActionRegistry.Messages
 
Messages() - Constructor for class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.Messages
 
MessageSlice - Class in org.opendaylight.controller.cluster.messaging
Represents a sliced message chunk.
MessageSliceException - Exception in org.opendaylight.controller.cluster.messaging
An exception indicating a message slice failure.
MessageSliceException(String, boolean) - Constructor for exception org.opendaylight.controller.cluster.messaging.MessageSliceException
Constructs an instance.
MessageSliceException(String, Throwable) - Constructor for exception org.opendaylight.controller.cluster.messaging.MessageSliceException
Constructs an instance.
messageSlicer() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
 
MessageSlicer - Class in org.opendaylight.controller.cluster.messaging
This class slices messages into smaller chunks.
MessageSlicer.Builder - Class in org.opendaylight.controller.cluster.messaging
 
MessageSliceReply - Class in org.opendaylight.controller.cluster.messaging
The reply message for MessageSlice.
messageSliceSize(int) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer.Builder
Sets the maximum size (in bytes) for a message slice.
MessageTracker - Class in org.opendaylight.controller.cluster.common.actor
MessageTracker is a diagnostic utility class to be used for figuring out why a certain message which was expected to arrive in a given time interval does not arrive.
MessageTracker(Class<?>, long) - Constructor for class org.opendaylight.controller.cluster.common.actor.MessageTracker
Constructs an instance.
MessageTracker.Context - Class in org.opendaylight.controller.cluster.common.actor
 
MessageTracker.Error - Interface in org.opendaylight.controller.cluster.common.actor
 
MessageTracker.MessageProcessingTime - Class in org.opendaylight.controller.cluster.common.actor
 
MetadataShardDataTreeSnapshot - Class in org.opendaylight.controller.cluster.datastore.persisted
An AbstractVersionedShardDataTreeSnapshot which contains additional metadata.
MetadataShardDataTreeSnapshot(NormalizedNode<?, ?>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.MetadataShardDataTreeSnapshot
 
MetadataShardDataTreeSnapshot(NormalizedNode<?, ?>, Map<Class<? extends ShardDataTreeSnapshotMetadata<?>>, ShardDataTreeSnapshotMetadata<?>>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.MetadataShardDataTreeSnapshot
 
MeteredBoundedMailbox - Class in org.opendaylight.controller.cluster.common.actor
 
MeteredBoundedMailbox(ActorSystem.Settings, Config) - Constructor for class org.opendaylight.controller.cluster.common.actor.MeteredBoundedMailbox
 
MeteredBoundedMailbox.MeteredMessageQueue - Class in org.opendaylight.controller.cluster.common.actor
 
MeteredMessageQueue(int, FiniteDuration) - Constructor for class org.opendaylight.controller.cluster.common.actor.MeteredBoundedMailbox.MeteredMessageQueue
 
MeteringBehavior - Class in org.opendaylight.controller.cluster.common.actor
Represents behaviour that can be exhibited by actors of type AbstractActor
MeteringBehavior(AbstractActor) - Constructor for class org.opendaylight.controller.cluster.common.actor.MeteringBehavior
 
MeteringBehavior(AbstractUntypedActorWithMetering) - Constructor for class org.opendaylight.controller.cluster.common.actor.MeteringBehavior
Constructs an instance.
metricCapture() - Method in annotation type org.opendaylight.controller.remote.rpc.OSGiRemoteOpsProvider.Config
 
metricCaptureEnabled(boolean) - Method in class org.opendaylight.controller.cluster.common.actor.CommonConfig.Builder
 
METRICS_DOMAIN - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
MetricsReporter - Class in org.opendaylight.controller.cluster.reporting
Maintains metrics registry that is provided to reporters.
MigratedSerializable - Interface in org.opendaylight.controller.cluster.raft.persisted
Transitional marker interface for use with evolution of serializable classes held in persistence.
Modification - Interface in org.opendaylight.controller.cluster.datastore.modification
Represents a modification to the data store.
ModifyTransactionRequest - Class in org.opendaylight.controller.cluster.access.commands
A transaction request to apply a particular set of operations on top of the current transaction.
ModifyTransactionRequestBuilder - Class in org.opendaylight.controller.cluster.access.commands
A reusable Builder for creating ModifyTransactionRequest message instances.
ModifyTransactionRequestBuilder(TransactionIdentifier, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
ModifyTransactionSuccess - Class in org.opendaylight.controller.cluster.access.commands
Response to a ModifyTransactionRequest which does not have a PersistenceProtocol.
ModifyTransactionSuccess(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.ModifyTransactionSuccess
 
ModuleConfig - Class in org.opendaylight.controller.cluster.datastore.config
Encapsulates configuration for a module.
ModuleConfig.Builder - Class in org.opendaylight.controller.cluster.datastore.config
 
ModuleShardConfigProvider - Interface in org.opendaylight.controller.cluster.datastore.config
Interface for a class that provides module and shard configuration information.
ModuleShardConfiguration - Class in org.opendaylight.controller.cluster.datastore.config
Encapsulates information for adding a new module shard configuration.
ModuleShardConfiguration(URI, String, String, String, Collection<MemberName>) - Constructor for class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
Constructs a new instance.
ModuleShardStrategy - Class in org.opendaylight.controller.cluster.datastore.shardstrategy
 
ModuleShardStrategy(String, Configuration) - Constructor for class org.opendaylight.controller.cluster.datastore.shardstrategy.ModuleShardStrategy
 
Monitor - Class in org.opendaylight.controller.cluster.common.actor
 
Monitor(ActorRef) - Constructor for class org.opendaylight.controller.cluster.common.actor.Monitor
 
MutableCompositeModification - Class in org.opendaylight.controller.cluster.datastore.modification
MutableCompositeModification is just a mutable version of a CompositeModification.
MutableCompositeModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
MutableCompositeModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 

N

name(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig.Builder
 
NAME - Static variable in class org.opendaylight.controller.cluster.datastore.shardstrategy.DefaultShardStrategy
 
NAME - Static variable in class org.opendaylight.controller.cluster.datastore.shardstrategy.ModuleShardStrategy
 
NAME - Static variable in class org.opendaylight.controller.cluster.datastore.shardstrategy.PrefixShardStrategy
 
nameSpace(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig.Builder
 
NamingThreadPoolFactory - Class in org.opendaylight.controller.config.threadpool.util
Implementation of ThreadFactory.
NamingThreadPoolFactory(String) - Constructor for class org.opendaylight.controller.config.threadpool.util.NamingThreadPoolFactory
 
nanosSinceLastActivity() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Returns the time since the last activity occurred for the follower.
Native - org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
 
navigate(String, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.NormalizedNodeNavigator
 
needsLeaderAddress(String) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
 
needsMigration() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardSnapshotState
 
needsMigration() - Method in interface org.opendaylight.controller.cluster.raft.persisted.Snapshot.State
Indicate whether the snapshot requires migration, i.e.
NEON_SR2 - org.opendaylight.controller.cluster.access.ABIVersion
Revised ABI version.
NEON_SR2 - org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Revised payload version.
NEON_SR2_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
 
newBuilder() - Static method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
newBuilder() - Static method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState
 
newBuilderFrom(DatastoreContext) - Static method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
newCaptureSnapshot(ReplicatedLogEntry, long, boolean) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
Constructs a CaptureSnapshot instance.
newContextFactory() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextIntrospector
 
newFailedFuture(Throwable) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
newInstance() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStreamFactory
Creates a new FileBackedOutputStream with the settings configured for this factory.
newInstance(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
newInstance(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
 
newInstance(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
 
newInstance(Long, Integer) - Static method in class org.opendaylight.controller.config.yang.netty.timer.HashedWheelTimerCloseable
 
newInstance(ThreadFactory, Long, Integer) - Static method in class org.opendaylight.controller.config.yang.netty.timer.HashedWheelTimerCloseable
 
newInstance(Integer) - Static method in class org.opendaylight.controller.config.yang.netty.threadgroup.NioEventLoopGroupCloseable
 
newInstance(String, boolean, int) - Static method in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
This is called via blueprint xml as the builder pattern can't be used.
newInstance(LogicalDatastoreType) - Method in interface org.opendaylight.controller.cluster.datastore.DatastoreContextIntrospectorFactory
 
newLeaderStateChanged(String, String, short) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
newLeaderStateChanged(String, String, short) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
newModification() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTree
 
newModification() - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
 
newOnDemandRaftStateBuilder() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
newOnDemandRaftStateBuilder() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
newProgressivePromise() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
newPromise() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
newRaftActorRecoverySupport() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
Creates a new read-only transaction.
newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
 
newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker
 
newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.datastore.DistributedDataStore
 
newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
Creates a new read-write transaction.
newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
 
newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker
 
newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.datastore.DistributedDataStore
 
newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
newShardStrategyInstance(String, String, Configuration) - Static method in class org.opendaylight.controller.cluster.datastore.shardstrategy.ShardStrategyFactory
 
newSharedInstance() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStreamFactory
Creates a new SharedFileBackedOutputStream with the settings configured for this factory.
newSucceededFuture(V) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
newSuccessEnvelope(RequestSuccess<?, ?>, long) - Method in class org.opendaylight.controller.cluster.access.concepts.RequestEnvelope
Creates a successful ResponseEnvelope that wraps the given successful Request response message.
newThread(Runnable) - Method in class org.opendaylight.controller.config.threadpool.util.NamingThreadPoolFactory
 
newTimeout(TimerTask, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.timer.HashedWheelTimerCloseable
 
newTimeout(TimerTask, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.timer.OSGiGlobalTimer
 
newTransactionIdentifier() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBroker
 
newTransactionIdentifier() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
Implementations must return unique identifier for each and every call of this method.
newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMTransactionFactory
Creates a new write-only transaction.
newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
 
newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker
 
newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.datastore.DistributedDataStore
 
newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
next() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
NioEventLoopGroupCloseable - Class in org.opendaylight.controller.config.yang.netty.threadgroup
 
no(short) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
NO_INDEX - Static variable in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
 
NO_LEADER - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
No leader exists to process the request.
NO_MAX_SIZE - Static variable in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
 
Node - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Describes the contents of a generic node - essentially an ID and a list of node-connectors.
Node - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes
A list of nodes (as defined by the 'grouping node').
Node1 - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
 
Node1 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
 
Node1Builder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Class that builds Node1Builder instances.
Node1Builder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
Class that builds Node1Builder instances.
Node1Builder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.Node1Builder
 
Node1Builder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Node1Builder
 
Node1Builder(Node1) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.Node1Builder
 
Node1Builder(Node1) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Node1Builder
 
NodeBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes
Class that builds NodeBuilder instances.
NodeBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
NodeBuilder(Node) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
NodeBuilder(Node) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
NodeConnector - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node
A list of node connectors that belong this node.
NodeConnector - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Describes a generic node connector which consists of an ID.
NodeConnectorBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node
Class that builds NodeConnectorBuilder instances.
NodeConnectorBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
NodeConnectorBuilder(NodeConnector) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
NodeConnectorBuilder(NodeConnector) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
NodeConnectorContext - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
A node-connector-context is a classifier for node-connector elements which allows an RPC to provide a service on behalf of a particular element in the tree.
NodeConnectorId - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
 
NodeConnectorId(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorId
 
NodeConnectorId(Uri) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorId
Creates a new instance from Uri
NodeConnectorId(NodeConnectorId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorId
Creates a copy from Source Object.
NodeConnectorKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node
 
NodeConnectorKey(NodeConnectorKey) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorKey
Creates a copy from Source Object.
NodeConnectorKey(NodeConnectorId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorKey
 
NodeConnectorRef - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
 
NodeConnectorRef(NodeConnectorRef) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRef
Creates a copy from Source Object.
NodeConnectorRef(InstanceIdentifier<?>) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRef
 
NodeConnectorRemoved - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Deprecated.
NodeConnectorRemovedBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Class that builds NodeConnectorRemovedBuilder instances.
NodeConnectorRemovedBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
 
NodeConnectorRemovedBuilder(NodeConnectorRemoved) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
 
NodeConnectorType - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
A base identity definition which represents a generic node connector type and can be extended in other YANG files.
NodeConnectorUpdated - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Deprecated.
NodeConnectorUpdatedBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Class that builds NodeConnectorUpdatedBuilder instances.
NodeConnectorUpdatedBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
NodeConnectorUpdatedBuilder(NodeConnector) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
NodeConnectorUpdatedBuilder(NodeConnectorUpdated) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
NodeContext - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
A node-context is a classifier for node elements which allows an RPC to provide a service on behalf of a particular element in the data tree.
NodeContextRef - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
A helper grouping which contains a reference to a node classified with a node-context.
NodeId - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
 
NodeId(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId
 
NodeId(Uri) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId
Creates a new instance from Uri
NodeId(NodeId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId
Creates a copy from Source Object.
NodeIdentifier - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers
This class represents the following YANG schema fragment defined in module opendaylight-topology
NodeIdentifierBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers
Class that builds NodeIdentifierBuilder instances.
NodeIdentifierBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
NodeIdentifierBuilder(NodeIdentifier) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
NodeIdentifierKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers
 
NodeIdentifierKey(Uri, Class<? extends NodeType>) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierKey
 
NodeIdentifierKey(NodeIdentifierKey) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierKey
Creates a copy from Source Object.
NodeIdentifiers - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
This class represents the following YANG schema fragment defined in module opendaylight-topology
NodeKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes
 
NodeKey(NodeId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey
 
NodeKey(NodeKey) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey
Creates a copy from Source Object.
NodeRef - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
 
NodeRef(NodeRef) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef
Creates a copy from Source Object.
NodeRef(InstanceIdentifier<?>) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef
 
NodeRemoved - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Deprecated.
NodeRemovedBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Class that builds NodeRemovedBuilder instances.
NodeRemovedBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
 
NodeRemovedBuilder(NodeRemoved) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
 
Nodes - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
The root container of all nodes.
NodesBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Class that builds NodesBuilder instances.
NodesBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
 
NodesBuilder(Nodes) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
 
NodeType - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
A base identity definition which represents a generic node type and can be extended in other yang files.
NodeType - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
This class represents the following YANG schema fragment defined in module opendaylight-topology
NodeUpdated - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Deprecated.
NodeUpdatedBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Class that builds NodeUpdatedBuilder instances.
NodeUpdatedBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
NodeUpdatedBuilder(Node) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
NodeUpdatedBuilder(NodeUpdated) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
NON_PERSISTENT_JOURNAL_ID - Static variable in class org.opendaylight.controller.cluster.datastore.Shard
 
NON_VOTING - org.opendaylight.controller.cluster.raft.VotingState
 
nonnullKnownClients() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1
 
nonnullMemberVotingState() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MemberVotingStatesInput
 
nonnullNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Nodes
 
nonnullNodeConnector() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Node
 
nonnullNodeIdentifier() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.NodeIdentifiers
 
nonnullOriginalNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregateNode
 
nonnullShard() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShards
 
nonnullShardResult() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardResultOutput
 
NonPersistentDataProvider - Class in org.opendaylight.controller.cluster
A DataPersistenceProvider implementation with persistence disabled, essentially a no-op.
NonPersistentDataProvider(ExecuteInSelfActor) - Constructor for class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
NonZeroUint32Type - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
 
NonZeroUint32Type(Long) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link NonZeroUint32Type(Uint32)} instead.
NonZeroUint32Type(NonZeroUint32Type) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
Creates a copy from Source Object.
NonZeroUint32Type(Uint32) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
 
NoopAutoCloseable - Class in org.opendaylight.controller.sal.common.util
An AutoCloseable that does nothing.
NoopPayload - Class in org.opendaylight.controller.cluster.raft.persisted
Payload used for no-op log entries that are put into the journal by the PreLeader in order to commit entries from the prior term.
NoopPeerAddressResolver - Class in org.opendaylight.controller.cluster.raft
Implementation of PeerAddressResolver that does nothing.
NoopProcedure<T> - Class in org.opendaylight.controller.cluster.raft
An akka Procedure that does nothing.
NoopRaftActorSnapshotCohort - Class in org.opendaylight.controller.cluster.raft
RaftActorSnapshotCohort implementation that does nothing.
NormalizedNodeAggregator - Class in org.opendaylight.controller.cluster.datastore.utils
 
NormalizedNodeNavigator - Class in org.opendaylight.controller.cluster.datastore.node.utils
NormalizedNodeNavigator walks a NormalizedNodeVisitor through the NormalizedNode.
NormalizedNodeNavigator(NormalizedNodeVisitor) - Constructor for class org.opendaylight.controller.cluster.datastore.node.utils.NormalizedNodeNavigator
 
NormalizedNodeVisitor - Interface in org.opendaylight.controller.cluster.datastore.node.utils
 
NormalizedNodeXMLOutput - Class in org.opendaylight.controller.cluster.datastore.utils
Utility class to output NormalizedNodes as XML.
NoShardLeaderException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
Exception indicating a shard has no current leader.
NoShardLeaderException(String) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.NoShardLeaderException
 
NoShardLeaderException(String, String) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.NoShardLeaderException
 
NoShardLeaderException(ShardIdentifier) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.NoShardLeaderException
 
NOT_SUPPORTED - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
An unsupported request, for example removing the leader in a single node cluster.
Notification - org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
 
NOTIFICATION_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
NotificationPattern - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
 
NotificationPattern(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.NotificationPattern
 
NotificationPattern(NotificationPattern) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.NotificationPattern
Creates a copy from Source Object.
NotificationPattern(Pattern) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.NotificationPattern
Creates a new instance from Pattern
notifyListeners(DataTreeCandidate) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTree
 
notifyNode(InstanceIdentifier<?>) - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopic
 
notifyOnCompleteTasks(Throwable, T) - Method in class org.opendaylight.controller.cluster.datastore.utils.CompositeOnComplete
 
NotifyProducerCreated - Class in org.opendaylight.controller.cluster.sharding.messages
Message sent to remote ShardedDataTreeActor's when attempting to create a producer.
NotifyProducerCreated(Collection<DOMDataTreeIdentifier>) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.NotifyProducerCreated
 
NotifyProducerRemoved - Class in org.opendaylight.controller.cluster.sharding.messages
Message sent to remote ShardedDataTreeActor's when attempting to close a producer.
NotifyProducerRemoved(Collection<DOMDataTreeIdentifier>) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.NotifyProducerRemoved
 
notifyWhenBackendInfoIsStale(Consumer<Long>) - Method in class org.opendaylight.controller.cluster.access.client.BackendInfoResolver
Registers a callback to be notified when BackendInfo that may have been previously obtained is now stale and should be refreshed.
NotInitializedException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
 
NotInitializedException(String) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.NotInitializedException
 
NotLeaderException - Exception in org.opendaylight.controller.cluster.access.commands
General error raised when the recipient of a Request is not the correct backend to talk to.
NotLeaderException(ActorRef) - Constructor for exception org.opendaylight.controller.cluster.access.commands.NotLeaderException
 
NotSupported - org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
 

O

OK - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
Request successfully completed.
okToReplicate(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
This method checks if the next replicate message can be sent to the follower.
onBucketRemoved(Address, Bucket<ActionRoutingTable>) - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry
 
onBucketRemoved(Address, Bucket<RoutingTable>) - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry
 
onBucketRemoved(Address, Bucket<T>) - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
Callback to subclasses invoked when a bucket is removed.
onBucketsUpdated(Map<Address, Bucket<ActionRoutingTable>>) - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry
 
onBucketsUpdated(Map<Address, Bucket<RoutingTable>>) - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry
 
onBucketsUpdated(Map<Address, Bucket<T>>) - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
Callback to subclasses invoked when the set of remote buckets is updated.
onCommand(Object) - Method in class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
Override this method to handle any command which is not handled by the base behavior.
onDatastoreContext(DatastoreContext) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
onDatastoreContextUpdated(DatastoreContextFactory) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
onDatastoreContextUpdated(DatastoreContextFactory) - Method in interface org.opendaylight.controller.cluster.datastore.DatastoreContextPropertiesUpdater.Listener
 
onDataTreeChanged(Collection<DataTreeModification<Node>>) - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopic
 
onDataTreeChanged(Collection<DataTreeCandidate>) - Method in class org.opendaylight.controller.cluster.sharding.PrefixedShardConfigUpdateHandler.ShardConfigHandler
 
OnDemandRaftState - Class in org.opendaylight.controller.cluster.raft.client.messages
The response to a GetOnDemandRaftState message.
OnDemandRaftState() - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState
 
OnDemandRaftState.AbstractBuilder<B extends OnDemandRaftState.AbstractBuilder<B,​T>,​T extends OnDemandRaftState> - Class in org.opendaylight.controller.cluster.raft.client.messages
 
OnDemandRaftState.Builder - Class in org.opendaylight.controller.cluster.raft.client.messages
 
OnDemandShardState - Class in org.opendaylight.controller.cluster.datastore.messages
Extends OnDemandRaftState to add Shard state.
OnDemandShardState() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState
 
OnDemandShardState.Builder - Class in org.opendaylight.controller.cluster.datastore.messages
 
onEventSourceStatusNotification(EventSourceStatusNotification) - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceListener
Notification of change event source status.
onFailure() - Method in interface org.opendaylight.controller.cluster.raft.base.messages.ApplySnapshot.Callback
 
onFailureCallback(Consumer<Throwable>) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Sets the callback to be notified of failure.
OnInitialData - Class in org.opendaylight.controller.cluster.datastore.messages
Message sent to a data tree change listener actor to indicate there is no initial data.
onLeaderChanged(String, String) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
onLeaderChanged(String, String) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
onLeaderLocationChanged(LeaderLocation) - Method in interface org.opendaylight.controller.cluster.dom.api.LeaderLocationListener
Invoked when shard leader location changes.
onModelContextUpdated(EffectiveModelContext) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
onNewActorSystem(ActorSystem) - Method in interface org.opendaylight.controller.cluster.ActorSystemProviderListener
Method called when the current actor system is shutdown and a new actor system is created.
onNodeConnectorRemoved(NodeConnectorRemoved) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.OpendaylightInventoryListener
A notification sent by someone who realized there was a node-connector was removed, but did not modify the data tree.
onNodeConnectorUpdated(NodeConnectorUpdated) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.OpendaylightInventoryListener
A notification sent by someone who realized there was a modification to a node-connector, but did not modify the data tree.
onNodeRemoved(NodeRemoved) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.OpendaylightInventoryListener
A notification sent by someone who realized there was a node was removed, but did not modify the data tree.
onNodeUpdated(NodeUpdated) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.OpendaylightInventoryListener
A notification sent by someone who realized there was a modification to a node, but did not modify the data tree.
onPreShutdownActorSystem() - Method in interface org.opendaylight.controller.cluster.ActorSystemProviderListener
Method called when the current actor system is about to be shutdown.
onReceive(Object) - Method in class org.opendaylight.controller.cluster.common.actor.QuarantinedMonitorActor
 
onReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.TerminationMonitor
 
onReceive(Object) - Method in class org.opendaylight.controller.remote.rpc.TerminationMonitor
 
onRecoveryComplete() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
onRecoveryComplete() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
This method is called when recovery is complete.
onStateChanged() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
onStateChanged() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
This method will be called by the RaftActor when the state of the RaftActor changes.
onSuccess() - Method in interface org.opendaylight.controller.cluster.raft.base.messages.ApplySnapshot.Callback
 
onTopicNotification(TopicNotification) - Method in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.EventAggregatorListener
Notification of an event occuring on a particular node.
onVotingStateChangeComplete() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
This method is called on the leader when a voting change operation completes.
openCursor() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
 
OpendaylightInventoryData - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
This class represents the following YANG schema fragment defined in module opendaylight-inventory
OpendaylightInventoryListener - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
Interface for implementing the following YANG notifications defined in module opendaylight-inventory
Operational - org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
 
OperationLimiter - Class in org.opendaylight.controller.cluster.datastore
Class for limiting operations.
operationTimeoutInMillis(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
operationTimeoutInSeconds(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
OperationTimeoutType - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
 
OperationTimeoutType(Integer) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link OperationTimeoutType(Uint16)} instead.
OperationTimeoutType(OperationTimeoutType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
Creates a copy from Source Object.
OperationTimeoutType(Uint16) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
 
OpsManager - Class in org.opendaylight.controller.remote.rpc
This class acts as a supervisor, creates all the actors, resumes them, if an exception is thrown.
optimisticRead() - Method in class org.opendaylight.controller.cluster.access.client.InversibleLock
Return a stamp for read validation.
org.opendaylight.controller.cluster - package org.opendaylight.controller.cluster
 
org.opendaylight.controller.cluster.access - package org.opendaylight.controller.cluster.access
This package contains the base definitions of the APIs exposed by the clustered data store backend.
org.opendaylight.controller.cluster.access.client - package org.opendaylight.controller.cluster.access.client
This package contains the baseline client infrastructure required to implement clients accessing the data store.
org.opendaylight.controller.cluster.access.commands - package org.opendaylight.controller.cluster.access.commands
This package defines the messages used to interact with the CDS backend implementation.
org.opendaylight.controller.cluster.access.concepts - package org.opendaylight.controller.cluster.access.concepts
This package defines basic concepts used to interact with the CDS backend implementation.
org.opendaylight.controller.cluster.akka.impl - package org.opendaylight.controller.cluster.akka.impl
 
org.opendaylight.controller.cluster.akka.osgi.impl - package org.opendaylight.controller.cluster.akka.osgi.impl
 
org.opendaylight.controller.cluster.common.actor - package org.opendaylight.controller.cluster.common.actor
 
org.opendaylight.controller.cluster.databroker - package org.opendaylight.controller.cluster.databroker
 
org.opendaylight.controller.cluster.databroker.actors.dds - package org.opendaylight.controller.cluster.databroker.actors.dds
This package contains implementation required by the DistributedDataStore frontend.
org.opendaylight.controller.cluster.datastore - package org.opendaylight.controller.cluster.datastore
 
org.opendaylight.controller.cluster.datastore.actors - package org.opendaylight.controller.cluster.datastore.actors
 
org.opendaylight.controller.cluster.datastore.admin - package org.opendaylight.controller.cluster.datastore.admin
 
org.opendaylight.controller.cluster.datastore.config - package org.opendaylight.controller.cluster.datastore.config
 
org.opendaylight.controller.cluster.datastore.exceptions - package org.opendaylight.controller.cluster.datastore.exceptions
 
org.opendaylight.controller.cluster.datastore.identifiers - package org.opendaylight.controller.cluster.datastore.identifiers
 
org.opendaylight.controller.cluster.datastore.jmx.mbeans - package org.opendaylight.controller.cluster.datastore.jmx.mbeans
 
org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard - package org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard
 
org.opendaylight.controller.cluster.datastore.messages - package org.opendaylight.controller.cluster.datastore.messages
 
org.opendaylight.controller.cluster.datastore.modification - package org.opendaylight.controller.cluster.datastore.modification
 
org.opendaylight.controller.cluster.datastore.node.utils - package org.opendaylight.controller.cluster.datastore.node.utils
 
org.opendaylight.controller.cluster.datastore.node.utils.stream - package org.opendaylight.controller.cluster.datastore.node.utils.stream
 
org.opendaylight.controller.cluster.datastore.node.utils.transformer - package org.opendaylight.controller.cluster.datastore.node.utils.transformer
 
org.opendaylight.controller.cluster.datastore.persisted - package org.opendaylight.controller.cluster.datastore.persisted
Persisted backend structures.
org.opendaylight.controller.cluster.datastore.policy - package org.opendaylight.controller.cluster.datastore.policy
 
org.opendaylight.controller.cluster.datastore.shardmanager - package org.opendaylight.controller.cluster.datastore.shardmanager
 
org.opendaylight.controller.cluster.datastore.shardstrategy - package org.opendaylight.controller.cluster.datastore.shardstrategy
 
org.opendaylight.controller.cluster.datastore.util - package org.opendaylight.controller.cluster.datastore.util
 
org.opendaylight.controller.cluster.datastore.utils - package org.opendaylight.controller.cluster.datastore.utils
 
org.opendaylight.controller.cluster.dom.api - package org.opendaylight.controller.cluster.dom.api
This package defines extensions to org.opendaylight.mdsal.dom.api specific to Clustered Datastore implementation.
org.opendaylight.controller.cluster.io - package org.opendaylight.controller.cluster.io
 
org.opendaylight.controller.cluster.messaging - package org.opendaylight.controller.cluster.messaging
 
org.opendaylight.controller.cluster.notifications - package org.opendaylight.controller.cluster.notifications
 
org.opendaylight.controller.cluster.persistence - package org.opendaylight.controller.cluster.persistence
 
org.opendaylight.controller.cluster.raft - package org.opendaylight.controller.cluster.raft
 
org.opendaylight.controller.cluster.raft.base.messages - package org.opendaylight.controller.cluster.raft.base.messages
 
org.opendaylight.controller.cluster.raft.behaviors - package org.opendaylight.controller.cluster.raft.behaviors
 
org.opendaylight.controller.cluster.raft.client.messages - package org.opendaylight.controller.cluster.raft.client.messages
 
org.opendaylight.controller.cluster.raft.messages - package org.opendaylight.controller.cluster.raft.messages
 
org.opendaylight.controller.cluster.raft.persisted - package org.opendaylight.controller.cluster.raft.persisted
 
org.opendaylight.controller.cluster.raft.policy - package org.opendaylight.controller.cluster.raft.policy
 
org.opendaylight.controller.cluster.raft.protobuff.client.messages - package org.opendaylight.controller.cluster.raft.protobuff.client.messages
 
org.opendaylight.controller.cluster.reporting - package org.opendaylight.controller.cluster.reporting
 
org.opendaylight.controller.cluster.schema.provider - package org.opendaylight.controller.cluster.schema.provider
 
org.opendaylight.controller.cluster.schema.provider.impl - package org.opendaylight.controller.cluster.schema.provider.impl
 
org.opendaylight.controller.cluster.sharding - package org.opendaylight.controller.cluster.sharding
 
org.opendaylight.controller.cluster.sharding.messages - package org.opendaylight.controller.cluster.sharding.messages
 
org.opendaylight.controller.config.threadpool - package org.opendaylight.controller.config.threadpool
 
org.opendaylight.controller.config.threadpool.util - package org.opendaylight.controller.config.threadpool.util
 
org.opendaylight.controller.config.yang.netty.eventexecutor - package org.opendaylight.controller.config.yang.netty.eventexecutor
 
org.opendaylight.controller.config.yang.netty.threadgroup - package org.opendaylight.controller.config.yang.netty.threadgroup
 
org.opendaylight.controller.config.yang.netty.timer - package org.opendaylight.controller.config.yang.netty.timer
 
org.opendaylight.controller.md.sal.common.util.jmx - package org.opendaylight.controller.md.sal.common.util.jmx
 
org.opendaylight.controller.messagebus.app.impl - package org.opendaylight.controller.messagebus.app.impl
 
org.opendaylight.controller.messagebus.app.util - package org.opendaylight.controller.messagebus.app.util
 
org.opendaylight.controller.messagebus.spi - package org.opendaylight.controller.messagebus.spi
 
org.opendaylight.controller.remote.rpc - package org.opendaylight.controller.remote.rpc
 
org.opendaylight.controller.remote.rpc.messages - package org.opendaylight.controller.remote.rpc.messages
 
org.opendaylight.controller.remote.rpc.registry - package org.opendaylight.controller.remote.rpc.registry
 
org.opendaylight.controller.remote.rpc.registry.gossip - package org.opendaylight.controller.remote.rpc.registry.gossip
 
org.opendaylight.controller.remote.rpc.registry.mbeans - package org.opendaylight.controller.remote.rpc.registry.mbeans
 
org.opendaylight.controller.sal.common.util - package org.opendaylight.controller.sal.common.util
 
org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202 - package org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
 
org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.topic.notification - package org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.topic.notification
 
org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202 - package org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
 
org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type - package org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type
 
org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819 - package org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
 
org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node - package org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node
 
org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes - package org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes
 
org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030 - package org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
 
org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers - package org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers
 
org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030 - package org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030
 
org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030 - package org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030
 
org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node - package org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024 - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612 - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013 - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110 - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards
 
org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard
 
OriginalNode - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node
This class represents the following YANG schema fragment defined in module opendaylight-topology-view
OriginalNodeBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node
Class that builds OriginalNodeBuilder instances.
OriginalNodeBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
OriginalNodeBuilder(OriginalNode) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
OSGiActorSystemProvider - Class in org.opendaylight.controller.cluster.akka.osgi.impl
 
OSGiActorSystemProvider() - Constructor for class org.opendaylight.controller.cluster.akka.osgi.impl.OSGiActorSystemProvider
 
OSGiClusterAdmin - Class in org.opendaylight.controller.cluster.datastore.admin
 
OSGiClusterAdmin() - Constructor for class org.opendaylight.controller.cluster.datastore.admin.OSGiClusterAdmin
 
OSGiDatastoreContextIntrospectorFactory - Class in org.opendaylight.controller.cluster.datastore
 
OSGiDatastoreContextIntrospectorFactory() - Constructor for class org.opendaylight.controller.cluster.datastore.OSGiDatastoreContextIntrospectorFactory
 
OSGiDistributedDataStore - Class in org.opendaylight.controller.cluster.datastore
Global bootstrap component.
OSGiDistributedDataStore() - Constructor for class org.opendaylight.controller.cluster.datastore.OSGiDistributedDataStore
 
OSGiDistributedShardedDOMDataTree - Class in org.opendaylight.controller.cluster.sharding
 
OSGiDistributedShardedDOMDataTree() - Constructor for class org.opendaylight.controller.cluster.sharding.OSGiDistributedShardedDOMDataTree
 
OSGiDOMDataBroker - Class in org.opendaylight.controller.cluster.databroker
 
OSGiDOMDataBroker() - Constructor for class org.opendaylight.controller.cluster.databroker.OSGiDOMDataBroker
 
OSGiDOMDataBroker.Config - Annotation Type in org.opendaylight.controller.cluster.databroker
 
OSGiDOMStore - Class in org.opendaylight.controller.cluster.datastore
OSGi manifestation of a the distributed datastore, as represented by AbstractDataStore.
OSGiDOMStore() - Constructor for class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
OSGiEventSourceRegistry - Class in org.opendaylight.controller.messagebus.app.impl
 
OSGiEventSourceRegistry() - Constructor for class org.opendaylight.controller.messagebus.app.impl.OSGiEventSourceRegistry
 
OSGiGlobalEventExecutor - Class in org.opendaylight.controller.config.yang.netty.eventexecutor
 
OSGiGlobalEventExecutor() - Constructor for class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
OSGiGlobalTimer - Class in org.opendaylight.controller.config.yang.netty.timer
 
OSGiGlobalTimer() - Constructor for class org.opendaylight.controller.config.yang.netty.timer.OSGiGlobalTimer
 
OSGiGlobalTimer.Config - Annotation Type in org.opendaylight.controller.config.yang.netty.timer
 
OSGiRemoteOpsProvider - Class in org.opendaylight.controller.remote.rpc
 
OSGiRemoteOpsProvider() - Constructor for class org.opendaylight.controller.remote.rpc.OSGiRemoteOpsProvider
 
OSGiRemoteOpsProvider.Config - Annotation Type in org.opendaylight.controller.remote.rpc
 
OutOfOrderRequestException - Exception in org.opendaylight.controller.cluster.access.commands
A RequestException indicating that the backend has received a Request whose sequence does not match the next expected sequence for the target.
OutOfOrderRequestException(long) - Constructor for exception org.opendaylight.controller.cluster.access.commands.OutOfOrderRequestException
 
OutOfSequenceEnvelopeException - Exception in org.opendaylight.controller.cluster.access.commands
A RequestException indicating that the backend has received a RequestEnvelope whose sequence does not match the next expected sequence.
OutOfSequenceEnvelopeException(long) - Constructor for exception org.opendaylight.controller.cluster.access.commands.OutOfSequenceEnvelopeException
 

P

parent() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
PastVersionException - Exception in org.opendaylight.controller.cluster.access
Exception thrown from ABIVersion.valueOf(short) when the specified version is too old and no longer supported by the codebase.
PastVersionException - Exception in org.opendaylight.controller.cluster.datastore.persisted
Exception thrown from PayloadVersion.valueOf(short) when the specified version is too old and no longer supported by the codebase.
Pattern - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
 
Pattern(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.Pattern
 
Pattern(Pattern) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.Pattern
Creates a copy from Source Object.
PATTERN_CONSTANTS - Static variable in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
 
pause() - Method in class org.opendaylight.controller.cluster.datastore.TransactionRateLimitingCallback
 
pauseLeader(Runnable) - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
pauseLeader(Runnable) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
This method is called prior to operations such as leadership transfer and actor shutdown when the leader must pause or stop its duties.
Payload - Class in org.opendaylight.controller.cluster.raft.protobuff.client.messages
An instance of a Payload class is meant to be used as the Payload for AppendEntries.
Payload - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.topic.notification
Encapsulated notification.
Payload() - Constructor for class org.opendaylight.controller.cluster.raft.protobuff.client.messages.Payload
 
PayloadVersion - Enum in org.opendaylight.controller.cluster.datastore.persisted
Enumeration of all ABI versions supported by this implementation of persistence.
peerAddresses(Map<String, String>) - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
peerAddresses(Map<String, String>) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
PeerAddressResolved - Class in org.opendaylight.controller.cluster.datastore.messages
 
PeerAddressResolved(String, String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.PeerAddressResolved
 
PeerAddressResolver - Interface in org.opendaylight.controller.cluster.raft
Interface to resolve raft actor peer addresses.
PeerDown - Class in org.opendaylight.controller.cluster.datastore.messages
Message sent to a shard actor indicating one of its peers is down.
PeerDown(MemberName, String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.PeerDown
 
PeerInfo - Class in org.opendaylight.controller.cluster.raft
Stores information about a raft peer.
PeerInfo(String, String, VotingState) - Constructor for class org.opendaylight.controller.cluster.raft.PeerInfo
Constructs an instance.
PeerUp - Class in org.opendaylight.controller.cluster.datastore.messages
Message sent to a shard actor indicating one of its peers is up.
PeerUp(MemberName, String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.PeerUp
 
peerVotingStates(Map<String, Boolean>) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
Percentage - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612
 
Percentage(Short) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link Percentage(Uint8)} instead.
Percentage(Percentage) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
Creates a copy from Source Object.
Percentage(Uint8) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
 
performSnapshotWithoutCapture(long) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Performs a snapshot with no capture on the replicated log.
persist(Snapshot.State, Optional<OutputStream>, long) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
persist(Snapshot.State, Optional<OutputStream>, long) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Persists a snapshot.
persist(T, Procedure<T>) - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
Persists an entry to the applicable journal synchronously.
persist(T, Procedure<T>) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
persist(T, Procedure<T>) - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
persist(T, Procedure<T>) - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
 
persistAsync(T, Procedure<T>) - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
Persists an entry to the applicable journal asynchronously.
persistAsync(T, Procedure<T>) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
persistAsync(T, Procedure<T>) - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
persistAsync(T, Procedure<T>) - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
 
persistData(ActorRef, Identifier, Payload, boolean) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
Persists the given Payload in the journal and replicates to any followers.
persistence() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
persistenceId() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActor
 
persistenceId() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActorBehavior
Return the persistence identifier associated with this AbstractClientActor.
persistenceId() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
persistenceId() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor
 
persistenceId() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
PersistenceProtocol - Enum in org.opendaylight.controller.cluster.access.commands
Enumeration of transaction persistence protocols.
persistent(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
PersistentDataProvider - Class in org.opendaylight.controller.cluster
A DataPersistenceProvider implementation with persistence enabled.
PersistentDataProvider(AbstractPersistentActor) - Constructor for class org.opendaylight.controller.cluster.PersistentDataProvider
 
PersistentPayload - Interface in org.opendaylight.controller.cluster.raft.protobuff.client.messages
This is a tagging interface for a Payload implementation that needs to always be persisted regardless of whether or not the component is configured to be persistent.
postStop() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActor
 
postStop() - Method in class org.opendaylight.controller.cluster.common.actor.QuarantinedMonitorActor
 
postStop() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
postStop() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
postStop() - Method in class org.opendaylight.controller.remote.rpc.OpsManager
 
postStop() - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry
 
postStop() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.Gossiper
 
postStop() - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry
 
PRE_COMMIT_COMPLETE - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
PRE_COMMIT_PENDING - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
preCommit() - Method in class org.opendaylight.controller.cluster.datastore.ThreePhaseCommitCohortProxy
 
preCommit(FutureCallback<DataTreeCandidate>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
 
PREFIX_CONFIG_SHARD_ID - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
PREFIX_SHARDS_PATH - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
PREFIX_SHARDS_QNAME - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
PrefixedShardConfigUpdateHandler - Class in org.opendaylight.controller.cluster.sharding
Listens on changes on prefix-shard-configuration.
PrefixedShardConfigUpdateHandler(ActorRef, MemberName) - Constructor for class org.opendaylight.controller.cluster.sharding.PrefixedShardConfigUpdateHandler
 
PrefixedShardConfigUpdateHandler.ShardConfigHandler - Class in org.opendaylight.controller.cluster.sharding
 
PrefixShardConfiguration - Class in org.opendaylight.controller.cluster.datastore.config
Configuration for prefix based shards.
PrefixShardConfiguration(DOMDataTreeIdentifier, String, Collection<MemberName>) - Constructor for class org.opendaylight.controller.cluster.datastore.config.PrefixShardConfiguration
 
PrefixShardConfigurationData - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110
This module contains the base YANG definitions for shards based on prefix configuration
PrefixShardCreated - Class in org.opendaylight.controller.cluster.sharding.messages
Message sent to the local ShardedDataTreeActor when a clustered shard was created locally.
PrefixShardCreated(PrefixShardConfiguration) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.PrefixShardCreated
 
PrefixShardRemovalLookup - Class in org.opendaylight.controller.cluster.sharding.messages
Sent to the local ShardedDataTreeActor to initiate the lookup of the shard, once the shard is removed from the system entirely the actor responds with a success.
PrefixShardRemovalLookup(DOMDataTreeIdentifier) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.PrefixShardRemovalLookup
 
PrefixShardRemoved - Class in org.opendaylight.controller.cluster.sharding.messages
Message sent to remote ShardedDataTreeActor's when there is an attempt to remove the shard, the ShardedDataTreeActor should remove the shard from the current configuration so that the change is picked up in the backend ShardManager.
PrefixShardRemoved(DOMDataTreeIdentifier) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.PrefixShardRemoved
 
PrefixShards - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110
This class represents the following YANG schema fragment defined in module prefix-shard-configuration
PrefixShardsBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110
Class that builds PrefixShardsBuilder instances.
PrefixShardsBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
 
PrefixShardsBuilder(PrefixShards) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
 
PrefixShardStrategy - Class in org.opendaylight.controller.cluster.datastore.shardstrategy
Shard Strategy that resolves a path to a prefix shard name.
PrefixShardStrategy(String, YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.shardstrategy.PrefixShardStrategy
 
PreLeader - Class in org.opendaylight.controller.cluster.raft.behaviors
The behavior of a RaftActor when it is in the PreLeader state.
PreLeader - org.opendaylight.controller.cluster.raft.RaftState
 
PreLeader(RaftActorContext) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.PreLeader
 
preStart() - Method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotifier
 
preStart() - Method in class org.opendaylight.controller.cluster.persistence.LocalSnapshotStore
 
preStart() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
preStart() - Method in class org.opendaylight.controller.cluster.sharding.RoleChangeListenerActor
 
preStart() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor
 
preStart() - Method in class org.opendaylight.controller.remote.rpc.OpsManager
 
preStart() - Method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry
 
preStart() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
preStart() - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.Gossiper
 
preStart() - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry
 
prestartAllCoreThreads() - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
PrimaryNotFoundException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
 
PrimaryNotFoundException(String) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.PrimaryNotFoundException
 
PrimaryShardInfo - Class in org.opendaylight.controller.cluster.datastore.messages
Local message DTO that contains information about the primary shard.
PrimaryShardInfo(ActorSelection, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.PrimaryShardInfo
 
PrimaryShardInfo(ActorSelection, short, ReadOnlyDataTree) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.PrimaryShardInfo
 
primaryShardInfoCache(PrimaryShardInfoFutureCache) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
PrimaryShardInfoFutureCache - Class in org.opendaylight.controller.cluster.datastore.utils
Maintains a cache of PrimaryShardInfo Future instances per shard.
PrimaryShardInfoFutureCache() - Constructor for class org.opendaylight.controller.cluster.datastore.utils.PrimaryShardInfoFutureCache
 
printFollowerStates() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
PRIOR_REQUEST_CONSENSUS_TIMEOUT - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
The leader could not process the request due to a prior request that timed out while trying to achieve replication consensus.
Proactive(DataTreeModification, DataTree, ReusableNormalizedNodePruner) - Constructor for class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification.Proactive
 
processResponse(Object, SettableFuture<Boolean>) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
 
processResponse(Object, SettableFuture<Optional<NormalizedNode<?, ?>>>) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
 
processResponse(Object, SettableFuture<T>) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
ProducerCreated - Class in org.opendaylight.controller.cluster.sharding.messages
Message sent to local ShardedDataTreeActor's when there was an attempt to create a producer on the local node.
ProducerCreated(Collection<DOMDataTreeIdentifier>) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.ProducerCreated
 
ProducerRemoved - Class in org.opendaylight.controller.cluster.sharding.messages
Message sent to local ShardedDataTreeActor's when there was an attempt to close a producer on the local node.
ProducerRemoved(Collection<DOMDataTreeIdentifier>) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.ProducerRemoved
 
props() - Static method in class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor
 
props() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
props() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
props() - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
props(MemberName, String, ActorUtils) - Static method in class org.opendaylight.controller.cluster.databroker.actors.dds.DistributedDataStoreClientActor
 
props(MemberName, String, ActorUtils, String) - Static method in class org.opendaylight.controller.cluster.databroker.actors.dds.SimpleDataStoreClientActor
 
props(ActorRef, LeaderLocationListener) - Static method in class org.opendaylight.controller.cluster.sharding.RoleChangeListenerActor
 
props(Effect) - Static method in class org.opendaylight.controller.cluster.common.actor.QuarantinedMonitorActor
 
props(TransactionType, AbstractShardDataTreeTransaction<?>, ActorRef, DatastoreContext, ShardStats) - Static method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
props(InputOutputStreamFactory) - Static method in class org.opendaylight.controller.cluster.datastore.actors.ShardSnapshotActor
 
props(RemoteOpsProviderConfig) - Static method in class org.opendaylight.controller.remote.rpc.registry.gossip.Gossiper
 
props(RemoteOpsProviderConfig, ActorRef, ActorRef) - Static method in class org.opendaylight.controller.remote.rpc.registry.ActionRegistry
Create a new props instance for instantiating an ActionRegistry actor.
props(RemoteOpsProviderConfig, ActorRef, ActorRef) - Static method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry
Create a new props instance for instantiating an RpcRegistry actor.
props(DOMRpcProviderService, DOMRpcService, RemoteOpsProviderConfig, DOMActionProviderService, DOMActionService) - Static method in class org.opendaylight.controller.remote.rpc.OpsManager
 
PruningDataTreeModification - Class in org.opendaylight.controller.cluster.datastore.utils
The PruningDataTreeModification first removes all entries from the data which do not belong in the schemaContext before delegating it to the actual DataTreeModification.
PruningDataTreeModification.Proactive - Class in org.opendaylight.controller.cluster.datastore.utils
A PruningDataTreeModification which always performs pruning before attempting an operation.
PruningDataTreeModification.Reactive - Class in org.opendaylight.controller.cluster.datastore.utils
A PruningDataTreeModification which performs pruning only when an operation results in an SchemaValidationFailedException.
publisher() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeNotificationPublisherActor
 
PurgeLocalHistoryPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
Payload persisted when a local history is completely purged, i.e.
PurgeLocalHistoryRequest - Class in org.opendaylight.controller.cluster.access.commands
Request to purge a local history.
PurgeLocalHistoryRequest(LocalHistoryIdentifier, long, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.PurgeLocalHistoryRequest
 
PurgeTransactionPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
Payload persisted when a transaction is purged from the frontend.
put(LogicalDatastoreType, YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerWriteTransaction
 
putSuccessful(String, PrimaryShardInfo) - Method in class org.opendaylight.controller.cluster.datastore.utils.PrimaryShardInfoFutureCache
 

Q

QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.topic.notification.Payload
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotification
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotification
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSource
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyEventSourceType
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnector
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Node
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnector
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorContext
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemoved
Deprecated.
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorType
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdated
Deprecated.
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeContext
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeContextRef
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemoved
Deprecated.
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.Node
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Nodes
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeType
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdated
Deprecated.
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifier
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.NodeIdentifiers
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.NodeType
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.TopologyContext
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.TopologyNodeContext
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNode
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregateNode
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregateTopology
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientIdentifier
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendIdentifier
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStoreProperties
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainer
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClients
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRef
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.Local
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.MemberNode
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingState
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MemberVotingStatesInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResult
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardResultOutput
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.Shard
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.Replicas
 
QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShards
 
QuarantinedMonitorActor - Class in org.opendaylight.controller.cluster.common.actor
This class listens to Akka RemotingLifecycleEvent events to detect when this node has been quarantined by another.
QuarantinedMonitorActor(Effect) - Constructor for class org.opendaylight.controller.cluster.common.actor.QuarantinedMonitorActor
 
QuarantinedMonitorActorPropsFactory - Class in org.opendaylight.controller.cluster.akka.osgi.impl
 

R

RaftActor - Class in org.opendaylight.controller.cluster.raft
RaftActor encapsulates a state machine that needs to be kept synchronized in a cluster.
RaftActor(String, Map<String, String>, Optional<ConfigParams>, short) - Constructor for class org.opendaylight.controller.cluster.raft.RaftActor
 
RaftActorBehavior - Interface in org.opendaylight.controller.cluster.raft.behaviors
The interface for a class that implements a specific behavior of a RaftActor.
RaftActorContext - Interface in org.opendaylight.controller.cluster.raft
The RaftActorContext contains that portion of the RaftActors state that needs to be shared with it's behaviors.
RaftActorContextImpl - Class in org.opendaylight.controller.cluster.raft
Implementation of the RaftActorContext interface.
RaftActorContextImpl(ActorRef, ActorContext, String, ElectionTerm, long, long, Map<String, String>, ConfigParams, DataPersistenceProvider, Consumer<ApplyState>, Logger, Executor) - Constructor for class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
RaftActorLeadershipTransferCohort - Class in org.opendaylight.controller.cluster.raft
A raft actor support class that participates in leadership transfer.
RaftActorRecoveryCohort - Interface in org.opendaylight.controller.cluster.raft
Interface for a class that participates in raft actor persistence recovery.
RaftActorSnapshotCohort - Interface in org.opendaylight.controller.cluster.raft
Interface for a class that participates in raft actor snapshotting.
RaftPolicy - Interface in org.opendaylight.controller.cluster.raft.policy
The RaftPolicy is intended to change the default behavior of Raft.
RaftRPC - Interface in org.opendaylight.controller.cluster.raft.messages
Interface implemented by all requests exchanged in the Raft protocol.
raftState(String) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
RaftState - Enum in org.opendaylight.controller.cluster.raft
 
RaftVersions - Class in org.opendaylight.controller.cluster.raft
Enumerates the raft versions.
Reactive(DataTreeModification, DataTree, ReusableNormalizedNodePruner) - Constructor for class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification.Reactive
 
read() - Method in interface org.opendaylight.controller.cluster.common.actor.AkkaConfigurationReader
 
read() - Method in class org.opendaylight.controller.cluster.common.actor.FileAkkaConfigurationReader
 
read(LogicalDatastoreType, YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerReadOnlyTransaction
 
read(LogicalDatastoreType, YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.DOMBrokerReadWriteTransaction
 
read(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientSnapshot
 
read(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
 
read(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
READ_ONLY - org.opendaylight.controller.cluster.datastore.TransactionType
 
READ_WRITE - org.opendaylight.controller.cluster.datastore.TransactionType
 
readData(AbstractShardDataTreeTransaction<?>, ReadData) - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
readData(ReadData) - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
 
ReadData - Class in org.opendaylight.controller.cluster.datastore.messages
 
ReadData() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadData
 
ReadData(YangInstanceIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadData
 
ReadDataReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
ReadDataReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
 
ReadDataReply(NormalizedNode<?, ?>, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
 
readDataTreeCandidate(DataInput, ReusableStreamReceiver) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.access.concepts.AbstractRequestFailureProxy
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.access.concepts.AbstractRequestProxy
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.EmptyExternalizable
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
readExternal(ObjectInput) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.AbstractProxy
 
readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.raft.base.messages.EmptyExternalizableProxy
 
readFrom(DataInput) - Static method in enum org.opendaylight.controller.cluster.access.ABIVersion
Read an ABIVersion from a DataInput.
readFrom(DataInput) - Static method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Read an PayloadVersion from a DataInput.
readFrom(DataInput) - Static method in enum org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
 
readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
readIdentifier(DataInput) - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.AbstractProxy
 
readinessFuture(SettableFuture<Void>) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
readNode(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTree
 
readNode(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
 
readNode(YangInstanceIdentifier.PathArgument) - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
 
readNodeAndPath(DataInput, T, SerializationUtils.Applier<T>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
readNormalizedNode(DataInput) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
readPath(DataInput) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
readPathAndNode(DataInput, T, SerializationUtils.Applier<T>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
readResolve() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.AbstractProxy
 
readResolve() - Method in class org.opendaylight.controller.cluster.raft.base.messages.EmptyExternalizableProxy
 
ReadTransactionRequest - Class in org.opendaylight.controller.cluster.access.commands
A transaction request to read a particular path exists in the current view of a particular transaction.
ReadTransactionRequest(TransactionIdentifier, long, ActorRef, YangInstanceIdentifier, boolean) - Constructor for class org.opendaylight.controller.cluster.access.commands.ReadTransactionRequest
 
ReadTransactionSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to an ReadTransactionRequest.
ReadTransactionSuccess(TransactionIdentifier, long, Optional<NormalizedNode<?, ?>>) - Constructor for class org.opendaylight.controller.cluster.access.commands.ReadTransactionSuccess
 
ReadWriteShardDataTreeTransaction - Class in org.opendaylight.controller.cluster.datastore
 
ready() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
 
ready() - Method in class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
ready() - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
 
READY - org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
Transaction is ready.
READY - org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
 
ReadyLocalTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
Message notifying the shard leader to apply modifications which have been prepared locally against its DataTree.
ReadyLocalTransaction(TransactionIdentifier, DataTreeModification, boolean, Optional<SortedSet<String>>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
 
ReadyLocalTransactionSerializer - Class in org.opendaylight.controller.cluster.datastore.messages
Specialized message transformer, which transforms a ReadyLocalTransaction into a BatchedModifications message.
ReadyLocalTransactionSerializer(ExtendedActorSystem) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
 
readyTransaction(Boolean, Optional<SortedSet<String>>) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
ReadyTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
 
ReadyTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
ReadyTransactionReply(String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
ReadyTransactionReply(String, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
received(Object) - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker
 
ReconnectForwarder - Class in org.opendaylight.controller.cluster.access.client
Forwarder class responsible for routing requests from the previous connection incarnation back to the originator, which can then convert them as appropriate.
ReconnectForwarder(AbstractReceivingClientConnection<?>) - Constructor for class org.opendaylight.controller.cluster.access.client.ReconnectForwarder
 
ReconnectingClientConnection<T extends BackendInfo> - Class in org.opendaylight.controller.cluster.access.client
An AbstractClientConnection which is being reconnected after having timed out.
recoverySnapshotIntervalSeconds(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
refreshBackendInfo(Long, T) - Method in class org.opendaylight.controller.cluster.access.client.BackendInfoResolver
Request re-resolution of a particular backend identified by a cookie, indicating a particular information as being stale.
register() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
This method is a wrapper for registerMBean with void return type so it can be invoked by dependency injection frameworks such as Spring and Blueprint.
register(EventSource) - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopology
 
registerActorSystemProviderListener(ActorSystemProviderListener) - Method in interface org.opendaylight.controller.cluster.ActorSystemProvider
Register a listener for ActorSystem lifecycle events.
registerActorSystemProviderListener(ActorSystemProviderListener) - Method in class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
 
registerActorSystemProviderListener(ActorSystemProviderListener) - Method in class org.opendaylight.controller.cluster.akka.osgi.impl.OSGiActorSystemProvider
 
registerCommitCohort(DOMDataTreeIdentifier, C) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
registerCommitCohort(DOMDataTreeIdentifier, T) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
RegisterDataTreeChangeListener - Class in org.opendaylight.controller.cluster.datastore.messages
Request a DOMDataTreeChangeListener registration be made on the shard leader.
RegisterDataTreeChangeListener() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
RegisterDataTreeChangeListener(YangInstanceIdentifier, ActorRef, boolean) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
RegisterDataTreeNotificationListenerReply - Class in org.opendaylight.controller.cluster.datastore.messages
Successful reply to a notification listener registration request.
RegisterDataTreeNotificationListenerReply(ActorRef) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeNotificationListenerReply
 
registerDataTreeShard(DOMDataTreeIdentifier, T, DOMDataTreeProducer) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardedDOMDataTree
 
registerDataTreeShard(DOMDataTreeIdentifier, T, DOMDataTreeProducer) - Method in class org.opendaylight.controller.cluster.sharding.OSGiDistributedShardedDOMDataTree
 
registerEventSource(T) - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopology
 
registerEventSource(T) - Method in class org.opendaylight.controller.messagebus.app.impl.OSGiEventSourceRegistry
 
registerEventSource(T) - Method in interface org.opendaylight.controller.messagebus.spi.EventSourceRegistry
Registers the given EventSource for public consumption.
RegisterForShardAvailabilityChanges - Class in org.opendaylight.controller.cluster.datastore.shardmanager
Local ShardManager message to register a callback to be notified of shard availability changes.
RegisterForShardAvailabilityChanges(Consumer<String>) - Constructor for class org.opendaylight.controller.cluster.datastore.shardmanager.RegisterForShardAvailabilityChanges
 
registerLeaderLocationListener(L) - Method in interface org.opendaylight.controller.cluster.dom.api.CDSShardAccess
Register a listener to shard location changes.
registerListener(T, Collection<DOMDataTreeIdentifier>, boolean, Collection<DOMDataTreeProducer>) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardedDOMDataTree
 
registerListener(T, Collection<DOMDataTreeIdentifier>, boolean, Collection<DOMDataTreeProducer>) - Method in class org.opendaylight.controller.cluster.sharding.OSGiDistributedShardedDOMDataTree
 
registerMBean() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
Registers this bean with the platform MBean server with the domain defined by AbstractMXBean.BASE_JMX_PREFIX.
registerProxyListener(YangInstanceIdentifier, YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
registerProxyListener(YangInstanceIdentifier, YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in interface org.opendaylight.controller.cluster.datastore.DistributedDataStoreInterface
 
registerProxyListener(YangInstanceIdentifier, YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
RegisterRoleChangeListener - Class in org.opendaylight.controller.cluster.notifications
Message sent from the listener of Role Change messages to register itself to the Role Change Notifier.
RegisterRoleChangeListener() - Constructor for class org.opendaylight.controller.cluster.notifications.RegisterRoleChangeListener
 
RegisterRoleChangeListenerReply - Class in org.opendaylight.controller.cluster.notifications
Reply message sent from a RoleChangeNotifier to the Role Change Listener.
RegisterRoleChangeListenerReply() - Constructor for class org.opendaylight.controller.cluster.notifications.RegisterRoleChangeListenerReply
 
registerShardConfigListener(YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
registerShardConfigListener(YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in interface org.opendaylight.controller.cluster.datastore.DistributedDataStoreInterface
 
registerShardConfigListener(YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
registerTreeChangeListener(YangInstanceIdentifier, L) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
registerTreeChangeListener(YangInstanceIdentifier, L) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
 
registerTreeChangeListener(YangInstanceIdentifier, L) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardChangePublisher
 
registerTreeChangeListener(YangInstanceIdentifier, DOMDataTreeChangeListener, Optional<DataTreeCandidate>, Consumer<ListenerRegistration<DOMDataTreeChangeListener>>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTree
 
registrationRemoved(AbstractDOMDataTreeChangeListenerRegistration<?>) - Method in class org.opendaylight.controller.cluster.sharding.DistributedShardChangePublisher
 
releaseAll() - Method in class org.opendaylight.controller.cluster.datastore.OperationLimiter
Release all the permits.
REMOTE - org.opendaylight.controller.cluster.dom.api.LeaderLocation
The leader is resident on a different node.
RemoteActionEndpoint(ActorRef, Collection<DOMActionInstance>) - Constructor for class org.opendaylight.controller.remote.rpc.registry.ActionRegistry.RemoteActionEndpoint
 
RemoteActionRegistryMXBean - Interface in org.opendaylight.controller.remote.rpc.registry.mbeans
 
RemoteActionRegistryMXBeanImpl - Class in org.opendaylight.controller.remote.rpc.registry.mbeans
 
RemoteActionRegistryMXBeanImpl(BucketStoreAccess, Timeout) - Constructor for class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBeanImpl
 
RemoteDOMActionException - Exception in org.opendaylight.controller.remote.rpc
 
RemoteFindPrimary - Class in org.opendaylight.controller.cluster.datastore.messages
A remote message sent to locate the primary shard.
RemoteFindPrimary(String, boolean, Collection<String>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.RemoteFindPrimary
 
RemoteOpsProvider - Class in org.opendaylight.controller.remote.rpc
This is the base class which initialize all the actors, listeners and default RPc implementation so remote invocation of rpcs.
RemoteOpsProvider(ActorSystem, DOMRpcProviderService, DOMRpcService, RemoteOpsProviderConfig, DOMActionProviderService, DOMActionService) - Constructor for class org.opendaylight.controller.remote.rpc.RemoteOpsProvider
 
RemoteOpsProviderConfig - Class in org.opendaylight.controller.remote.rpc
 
RemoteOpsProviderConfig(Config) - Constructor for class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
RemoteOpsProviderConfig.Builder - Class in org.opendaylight.controller.remote.rpc
 
RemoteOpsProviderFactory - Class in org.opendaylight.controller.remote.rpc
 
RemotePrimaryShardFound - Class in org.opendaylight.controller.cluster.datastore.messages
Local or remote message sent in reply to FindPrimaryShard to indicate the primary shard is remote to the caller.
RemotePrimaryShardFound(String, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.RemotePrimaryShardFound
 
RemoteRpcEndpoint(ActorRef, Collection<DOMRpcIdentifier>) - Constructor for class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.RemoteRpcEndpoint
 
RemoteRpcRegistryMXBean - Interface in org.opendaylight.controller.remote.rpc.registry.mbeans
JMX bean to check remote rpc registry.
RemoteRpcRegistryMXBeanImpl - Class in org.opendaylight.controller.remote.rpc.registry.mbeans
 
RemoteRpcRegistryMXBeanImpl(BucketStoreAccess, Timeout) - Constructor for class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBeanImpl
 
RemoteSchemaProvider - Class in org.opendaylight.controller.cluster.schema.provider.impl
Provides schema sources from RemoteYangTextSourceProvider.
RemoteSchemaProvider(RemoteYangTextSourceProvider, ExecutionContext) - Constructor for class org.opendaylight.controller.cluster.schema.provider.impl.RemoteSchemaProvider
 
RemoteTransactionContext - Class in org.opendaylight.controller.cluster.datastore
Redirects front-end transaction operations to a shard for processing.
RemoteTransactionContext(TransactionIdentifier, ActorSelection, ActorUtils, short, OperationLimiter) - Constructor for class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
RemoteYangTextSourceProvider - Interface in org.opendaylight.controller.cluster.schema.provider
A remote yang text source provider provides serializable yang text sources.
RemoteYangTextSourceProviderImpl - Class in org.opendaylight.controller.cluster.schema.provider.impl
Remote schema provider implementation backed by local schema provider.
RemoteYangTextSourceProviderImpl(SchemaRepository, Set<SourceIdentifier>) - Constructor for class org.opendaylight.controller.cluster.schema.provider.impl.RemoteYangTextSourceProviderImpl
 
remove(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.PrimaryShardInfoFutureCache
 
removeAllShardReplicas(RemoveAllShardReplicasInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
removeAllShardReplicas(RemoveAllShardReplicasInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Removes replicas for all shards on this node.
RemoveAllShardReplicasInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
RemoveAllShardReplicasInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds RemoveAllShardReplicasInputBuilder instances.
RemoveAllShardReplicasInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
 
RemoveAllShardReplicasInputBuilder(RemoveAllShardReplicasInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
 
RemoveAllShardReplicasOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
RemoveAllShardReplicasOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds RemoveAllShardReplicasOutputBuilder instances.
RemoveAllShardReplicasOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
 
RemoveAllShardReplicasOutputBuilder(RemoveAllShardReplicasOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
 
RemoveAllShardReplicasOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
 
removeAugmentation(Class<? extends Augmentation<CreateTopicInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<CreateTopicOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<DestroyTopicInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<DestroyTopicOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<TopicNotification>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<DisJoinTopicInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<DisJoinTopicOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<EventSourceStatusNotification>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<JoinTopicInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<JoinTopicOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<TopologyEventSource>>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSourceBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<NodeConnector>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<NodeConnectorRemoved>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<NodeConnectorUpdated>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<NodeRemoved>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<Node>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<Nodes>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<NodeUpdated>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<NodeIdentifier>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<OriginalNode>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<DataStorePropertiesContainer>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<AddPrefixShardReplicaInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<AddPrefixShardReplicaOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<AddReplicasForAllShardsInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<AddReplicasForAllShardsOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<AddShardReplicaInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<AddShardReplicaOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<BackupDatastoreInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<BackupDatastoreOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForAllShardsInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForAllShardsOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForShardInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<ChangeMemberVotingStatesForShardOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<FlipMemberVotingStatesForAllShardsInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<FlipMemberVotingStatesForAllShardsOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<KnownClients>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<GetKnownClientsForAllShardsInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<GetKnownClientsForAllShardsOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<GetPrefixShardRoleInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<GetPrefixShardRoleOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<GetShardRoleInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<GetShardRoleOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<LeaderActorRef>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<Local>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<LocateShardInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<LocateShardOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<MakeLeaderLocalInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<MakeLeaderLocalOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<MemberVotingState>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<RemoveAllShardReplicasInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<RemoveAllShardReplicasOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<RemovePrefixShardReplicaInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<RemovePrefixShardReplicaOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<RemoveShardReplicaInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<RemoveShardReplicaOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<ShardResult>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<Replicas>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<Shard>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
Remove an augmentation from this builder's product.
removeAugmentation(Class<? extends Augmentation<PrefixShards>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
Remove an augmentation from this builder's product.
removeFollower(String) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
removeFrom(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
removeFrom(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Removes entries from the in-memory log starting at the given index.
removeFromAndPersist(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Removes entries from the in-memory log and the persisted log starting at the given index.
removeMemberReplicaForShard(String, MemberName) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Removes the given member as a replica for the given shardName.
removeMemberReplicaForShard(String, MemberName) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
removePeer(String) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Removes a peer.
removePeer(String) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
removePrefixShardConfiguration(DOMDataTreeIdentifier) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
Removes a shard configuration for the specified prefix.
removePrefixShardConfiguration(DOMDataTreeIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
 
removePrefixShardReplica(RemovePrefixShardReplicaInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
removePrefixShardReplica(RemovePrefixShardReplicaInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Removes an existing replica of a prefix shard from this node via the RemoveServer mechanism as described in the Raft paper.
RemovePrefixShardReplica - Class in org.opendaylight.controller.cluster.datastore.messages
A message sent to the ShardManager to dynamically remove a local prefix shard replica available in this node.
RemovePrefixShardReplica(YangInstanceIdentifier, MemberName) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.RemovePrefixShardReplica
Constructor.
RemovePrefixShardReplicaInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
RemovePrefixShardReplicaInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds RemovePrefixShardReplicaInputBuilder instances.
RemovePrefixShardReplicaInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
RemovePrefixShardReplicaInputBuilder(RemovePrefixShardReplicaInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
RemovePrefixShardReplicaOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
RemovePrefixShardReplicaOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds RemovePrefixShardReplicaOutputBuilder instances.
RemovePrefixShardReplicaOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutputBuilder
 
RemovePrefixShardReplicaOutputBuilder(RemovePrefixShardReplicaOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaOutputBuilder
 
removeRegistration() - Method in class org.opendaylight.controller.cluster.datastore.DataTreeCohortRegistrationProxy
 
RemoveRoutes(Collection<DOMRpcIdentifier>) - Constructor for class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.Messages.RemoveRoutes
 
RemoveServer - Class in org.opendaylight.controller.cluster.raft.messages
Message sent to remove a replica (§4.1).
RemoveServer(String) - Constructor for class org.opendaylight.controller.cluster.raft.messages.RemoveServer
 
RemoveServerReply - Class in org.opendaylight.controller.cluster.raft.messages
Reply to a RemoveServer message (§4.1).
RemoveServerReply(ServerChangeStatus, String) - Constructor for class org.opendaylight.controller.cluster.raft.messages.RemoveServerReply
 
removeShardReplica(RemoveShardReplicaInput) - Method in class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
 
removeShardReplica(RemoveShardReplicaInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService
Removes an existing replica of a shard from this node via the RemoveServer mechanism as described in the Raft paper.
RemoveShardReplica - Class in org.opendaylight.controller.cluster.datastore.messages
A message sent to the ShardManager to dynamically remove a local shard replica available in this node.
RemoveShardReplica(String, MemberName) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.RemoveShardReplica
Constructor.
RemoveShardReplicaInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
RemoveShardReplicaInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds RemoveShardReplicaInputBuilder instances.
RemoveShardReplicaInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
RemoveShardReplicaInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
RemoveShardReplicaInputBuilder(RemoveShardReplicaInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
RemoveShardReplicaOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
 
RemoveShardReplicaOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
Class that builds RemoveShardReplicaOutputBuilder instances.
RemoveShardReplicaOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
 
RemoveShardReplicaOutputBuilder(RemoveShardReplicaOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
 
replayEntry(ConnectionEntry, long) - Method in class org.opendaylight.controller.cluster.access.client.ReconnectForwarder
 
replayToSuccessor(ConnectionEntry) - Method in class org.opendaylight.controller.cluster.access.client.ReconnectForwarder
 
Replicas - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard
List of cluster member nodes that this shard is replicated on
ReplicasBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard
Class that builds ReplicasBuilder instances.
ReplicasBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
 
ReplicasBuilder(Replicas) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
 
Replicate - Class in org.opendaylight.controller.cluster.raft.base.messages
 
Replicate(ActorRef, Identifier, ReplicatedLogEntry, boolean) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.Replicate
 
ReplicatedLog - Interface in org.opendaylight.controller.cluster.raft
Represents the ReplicatedLog that needs to be kept in sync by the RaftActor.
ReplicatedLogEntry - Interface in org.opendaylight.controller.cluster.raft
Represents one entry in the replicated log.
replicatedToAllIndex(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
replyTo(ActorRef) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Sets the reference of the actor to which message slice replies should be sent.
Request<T extends WritableIdentifier,​C extends Request<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
A request message concept.
Request(C, ABIVersion) - Constructor for class org.opendaylight.controller.cluster.access.concepts.Request
 
Request(T, long, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.concepts.Request
 
RequestEnvelope - Class in org.opendaylight.controller.cluster.access.concepts
 
RequestEnvelope(Request<?, ?>, long, long) - Constructor for class org.opendaylight.controller.cluster.access.concepts.RequestEnvelope
 
RequestException - Exception in org.opendaylight.controller.cluster.access.concepts
A failure cause behind a RequestFailure to process a Request.
RequestException(String) - Constructor for exception org.opendaylight.controller.cluster.access.concepts.RequestException
 
RequestException(String, Throwable) - Constructor for exception org.opendaylight.controller.cluster.access.concepts.RequestException
 
RequestFailure<T extends WritableIdentifier,​C extends RequestFailure<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
A failure response to a Request.
RequestFailure(C, ABIVersion) - Constructor for class org.opendaylight.controller.cluster.access.concepts.RequestFailure
 
RequestFailure(T, long, RequestException) - Constructor for class org.opendaylight.controller.cluster.access.concepts.RequestFailure
 
RequestLeadership - Class in org.opendaylight.controller.cluster.raft.messages
Message sent to leader to transfer leadership to a particular follower.
RequestLeadership(String, ActorRef) - Constructor for class org.opendaylight.controller.cluster.raft.messages.RequestLeadership
 
requestSnapshot(ActorRef, ShardDataTreeSnapshot, Optional<OutputStream>, ActorRef) - Static method in class org.opendaylight.controller.cluster.datastore.actors.ShardSnapshotActor
Sends a request to a ShardSnapshotActor to process a snapshot and send a CaptureSnapshotReply.
RequestSuccess<T extends WritableIdentifier,​C extends RequestSuccess<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
A successful reply to a Request.
RequestSuccess(C, ABIVersion) - Constructor for class org.opendaylight.controller.cluster.access.concepts.RequestSuccess
 
RequestSuccess(T, long) - Constructor for class org.opendaylight.controller.cluster.access.concepts.RequestSuccess
 
RequestTimeoutException - Exception in org.opendaylight.controller.cluster.access.client
 
RequestTimeoutException(String) - Constructor for exception org.opendaylight.controller.cluster.access.client.RequestTimeoutException
 
requestVote(ActorRef, RequestVote) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Handles the logic for the RequestVote message that is common for all behaviors.
RequestVote - Class in org.opendaylight.controller.cluster.raft.messages
Invoked by candidates to gather votes (§5.2).
RequestVote(long, String, long, long) - Constructor for class org.opendaylight.controller.cluster.raft.messages.RequestVote
 
RequestVoteReply - Class in org.opendaylight.controller.cluster.raft.messages
 
RequestVoteReply(long, boolean) - Constructor for class org.opendaylight.controller.cluster.raft.messages.RequestVoteReply
 
reset() - Method in class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Resets this instance to restart slicing from the beginning.
resetAskTimeoutExceptionCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBean
Reset the number of AskTimeoutExceptions encountered by the datastore.
resetAskTimeoutExceptionCount() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBeanImpl
 
resetAskTimeoutExceptionCount() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
resetTransactionCounters() - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
Resets the counters related to transactions.
resetTransactionCounters() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
 
resolve(String) - Method in class org.opendaylight.controller.cluster.raft.NoopPeerAddressResolver
 
resolve(String) - Method in interface org.opendaylight.controller.cluster.raft.PeerAddressResolver
Resolves a raft actor peer id to its remote actor address.
resolve(MemberName) - Method in class org.opendaylight.controller.cluster.sharding.ShardingServiceAddressResolver
 
resolveCookieName(Long) - Method in class org.opendaylight.controller.cluster.access.client.BackendInfoResolver
 
resolver() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorBehavior
Override this method to provide a backend resolver instance.
Response<T extends WritableIdentifier,​C extends Response<T,​C>> - Class in org.opendaylight.controller.cluster.access.concepts
Abstract counterpart to a Request.
ResponseEnvelope<T extends Response<?,​?>> - Class in org.opendaylight.controller.cluster.access.concepts
 
restoreFromSnapshot(DatastoreSnapshot) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
restoreFromSnapshot(DatastoreSnapshot.ShardSnapshot) - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
resultRpcSuccessFor(T) - Static method in class org.opendaylight.controller.messagebus.app.util.Util
 
resume() - Method in class org.opendaylight.controller.cluster.datastore.TransactionRateLimitingCallback
 
RetiredGenerationException - Exception in org.opendaylight.controller.cluster.access.concepts
General error raised when the recipient of a Request determines that the request contains a ClientIdentifier which corresponds to an outdated generation.
RetiredGenerationException(long, long) - Constructor for exception org.opendaylight.controller.cluster.access.concepts.RetiredGenerationException
 
retrieveModuleConfigs(Configuration) - Method in interface org.opendaylight.controller.cluster.datastore.config.ModuleShardConfigProvider
Returns a Map of ModuleConfig Builder instances keyed by module name.
retrieveModuleConfigs(Configuration) - Method in class org.opendaylight.controller.cluster.datastore.config.FileModuleShardConfigProvider
 
retrieveModuleConfigs(Configuration) - Method in class org.opendaylight.controller.cluster.datastore.config.HybridModuleShardConfigProvider
 
returnCloseTransactionReply() - Method in class org.opendaylight.controller.cluster.datastore.ShardReadTransaction
 
returnCloseTransactionReply() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
ReusableNormalizedNodePruner - Class in org.opendaylight.controller.cluster.datastore.node.utils.transformer
The NormalizedNodePruner removes all nodes from the input NormalizedNode that do not have a corresponding schema element in the passed in SchemaContext.
RoleChanged - Class in org.opendaylight.controller.cluster.notifications
Role Change message initiated internally from the Raft Actor when a the behavior/role changes.
RoleChanged(String, String, String) - Constructor for class org.opendaylight.controller.cluster.notifications.RoleChanged
 
RoleChangeListenerActor - Class in org.opendaylight.controller.cluster.sharding
Proxy actor which acts as a facade for user-provided LeaderLocationListener.
RoleChangeNotification - Class in org.opendaylight.controller.cluster.notifications
Notification message representing a Role change of a cluster member.
RoleChangeNotification(String, String, String) - Constructor for class org.opendaylight.controller.cluster.notifications.RoleChangeNotification
 
RoleChangeNotifier - Class in org.opendaylight.controller.cluster.notifications
The RoleChangeNotifier is responsible for receiving Raft role and leader state change messages and notifying the listeners (within the same node), which are registered with it.
RoleChangeNotifier(String) - Constructor for class org.opendaylight.controller.cluster.notifications.RoleChangeNotifier
 
rollback() - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
rollback() - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Rolls back the snapshot on failure.
RoutingTable - Class in org.opendaylight.controller.remote.rpc.registry
 
RpcErrorsException - Exception in org.opendaylight.controller.remote.rpc
An Exception for transferring RpcErrors.
RpcErrorsException(String, Iterable<? extends RpcError>) - Constructor for exception org.opendaylight.controller.remote.rpc.RpcErrorsException
 
RpcRegistry - Class in org.opendaylight.controller.remote.rpc.registry
Registry to look up cluster nodes that have registered for a given RPC.
RpcRegistry(RemoteOpsProviderConfig, ActorRef, ActorRef) - Constructor for class org.opendaylight.controller.remote.rpc.registry.RpcRegistry
 
RpcRegistry.Messages - Class in org.opendaylight.controller.remote.rpc.registry
All messages used by the RpcRegistry.
RpcRegistry.Messages.AddOrUpdateRoutes - Class in org.opendaylight.controller.remote.rpc.registry
 
RpcRegistry.Messages.RemoveRoutes - Class in org.opendaylight.controller.remote.rpc.registry
 
RpcRegistry.Messages.UpdateRemoteEndpoints - Class in org.opendaylight.controller.remote.rpc.registry
 
RpcRegistry.RemoteRpcEndpoint - Class in org.opendaylight.controller.remote.rpc.registry
 
RpcResponse - Class in org.opendaylight.controller.remote.rpc.messages
 
RpcResponse(NormalizedNode<?, ?>) - Constructor for class org.opendaylight.controller.remote.rpc.messages.RpcResponse
 
run() - Method in class org.opendaylight.controller.cluster.datastore.TransactionRateLimitingCallback
 
RuntimeRequestException - Exception in org.opendaylight.controller.cluster.access.concepts
General error raised when the recipient of a Request fails to process a request.
RuntimeRequestException(String, Throwable) - Constructor for exception org.opendaylight.controller.cluster.access.concepts.RuntimeRequestException
 

S

SAME_FAILURE_TRANSFORMER - Static variable in class org.opendaylight.controller.cluster.datastore.TransactionReadyReplyMapper
 
saveSnapshot(Object) - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
Saves a snapshot.
saveSnapshot(Object) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
saveSnapshot(Object) - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
 
saveSnapshot(Object) - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
 
schedule(Runnable, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
ScheduledThreadPool - Interface in org.opendaylight.controller.config.threadpool
Interface representing scheduled ThreadPool.
ScheduledThreadPoolWrapper - Class in org.opendaylight.controller.config.threadpool.util
ScheduledThreadPoolWrapper(int, ThreadFactory) - Constructor for class org.opendaylight.controller.config.threadpool.util.ScheduledThreadPoolWrapper
 
scheduleElection(FiniteDuration) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Schedule a new election.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
schemaContextProvider(EffectiveModelContextProvider) - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
self() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActorBehavior
Return an ActorRef of this ClientActor.
self() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
sendAppendEntries(long, boolean) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
sendBatchedModifications() - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
sendBatchedModifications(boolean, boolean, Optional<SortedSet<String>>) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
sendFailure(RequestException, long) - Method in class org.opendaylight.controller.cluster.access.concepts.RequestEnvelope
Respond to this envelope with a RequestFailure caused by specified RequestException.
SendHeartBeat - Class in org.opendaylight.controller.cluster.raft.base.messages
This messages is sent via a schedule to the Leader to prompt it to send a heart beat to its followers.
SendInstallSnapshot - Class in org.opendaylight.controller.cluster.raft.base.messages
Internal message sent from the SnapshotManager to its associated leader when a snapshot capture is complete to prompt the leader to install the snapshot on its followers as needed.
SendInstallSnapshot(Snapshot, ByteSource) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.SendInstallSnapshot
 
sendOperationAsync(ActorSelection, Object) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
Sends an operation to be executed by a remote actor asynchronously without waiting for a reply (essentially set and forget).
sendRequest(Request<?, ?>, Consumer<Response<?, ?>>) - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
Send a request to the backend and invoke a specified callback when it finishes.
sendSuccess(RequestSuccess<?, ?>, long) - Method in class org.opendaylight.controller.cluster.access.concepts.RequestEnvelope
Respond to this envelope with a RequestSuccess.
sendTo(ActorRef) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Sets the reference of the actor to which to send the message slices.
sendTo(ActorSelection) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
Sets the ActorSelection to which to send the message slices.
sendToSuccessor(ConnectionEntry) - Method in class org.opendaylight.controller.cluster.access.client.ReconnectForwarder
 
SerializableMessage - Interface in org.opendaylight.controller.cluster.datastore.messages
 
Serialization - org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
 
SERIALIZATION_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
SerializationUtils - Class in org.opendaylight.controller.cluster.datastore.node.utils.stream
Provides various utility methods for serialization and de-serialization.
SerializationUtils.Applier<T> - Interface in org.opendaylight.controller.cluster.datastore.node.utils.stream
 
serialize(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardDataTreeSnapshot
 
ServerChangeReply - Class in org.opendaylight.controller.cluster.raft.messages
A general server change reply.
ServerChangeReply(ServerChangeStatus, String) - Constructor for class org.opendaylight.controller.cluster.raft.messages.ServerChangeReply
 
ServerChangeStatus - Enum in org.opendaylight.controller.cluster.raft.messages
Enumerates server configuration change status reply codes.
ServerConfigurationPayload - Class in org.opendaylight.controller.cluster.raft.persisted
Payload data for server configuration log entries.
ServerConfigurationPayload(List<ServerInfo>) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
 
ServerInfo - Class in org.opendaylight.controller.cluster.raft.persisted
Server information.
ServerInfo(String, boolean) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
 
ServerRemoved - Class in org.opendaylight.controller.cluster.raft.messages
The ServerRemoved message is sent to a server which has been removed successfully from the ServerConfiguration.
ServerRemoved(String) - Constructor for class org.opendaylight.controller.cluster.raft.messages.ServerRemoved
 
setAbort() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
setActorSystem(ActorSystem) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
setAddress(String) - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
 
setBackendAlivenessTimerIntervalInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setBoundedMailboxCapacity(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setCandidateElectionTimeoutDivisor(long) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setCloseable(AutoCloseable) - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBroker
 
setCloseable(AutoCloseable) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
 
setClusterWrapper(ClusterWrapper) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
setCommit(boolean) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
setCommitIndex(long) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Sets the index of highest log entry known to be committed.
setCommitIndex(long) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setConfigParams(ConfigParams) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setContext(DatastoreContext) - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBeanImpl
 
setCustomRaftPolicyImplementation(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setCustomRaftPolicyImplementationClass(String) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setDatastoreContext(DatastoreContextFactory) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
setDelegate(DataPersistenceProvider) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
 
setDistributedConfigDatastore(DistributedDataStoreInterface) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
setDistributedOperDatastore(DistributedDataStoreInterface) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
setDoCommitOnReady(boolean) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
setDynamicServerConfigurationInUse() - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Sets that dynamic server configuration changes have been applied.
setDynamicServerConfigurationInUse() - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setElectionTimeoutFactor(long) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setEnableMetricCapture(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setErrorMessage(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
setEventSourceNode(NodeId) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.Node1Builder
 
setFileBackedStreamingThreshold(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setFileBackedStreamingThresholdInMegabytes(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setFilePath(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
setFollowerInitialSyncStatus(boolean) - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
setFrontendNoProgressTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setFrontendRequestTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setGeneration(ClientGeneration) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
setHeartBeatInterval(FiniteDuration) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setId(NodeConnectorId) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
setId(NodeConnectorId) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
setId(NodeId) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
setId(NodeId) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
setIdentifier(Uri) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
setInitialPayloadSerializedBufferCapacity(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setInitialSettleTimeoutMultiplier(Long) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link setInitialSettleTimeoutMultiplier(Uint32)} instead.
setInitialSettleTimeoutMultiplier(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setInventoryNodeConnectorRef(NodeConnectorRef) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeConnectorBuilder
 
setInventoryNodeRef(NodeRef) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.inventory.rev131030.InventoryNodeBuilder
 
setIsolatedLeaderCheckInterval(FiniteDuration) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setJournalRecoveryLogBatchSize(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setKeepAliveMillis(long) - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
setKnownClients(List<KnownClients>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1Builder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setKnownClients(Map)} instead.
setKnownClients(Map<KnownClientsKey, KnownClients>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1Builder
 
setLastApplied(long) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Sets index of highest log entry applied to state machine.
setLastApplied(long) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setLastCommittedTransactionTime(long) - Method in class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
setLeaderActorRef(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LeaderActorRefBuilder
 
setLeaderId(String) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
setLeaderInstallSnapshotState(LeaderInstallSnapshotState) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Sets the LeaderInstallSnapshotState when an install snapshot is initiated.
setLeaderPayloadVersion(short) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Follower
 
setListener(DatastoreContextPropertiesUpdater.Listener) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextPropertiesUpdater
 
setLocal(Empty) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.locate.shard.output.member.node.LocalBuilder
 
setLookupTaskMaxRetries(int) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
setMatchIndex(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Sets the index of the follower's highest log entry.
setMaximumMessageSliceSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setMaxShardDataChangeExecutorPoolSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setMaxShardDataChangeExecutorQueueSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setMaxShardDataChangeListenerQueueSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setMaxShardDataStoreExecutorQueueSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setMaxThreadCount(int) - Method in class org.opendaylight.controller.config.threadpool.util.FixedThreadPoolWrapper
 
setMaxThreadCount(int) - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
setMember(MemberName) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
setMemberName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
setMemberName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
 
setMemberName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
setMemberName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
setMemberNode(MemberNode) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
 
setMemberVotingState(List<MemberVotingState>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
 
setMemberVotingState(List<MemberVotingState>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
setMinThreadCount(int) - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
setNeedsLeaderAddress(boolean) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
 
setNextIndex(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Sets the index of the follower's next log entry.
setNode(List<Node>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setNode(Map)} instead.
setNode(Map<NodeKey, Node>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder
 
setNode(NodeId) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
setNode(InstanceIdentifier<?>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
setNode(InstanceIdentifier<?>) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
setNodeConnector(List<NodeConnector>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setNodeConnector(Map)} instead.
setNodeConnector(List<NodeConnector>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setNodeConnector(Map)} instead.
setNodeConnector(Map<NodeConnectorKey, NodeConnector>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
setNodeConnector(Map<NodeConnectorKey, NodeConnector>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
setNodeConnectorRef(NodeConnectorRef) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRemovedBuilder
 
setNodeConnectorRef(NodeConnectorRef) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorUpdatedBuilder
 
setNodeId(String) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
setNodeIdentifier(List<NodeIdentifier>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setNodeIdentifier(Map)} instead.
setNodeIdentifier(Map<NodeIdentifierKey, NodeIdentifier>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.IdentifiableNodeBuilder
 
setNodeIdPattern(Pattern) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
setNodeRef(NodeRef) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder
 
setNodeRef(NodeRef) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder
 
setNotificationPattern(NotificationPattern) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicInputBuilder
 
setNotificationPattern(NotificationPattern) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
setOnCleanupCallback(Consumer<T>, T) - Method in class org.opendaylight.controller.cluster.io.SharedFileBackedOutputStream
Sets the callback to be notified when FileBackedOutputStream.cleanup() is called to delete the backing file.
setOperationTimeoutInSeconds(OperationTimeoutType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setOriginalNode(List<OriginalNode>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedNodeBuilder
 
setOriginalTopology(List<TopologyId>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.AggregatedTopologyBuilder
 
setPath(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
 
setPayload(Payload) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
setPayloadVersion(short) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Sets the payload data version of the follower.
setPayloadVersion(short) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setPeerAddress(String, String) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
setPeerAddress sets the address of a known peer at a later time.
setPeerAddress(String, String) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Sets the address of a peer.
setPeerAddress(String, String) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setPeerAddressResolver(PeerAddressResolver) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setPersistence(boolean) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
setPersistence(DataPersistenceProvider) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
setPersistencePending(boolean) - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
setPersistencePending(boolean) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
Sets whether or not persistence is pending for this entry.
setPersistent(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setPrefix(InstanceIdentifier<?>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
setRaftActorLeadershipTransferCohort(RaftActorLeadershipTransferCohort) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Sets the RaftActorLeadershipTransferCohort for transferring leadership.
setRaftActorLeadershipTransferCohort(RaftActorLeadershipTransferCohort) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setRaftVersion(short) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Sets the raft version of the follower.
setReady() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
setReady() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
setReady(Optional<SortedSet<String>>) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
setRecoverySnapshotIntervalSeconds(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setRecoverySnapshotIntervalSeconds(Long) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link setRecoverySnapshotIntervalSeconds(Uint32)} instead.
setRecoverySnapshotIntervalSeconds(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
SetRegistration(ListenerRegistration<?>, Runnable) - Constructor for class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor.SetRegistration
 
setRemoteVersion(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
 
setReplica(List<String>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.shard.ReplicasBuilder
 
setReplicas(Replicas) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
setReplicatedLog(ReplicatedLog) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Sets the ReplicatedLog instance.
setReplicatedLog(ReplicatedLog) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setReplicatedToAllIndex(long) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
setReplicatedToAllIndex(long) - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
Sets the index of the last log entry that has been replicated to all peers.
setResolved(String, String) - Method in interface org.opendaylight.controller.cluster.raft.PeerAddressResolver
Sets the actor address for a raft peer.
setRole(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleOutputBuilder
 
setRole(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
 
setSchemaContext(EffectiveModelContext) - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
setSentCommitIndex(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
 
setSequence(long) - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
setShard(List<Shard>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setShard(Map)} instead.
setShard(Map<ShardKey, Shard>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.PrefixShardsBuilder
 
setShardBatchedModificationCount(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardCommitQueueExpiryTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardElectionTimeoutFactor(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardHeartbeatIntervalInMillis(HeartbeatIntervalType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardingService(DistributedShardedDOMDataTree) - Method in class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
setShardInitializationTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardIsolatedLeaderCheckIntervalInMillis(HeartbeatIntervalType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardJournalRecoveryLogBatchSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardLeaderElectionTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
 
setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
 
setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
 
setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
 
setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
 
setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
 
setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
setShardPrefix(InstanceIdentifier<?>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddPrefixShardReplicaInputBuilder
 
setShardPrefix(InstanceIdentifier<?>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetPrefixShardRoleInputBuilder
 
setShardPrefix(InstanceIdentifier<?>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemovePrefixShardReplicaInputBuilder
 
setShardResult(List<ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setShardResult(Map)} instead.
setShardResult(List<ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setShardResult(Map)} instead.
setShardResult(List<ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setShardResult(Map)} instead.
setShardResult(List<ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setShardResult(Map)} instead.
setShardResult(List<ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link #setShardResult(Map)} instead.
setShardResult(Map<ShardResultKey, ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
 
setShardResult(Map<ShardResultKey, ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
 
setShardResult(Map<ShardResultKey, ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
 
setShardResult(Map<ShardResultKey, ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
 
setShardResult(Map<ShardResultKey, ShardResult>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
 
setShardSnapshotBatchCount(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardSnapshotChunkSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardSnapshotDataThreshold(Long) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link setShardSnapshotDataThreshold(Uint32)} instead.
setShardSnapshotDataThreshold(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardSnapshotDataThresholdPercentage(Percentage) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardTransactionCommitQueueCapacity(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardTransactionCommitTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setShardTransactionIdleTimeoutInMinutes(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setSlicedLogEntryIndex(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
Sets the index of the log entry whose payload size exceeds the maximum size for a single message and thus needs to be sliced into smaller chunks.
setSnapshotBatchCount(long) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setSnapshotChunkSize(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setSnapshotDataThreshold(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setSnapshotDataThresholdPercentage(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setSnapshotIndex(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
setSnapshotIndex(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Sets the snapshot index in the replicated log.
setSnapshotOnRootOverwrite(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setSnapshotTerm(long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
setSnapshotTerm(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Sets snapshot term.
setStatus(EventSourceStatus) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatusNotificationBuilder
 
setStatus(JoinTopicStatus) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicOutputBuilder
 
setSucceeded(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
setSyncIndexThreshold(long) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setSyncIndexThreshold(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setTempFileDirectory(String) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
 
setThreadFactory(ThreadFactory) - Method in class org.opendaylight.controller.config.threadpool.util.FlexibleThreadPoolWrapper
 
setTimeout(Long) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use {#link setTimeout(Uint32)} instead.
setTimeout(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
 
setTopicId(TopicId) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.CreateTopicOutputBuilder
 
setTopicId(TopicId) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.DestroyTopicInputBuilder
 
setTopicId(TopicId) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
setTopicId(TopicId) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.DisJoinTopicInputBuilder
 
setTopicId(TopicId) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicInputBuilder
 
setTopology(TopologyId) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.view.rev131030.aggregate.node.OriginalNodeBuilder
 
setTopologyEventSource(TopologyEventSource) - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1Builder
 
setTotalMemoryRetriever(LongSupplier) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Sets the retriever of the total memory metric.
setTotalMemoryRetriever(LongSupplier) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
setTotalMessagesSent(int) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
setTransactionCreationInitialRateLimit(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setTransactionDebugContextEnabled(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setType(Class<? extends NodeType>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
setType(FrontendType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
setUseLz4Compression(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setUseTellBasedProtocol(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.DataStorePropertiesContainerBuilder
 
setVoting(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.member.voting.states.input.MemberVotingStateBuilder
 
setVotingState(VotingState) - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
 
Shard - Class in org.opendaylight.controller.cluster.datastore
A Shard represents a portion of the logical data tree.
Shard - org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
 
Shard - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards
List of prefix-based shards configured.
Shard(Shard.AbstractBuilder<?, ?>) - Constructor for class org.opendaylight.controller.cluster.datastore.Shard
 
SHARD_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
SHARD_LIST_PATH - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
SHARD_LIST_QNAME - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
SHARD_PREFIX_QNAME - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
SHARD_REPLICA_QNAME - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
SHARD_REPLICAS_QNAME - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ClusterUtils
 
Shard.AbstractBuilder<T extends Shard.AbstractBuilder<T,​S>,​S extends Shard> - Class in org.opendaylight.controller.cluster.datastore
 
Shard.Builder - Class in org.opendaylight.controller.cluster.datastore
 
shardBatchedModificationCount(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ShardBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards
Class that builds ShardBuilder instances.
ShardBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
ShardBuilder(Shard) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
shardCandidateElectionTimeoutDivisor(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardCommitQueueExpiryTimeoutInMillis(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardCommitQueueExpiryTimeoutInSeconds(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardConfig(String, Collection<MemberName>) - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig.Builder
 
ShardConfig - Class in org.opendaylight.controller.cluster.datastore.config
Encapsulated configuration for a shard.
ShardConfig(String, Collection<MemberName>) - Constructor for class org.opendaylight.controller.cluster.datastore.config.ShardConfig
 
ShardConfigHandler(MemberName, LogicalDatastoreType, ActorRef) - Constructor for class org.opendaylight.controller.cluster.sharding.PrefixedShardConfigUpdateHandler.ShardConfigHandler
 
ShardDataTree - Class in org.opendaylight.controller.cluster.datastore
Internal shard state, similar to a DOMStore, but optimized for use in the actor system, e.g.
ShardDataTree(Shard, EffectiveModelContext, TreeType) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardDataTree
 
ShardDataTreeChangePublisherActor - Class in org.opendaylight.controller.cluster.datastore
Actor used to generate and publish DataTreeChange notifications.
ShardDataTreeCohort - Class in org.opendaylight.controller.cluster.datastore
 
ShardDataTreeCohort.State - Enum in org.opendaylight.controller.cluster.datastore
 
ShardDataTreeListenerInfoMXBean - Interface in org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard
MXBean interface for reporting shard data tree change listener information.
ShardDataTreeListenerInfoMXBeanImpl - Class in org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard
Implementation of ShardDataTreeListenerInfoMXBean.
ShardDataTreeListenerInfoMXBeanImpl(String, String, ActorRef) - Constructor for class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardDataTreeListenerInfoMXBeanImpl
 
ShardDataTreeNotificationPublisherActor<T extends org.opendaylight.controller.cluster.datastore.ShardDataTreeNotificationPublisher> - Class in org.opendaylight.controller.cluster.datastore
Actor used to generate and publish data tree notifications.
ShardDataTreeNotificationPublisherActor(T, String, String) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardDataTreeNotificationPublisherActor
 
ShardDataTreeSnapshot - Class in org.opendaylight.controller.cluster.datastore.persisted
Abstract base class for snapshots of the ShardDataTree.
ShardDataTreeSnapshotMetadata<T extends ShardDataTreeSnapshotMetadata<T>> - Class in org.opendaylight.controller.cluster.datastore.persisted
Base class for various bits of metadata attached to a MetadataShardDataTreeSnapshot.
ShardedDataTreeActor - Class in org.opendaylight.controller.cluster.sharding
Actor that tracks currently open producers/shards on remote nodes and handles notifications of remote nodes of newly open producers/shards on the local node.
ShardedDataTreeActor.ShardedDataTreeActorCreator - Class in org.opendaylight.controller.cluster.sharding
 
ShardedDataTreeActorCreator() - Constructor for class org.opendaylight.controller.cluster.sharding.ShardedDataTreeActor.ShardedDataTreeActorCreator
 
shardElectionTimeoutFactor(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardHeartbeatIntervalInMillis(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ShardIdentifier - Class in org.opendaylight.controller.cluster.datastore.identifiers
 
ShardIdentifier.Builder - Class in org.opendaylight.controller.cluster.datastore.identifiers
 
ShardInformation - Class in org.opendaylight.controller.cluster.datastore.shardmanager
 
ShardingServiceAddressResolver - Class in org.opendaylight.controller.cluster.sharding
Resolver for remote ShardedDataTreeActor's.
ShardingServiceAddressResolver(String, MemberName) - Constructor for class org.opendaylight.controller.cluster.sharding.ShardingServiceAddressResolver
 
shardInitializationTimeout(long, TimeUnit) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardInitializationTimeoutInSeconds(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardIsolatedLeaderCheckIntervalInMillis(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardJournalRecoveryLogBatchSize(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ShardKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards
 
ShardKey(ShardKey) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardKey
Creates a copy from Source Object.
ShardKey(InstanceIdentifier<?>) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardKey
 
shardLeaderElectionTimeout(long, TimeUnit) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardLeaderElectionTimeoutInSeconds(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ShardLeaderNotRespondingException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
Exception indicating a shard leader is not responding to messages.
ShardLeaderNotRespondingException(String, Throwable) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.ShardLeaderNotRespondingException
 
ShardLeaderStateChanged - Class in org.opendaylight.controller.cluster.datastore.messages
A local message derived from LeaderStateChanged containing additional Shard-specific info that is sent when some state of the shard leader has changed.
ShardLeaderStateChanged(String, String, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ShardLeaderStateChanged
 
ShardLeaderStateChanged(String, String, ReadOnlyDataTree, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ShardLeaderStateChanged
 
ShardManagerCreator - Class in org.opendaylight.controller.cluster.datastore.shardmanager
 
ShardManagerCreator() - Constructor for class org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerCreator
 
ShardManagerIdentifier - Class in org.opendaylight.controller.cluster.datastore.identifiers
 
ShardManagerIdentifier(String) - Constructor for class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier
 
ShardManagerIdentifier.Builder - Class in org.opendaylight.controller.cluster.datastore.identifiers
 
ShardManagerInfoMBean - Interface in org.opendaylight.controller.cluster.datastore.shardmanager
 
shardManagerPersistenceId(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
For unit tests only.
ShardManagerSnapshot - Class in org.opendaylight.controller.cluster.datastore.persisted
Represents the persisted snapshot state for the ShardManager.
ShardManagerSnapshot - Class in org.opendaylight.controller.cluster.datastore.shardmanager
Deprecated, for removal: This API element is subject to removal in a future version.
ShardManagerSnapshot(List<String>, Map<DOMDataTreeIdentifier, PrefixShardConfiguration>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.ShardManagerSnapshot
 
ShardMBeanFactory - Class in org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard
Factory for creating ShardStats mbeans.
shardName(String) - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier.Builder
 
ShardOperationResult - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
shardPeerAddressResolver(PeerAddressResolver) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ShardReadTransaction - Class in org.opendaylight.controller.cluster.datastore
Actor for a shard read transaction.
ShardReadTransaction(AbstractShardDataTreeTransaction<?>, ActorRef, ShardStats) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardReadTransaction
 
ShardReadWriteTransaction - Class in org.opendaylight.controller.cluster.datastore
Actor for a shard read/write transaction.
ShardReadWriteTransaction(ReadWriteShardDataTreeTransaction, ActorRef, ShardStats) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardReadWriteTransaction
 
ShardResult - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output
The list of results, one per shard
ShardResult1 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output
 
ShardResult1Builder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output
Class that builds ShardResult1Builder instances.
ShardResult1Builder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1Builder
 
ShardResult1Builder(ShardResult1) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.ShardResult1Builder
 
ShardResultBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output
Class that builds ShardResultBuilder instances.
ShardResultBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
ShardResultBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
ShardResultBuilder(ShardResult) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
ShardResultBuilder(ShardOperationResult) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
ShardResultKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output
 
ShardResultKey(DataStoreType, String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultKey
 
ShardResultKey(ShardResultKey) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultKey
Creates a copy from Source Object.
ShardResultOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
This class represents the following YANG schema fragment defined in module cluster-admin
ShardSnapshot(String, Snapshot) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot.ShardSnapshot
 
ShardSnapshotActor - Class in org.opendaylight.controller.cluster.datastore.actors
This is an offload actor, which is given an isolated snapshot of the data tree.
shardSnapshotBatchCount(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardSnapshotChunkSize(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
Deprecated.
shardSnapshotDataThreshold(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardSnapshotDataThresholdPercentage(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ShardSnapshotState - Class in org.opendaylight.controller.cluster.datastore.persisted
Encapsulates the snapshot State for a Shard.
ShardSnapshotState(ShardDataTreeSnapshot) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.ShardSnapshotState
 
ShardSnapshotState(ShardDataTreeSnapshot, boolean) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.ShardSnapshotState
 
ShardStats - Class in org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard
Maintains statistics for a shard.
ShardStats(String, String, Shard) - Constructor for class org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStats
 
ShardStatsMXBean - Interface in org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard
MXBean interface for shard stats.
shardStrategy(ShardStrategy) - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig.Builder
 
ShardStrategy - Interface in org.opendaylight.controller.cluster.datastore.shardstrategy
The role of ShardStrategy is to figure out which shards a given piece of data belongs to.
ShardStrategyFactory - Class in org.opendaylight.controller.cluster.datastore.shardstrategy
 
ShardStrategyFactory(Configuration, LogicalDatastoreType) - Constructor for class org.opendaylight.controller.cluster.datastore.shardstrategy.ShardStrategyFactory
 
ShardTransaction - Class in org.opendaylight.controller.cluster.datastore
The ShardTransaction Actor represents a remote transaction that delegates all actions to DOMDataReadWriteTransaction.
ShardTransaction(ActorRef, ShardStats, TransactionIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardTransaction
 
shardTransactionCommitQueueCapacity(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardTransactionCommitTimeoutInSeconds(int) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardTransactionIdleTimeout(long, TimeUnit) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
shardTransactionIdleTimeoutInMinutes(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
ShardWriteTransaction - Class in org.opendaylight.controller.cluster.datastore
Actor for a shard write-only transaction.
ShardWriteTransaction(ReadWriteShardDataTreeTransaction, ActorRef, ShardStats) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
 
SharedFileBackedOutputStream - Class in org.opendaylight.controller.cluster.io
A FileBackedOutputStream that allows for sharing in that it maintains a usage count and the backing file isn't deleted until the usage count reaches 0.
SharedFileBackedOutputStream(int, String) - Constructor for class org.opendaylight.controller.cluster.io.SharedFileBackedOutputStream
 
shortValue() - Method in enum org.opendaylight.controller.cluster.access.ABIVersion
Return the unsigned short integer identifying this version.
shortValue() - Method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Return the unsigned short integer identifying this version.
shouldCaptureSnapshot(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Determines if a snapshot should be captured based on the count/memory consumed.
shouldUpdateTerm(RaftRPC) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
shutdown() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
 
shutdown() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
Deprecated.
Shutdown - Class in org.opendaylight.controller.cluster.raft.client.messages
Message sent to a raft actor to shutdown gracefully.
shutdownGracefully() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
shutdownGracefully(long, long, TimeUnit) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
shutdownNow() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
simple() - Static method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
 
SIMPLE - org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
Simple commit protocol.
SimpleDataStoreClientActor - Class in org.opendaylight.controller.cluster.databroker.actors.dds
A AbstractClientActor which acts as the point of contact for DistributedDataStore.
SimpleReplicatedLogEntry - Class in org.opendaylight.controller.cluster.raft.persisted
A ReplicatedLogEntry implementation.
SimpleReplicatedLogEntry(long, long, Payload) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
Constructs an instance.
SimpleReplicatedLogEntrySerializer - Class in org.opendaylight.controller.cluster.raft.persisted
Specialized serializer for SimpleReplicatedLogEntry that optimizes serialization.
SimpleReplicatedLogEntrySerializer(ExtendedActorSystem) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntrySerializer
 
size() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequestBuilder
 
size() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
 
size() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
size() - Method in class org.opendaylight.controller.cluster.raft.persisted.NoopPayload
 
size() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
 
size() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
size() - Method in class org.opendaylight.controller.cluster.raft.protobuff.client.messages.Payload
 
size() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Returns the number of entries in the journal.
size() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
Returns the size of the entry in bytes.
size() - Method in class org.opendaylight.controller.remote.rpc.registry.AbstractRoutingTable
 
slice(SliceOptions) - Method in class org.opendaylight.controller.cluster.messaging.MessageSlicer
Slices a message into chunks based on the serialized size, the maximum message slice size and the given options.
SliceableMessage - Interface in org.opendaylight.controller.cluster.access.concepts
A tagging interface that specifies a message whose serialized size can be large and thus should be sliced into smaller chunks when transporting over the wire.
SlicedMessageState<T> - Class in org.opendaylight.controller.cluster.messaging
Maintains the state of a sliced message.
SlicedMessageState(Identifier, FileBackedOutputStream, int, int, T, Consumer<Throwable>, String) - Constructor for class org.opendaylight.controller.cluster.messaging.SlicedMessageState
Constructor.
SliceOptions - Class in org.opendaylight.controller.cluster.messaging
Options for slicing a message with MessageSlicer.slice(SliceOptions).
SliceOptions.Builder - Class in org.opendaylight.controller.cluster.messaging
 
Snapshot - Class in org.opendaylight.controller.cluster.raft.persisted
Represents a snapshot of the raft data.
Snapshot.State - Interface in org.opendaylight.controller.cluster.raft.persisted
Implementations of this interface are used as the state payload for a snapshot.
snapshotCommit() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Sets the Replicated log to state after snapshot success.
snapshotCommit(boolean) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
snapshotCommit(boolean) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Sets the Replicated log to state after snapshot success.
SnapshotComplete - Class in org.opendaylight.controller.cluster.raft.base.messages
Internal message sent when a snapshot capture is complete.
snapshotIndex(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
SnapshotManager - Class in org.opendaylight.controller.cluster.raft
Manages the capturing of snapshots for a RaftActor.
SnapshotManager(RaftActorContext, Logger) - Constructor for class org.opendaylight.controller.cluster.raft.SnapshotManager
Constructs an instance.
snapshotOnRootOverwrite(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
snapshotPreCommit(long, long) - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
snapshotPreCommit(long, long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Handles all the bookkeeping in order to perform a rollback in the event of SaveSnapshotFailure.
snapshotRollback() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
 
snapshotRollback() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
Restores the replicated log to a state in the event of a save snapshot failure.
snapshotSequenceNr() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
SnapshotState - Interface in org.opendaylight.controller.cluster.raft
Interface for a snapshot phase state.
snapshotTerm(long) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
SODIUM_SR1 - org.opendaylight.controller.cluster.access.ABIVersion
Revised ABI version.
SODIUM_SR1 - org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Revised payload version.
SODIUM_SR1_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
 
start() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProvider
 
StartConfigShardLookup - Class in org.opendaylight.controller.cluster.sharding.messages
Message that should be sent to ShardedDataTreeActor when the lookup of the prefix config shard should begin.
StartConfigShardLookup(LogicalDatastoreType) - Constructor for class org.opendaylight.controller.cluster.sharding.messages.StartConfigShardLookup
 
startLogRecoveryBatch(int) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorRecoveryCohort
This method is called during recovery at the start of a batch of state entries.
state() - Method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState.Builder
 
state() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
state() - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
Returns the state associated with this behavior.
state() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
state() - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.Builder
 
stop() - Method in class org.opendaylight.controller.config.yang.netty.timer.HashedWheelTimerCloseable
 
stop() - Method in class org.opendaylight.controller.config.yang.netty.timer.OSGiGlobalTimer
 
stopElection() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Stops the currently scheduled election.
storeRoot(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
submit(Runnable) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
submit(Runnable, T) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
submit(Callable<T>) - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
subscribeToMemberEvents(ActorRef) - Method in interface org.opendaylight.controller.cluster.datastore.ClusterWrapper
 
subscribeToMemberEvents(ActorRef) - Method in class org.opendaylight.controller.cluster.datastore.ClusterWrapperImpl
 
success() - Method in class org.opendaylight.controller.cluster.datastore.TransactionRateLimitingCallback
 
success(Identifier, int, ActorRef) - Static method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
 
SuccessEnvelope - Class in org.opendaylight.controller.cluster.access.concepts
 
SuccessEnvelope(RequestSuccess<?, ?>, long, long, long) - Constructor for class org.opendaylight.controller.cluster.access.concepts.SuccessEnvelope
 
SuccessReply - Class in org.opendaylight.controller.cluster.datastore.messages
A reply message indicating success.
supervisorStrategy() - Method in class org.opendaylight.controller.remote.rpc.OpsManager
 
SupportType - Enum in org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819
 
switchAllLocalShardsState(String, long) - Method in interface org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerInfoMBean
Switches the raft behavior of all the local shards to the newBehavior.
switchBehavior(RaftActorBehavior) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
 
switchBehavior(RaftActorBehavior) - Method in interface org.opendaylight.controller.cluster.raft.behaviors.RaftActorBehavior
Closes the current behavior and switches to the specified behavior, if possible.
SwitchBehavior - Class in org.opendaylight.controller.cluster.raft.base.messages
 
SwitchBehavior(RaftState, long) - Constructor for class org.opendaylight.controller.cluster.raft.base.messages.SwitchBehavior
 
switchShardState(String, String, long) - Method in interface org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerInfoMBean
Switches the raft behavior of the shard specified by shardName to the newBehavior.
syncIndexThreshold(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
SyncStatusTracker - Class in org.opendaylight.controller.cluster.raft.behaviors
The SyncStatusTracker tracks if a Follower is in sync with any given Leader or not When an update is received from the Leader and the update happens to be the first update from that Leader then the SyncStatusTracker will not mark the Follower as not in-sync till the Followers commitIndex matches the commitIndex that the Leader sent in it's very first update.
SyncStatusTracker(ActorRef, String, long) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.SyncStatusTracker
 

T

TAG_ACTION_REGISTRY_NAME - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_ACTION_REGISTRY_PATH - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_ACTOR_SYSTEM_NAME - Static variable in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
TAG_ASK_DURATION - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_MAILBOX - Static variable in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
TAG_MAILBOX_CAPACITY - Static variable in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
TAG_MAILBOX_PUSH_TIMEOUT - Static variable in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
TAG_METRIC_CAPTURE_ENABLED - Static variable in class org.opendaylight.controller.cluster.common.actor.CommonConfig
 
TAG_RPC_BROKER_NAME - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_RPC_BROKER_PATH - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_RPC_MGR_NAME - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_RPC_MGR_PATH - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_RPC_REGISTRAR_NAME - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_RPC_REGISTRY_NAME - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
TAG_RPC_REGISTRY_PATH - Static variable in class org.opendaylight.controller.remote.rpc.RemoteOpsProviderConfig
 
takeSnapshot() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractClientHistory
Create a new ClientSnapshot.
tempFileDirectory(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
terminationFuture() - Method in class org.opendaylight.controller.config.yang.netty.eventexecutor.OSGiGlobalEventExecutor
 
TerminationMonitor - Class in org.opendaylight.controller.cluster.datastore
 
TerminationMonitor - Class in org.opendaylight.controller.remote.rpc
 
TerminationMonitor() - Constructor for class org.opendaylight.controller.cluster.datastore.TerminationMonitor
 
TerminationMonitor() - Constructor for class org.opendaylight.controller.remote.rpc.TerminationMonitor
 
TEST_FUTURE_VERSION - org.opendaylight.controller.cluster.access.ABIVersion
Version which is newer than any other version.
TEST_FUTURE_VERSION - org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Version which is newer than any other version.
TEST_PAST_VERSION - org.opendaylight.controller.cluster.access.ABIVersion
Version which is older than any other version.
TEST_PAST_VERSION - org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Version which is older than any other version.
TestOnlyRaftPolicy - Class in org.opendaylight.controller.cluster.datastore.policy
A RaftPolicy that disables elections so that we can then specify exactly which Shard Replica should be Leader.
TestOnlyRaftPolicy() - Constructor for class org.opendaylight.controller.cluster.datastore.policy.TestOnlyRaftPolicy
 
ThreadExecutorStats - Class in org.opendaylight.controller.md.sal.common.util.jmx
A bean class that holds various thread executor statistic metrics.
ThreadExecutorStats(long, long, long, long, long, Long, long, long, long, Long) - Constructor for class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStats
 
ThreadExecutorStatsMXBean - Interface in org.opendaylight.controller.md.sal.common.util.jmx
MXBean interface for thread executor statistic metrics.
ThreadExecutorStatsMXBeanImpl - Class in org.opendaylight.controller.md.sal.common.util.jmx
MXBean implementation of the ThreadExecutorStatsMXBean interface that retrieves statistics from a backing ExecutorService.
ThreadExecutorStatsMXBeanImpl(ThreadPoolExecutor, String, String, String) - Constructor for class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
Constructs an instance for the given Executor.
ThreadPool - Interface in org.opendaylight.controller.config.threadpool
Interface representing thread pool.
THREE_PHASE - org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
Three-phase commit protocol (3PC).
ThreePhaseCommitCohortProxy - Class in org.opendaylight.controller.cluster.datastore
ThreePhaseCommitCohortProxy represents a set of remote cohort proxies.
ThreePhaseCommitCohortProxy(ActorUtils, List<ThreePhaseCommitCohortProxy.CohortInfo>, TransactionIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.ThreePhaseCommitCohortProxy
 
tickDuration() - Method in annotation type org.opendaylight.controller.config.yang.netty.timer.OSGiGlobalTimer.Config
 
ticker() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
Return the time ticker for this ClientActorContext.
ticksPerWheel() - Method in annotation type org.opendaylight.controller.config.yang.netty.timer.OSGiGlobalTimer.Config
 
TIMEOUT - org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
For an AddServer request, the leader timed out trying to install a snapshot on the new server.
TimeoutException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
 
TimeoutException(String, Exception) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.TimeoutException
 
TimeoutNow - Class in org.opendaylight.controller.cluster.raft.base.messages
Message sent to a follower to force an immediate election time out.
toBinary(Object) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
 
toBinary(Object) - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntrySerializer
 
toFile(File, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.utils.NormalizedNodeXMLOutput
 
toFile(File, DataTreeModification) - Static method in class org.opendaylight.controller.cluster.datastore.utils.DataTreeModificationOutput
 
toImmutable() - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
toPersistentId() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
TopicDOMNotification - Class in org.opendaylight.controller.messagebus.app.util
 
TopicDOMNotification(ContainerNode) - Constructor for class org.opendaylight.controller.messagebus.app.util.TopicDOMNotification
 
TopicId - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
 
TopicId(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicId
 
TopicId(TopicId) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicId
Creates a copy from Source Object.
TopicNotification - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Notification of an event occuring on a particular node.
TopicNotificationBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202
Class that builds TopicNotificationBuilder instances.
TopicNotificationBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
TopicNotificationBuilder(TopicNotification) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicNotificationBuilder
 
Topology1 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
 
Topology1Builder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
Class that builds Topology1Builder instances.
Topology1Builder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Topology1Builder
 
Topology1Builder(Topology1) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.Topology1Builder
 
TopologyContext - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
This class represents the following YANG schema fragment defined in module opendaylight-topology
TopologyEventSource - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type
This class represents the following YANG schema fragment defined in module event-source
TopologyEventSourceBuilder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type
Class that builds TopologyEventSourceBuilder instances.
TopologyEventSourceBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSourceBuilder
 
TopologyEventSourceBuilder(TopologyEventSource) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.topology.event.source.type.TopologyEventSourceBuilder
 
TopologyEventSourceType - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
This class represents the following YANG schema fragment defined in module event-source
TopologyNodeContext - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030
This class represents the following YANG schema fragment defined in module opendaylight-topology
TopologyTypes1 - Interface in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
 
TopologyTypes1Builder - Class in org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202
Class that builds TopologyTypes1Builder instances.
TopologyTypes1Builder() - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1Builder
 
TopologyTypes1Builder(TopologyEventSourceType) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1Builder
 
TopologyTypes1Builder(TopologyTypes1) - Constructor for class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.TopologyTypes1Builder
 
toRequestFailure(RequestException) - Method in class org.opendaylight.controller.cluster.access.concepts.Request
Return a RequestFailure for this request, caused by a RequestException.
toRequestFailure(RequestException) - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientRequest
 
toRequestFailure(RequestException) - Method in class org.opendaylight.controller.cluster.access.commands.LocalHistoryRequest
 
toRequestFailure(RequestException) - Method in class org.opendaylight.controller.cluster.access.commands.TransactionRequest
 
toScala(Function<ActorRef, T>) - Static method in class org.opendaylight.controller.cluster.common.actor.ExplicitAsk
 
toSerializable() - Method in interface org.opendaylight.controller.cluster.datastore.messages.SerializableMessage
 
toSerializable() - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
toSerializable(short) - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
toShortString() - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
toStream(OutputStream, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.utils.NormalizedNodeXMLOutput
 
toString() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
 
toString() - Method in class org.opendaylight.controller.cluster.access.client.BackendInfo
 
toString() - Method in class org.opendaylight.controller.cluster.access.client.ConnectionEntry
 
toString() - Method in class org.opendaylight.controller.cluster.access.commands.TransactionModification
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.Envelope
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.Message
 
toString() - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
toString() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker.MessageProcessingTime
 
toString() - Method in class org.opendaylight.controller.cluster.databroker.AbstractDOMBrokerTransaction
 
toString() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractClientHandle
 
toString() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.config.PrefixShardConfiguration
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.AddPrefixShardReplica
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.AddShardReplica
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.ChangeShardMembersVotingStatus
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateShard
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.FindPrimary
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.FlipShardMembersVotingStatus
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.LocalPrimaryShardFound
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerDown
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.PeerUp
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemotePrimaryShardFound
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemovePrefixShardReplica
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.RemoveShardReplica
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendShardDataTreeSnapshotMetadata
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.persisted.MetadataShardDataTreeSnapshot
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardManagerSnapshot
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.ShardInformation
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.ShardManagerSnapshot
Deprecated.
 
toString() - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongRangeSet
 
toString() - Method in class org.opendaylight.controller.cluster.messaging.MessageSlice
 
toString() - Method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
 
toString() - Method in class org.opendaylight.controller.cluster.notifications.LeaderStateChanged
 
toString() - Method in class org.opendaylight.controller.cluster.notifications.RoleChanged
 
toString() - Method in class org.opendaylight.controller.cluster.raft.base.messages.ApplyState
 
toString() - Method in class org.opendaylight.controller.cluster.raft.base.messages.CaptureSnapshot
 
toString() - Method in class org.opendaylight.controller.cluster.raft.base.messages.LeaderTransitioning
 
toString() - Method in class org.opendaylight.controller.cluster.raft.base.messages.SwitchBehavior
 
toString() - Method in class org.opendaylight.controller.cluster.raft.behaviors.LeaderInstallSnapshotState
 
toString() - Method in class org.opendaylight.controller.cluster.raft.client.messages.GetSnapshotReply
 
toString() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
 
toString() - Method in class org.opendaylight.controller.cluster.raft.ImmutableElectionTerm
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.AbstractServerChangeReply
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.AddServer
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntriesReply
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.ChangeServersVotingStatus
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshot
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.InstallSnapshotReply
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.RemoveServer
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestLeadership
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestVote
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.RequestVoteReply
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.ServerRemoved
 
toString() - Method in class org.opendaylight.controller.cluster.raft.messages.UnInitializedFollowerSnapshotReply
 
toString() - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
 
toString() - Method in class org.opendaylight.controller.cluster.raft.persisted.ApplyJournalEntries
 
toString() - Method in class org.opendaylight.controller.cluster.raft.persisted.DeleteEntries
 
toString() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
 
toString() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
 
toString() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
 
toString() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
 
toString() - Method in class org.opendaylight.controller.cluster.raft.persisted.UpdateElectionTerm
 
toString() - Method in class org.opendaylight.controller.cluster.sharding.messages.LookupPrefixShard
 
toString() - Method in class org.opendaylight.controller.cluster.sharding.messages.PrefixShardCreated
 
toString() - Method in class org.opendaylight.controller.cluster.sharding.messages.PrefixShardRemovalLookup
 
toString() - Method in class org.opendaylight.controller.cluster.sharding.messages.StartConfigShardLookup
 
toString() - Method in class org.opendaylight.controller.cluster.sharding.PrefixedShardConfigUpdateHandler.ShardConfigHandler
 
toString() - Method in class org.opendaylight.controller.messagebus.app.util.TopicDOMNotification
 
toString() - Method in class org.opendaylight.controller.remote.rpc.messages.AbstractExecute
 
toString() - Method in class org.opendaylight.controller.remote.rpc.registry.AbstractRoutingTable
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.Pattern
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventaggregator.rev141202.TopicId
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorKey
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRef
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierKey
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientGeneration
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.MemberName
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.HeartbeatIntervalType
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.NonZeroUint32Type
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.OperationTimeoutType
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev140612.Percentage
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsKey
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultKey
 
toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardKey
 
toThreadExecutorStats() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
Returns a ThreadExecutorStats instance containing a snapshot of the statistic metrics.
toVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.concepts.Message
Return a message which will end up being serialized in the specified ABIVersion.
toYang() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
toYang() - Method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
Transaction - org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
 
TransactionAbortRequest - Class in org.opendaylight.controller.cluster.access.commands
A transaction request to perform the abort step of the three-phase commit protocol.
TransactionAbortRequest(TransactionIdentifier, long, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionAbortRequest
 
TransactionAbortSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to a coordinated commit request initiated by a ModifyTransactionRequest or CommitLocalTransactionRequest.
TransactionAbortSuccess(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionAbortSuccess
 
TransactionCanCommitSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to a coordinated commit request initiated by a ModifyTransactionRequest or CommitLocalTransactionRequest.
TransactionCanCommitSuccess(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionCanCommitSuccess
 
TransactionCommitSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to a coordinated commit request.
TransactionCommitSuccess(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionCommitSuccess
 
transactionCreationInitialRateLimit(long) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
TransactionDataModification - Class in org.opendaylight.controller.cluster.access.commands
A TransactionModification which has a data component.
transactionDebugContextEnabled(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
TransactionDelete - Class in org.opendaylight.controller.cluster.access.commands
Delete a particular path.
TransactionDelete(YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionDelete
 
TransactionDoCommitRequest - Class in org.opendaylight.controller.cluster.access.commands
A transaction request to perform the final, doCommit, step of the three-phase commit protocol.
TransactionDoCommitRequest(TransactionIdentifier, long, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionDoCommitRequest
 
TransactionFailure - Class in org.opendaylight.controller.cluster.access.commands
Generic RequestFailure involving a TransactionRequest.
TransactionIdentifier - Class in org.opendaylight.controller.cluster.access.concepts
Globally-unique identifier of a transaction.
TransactionIdentifier(LocalHistoryIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
TransactionMerge - Class in org.opendaylight.controller.cluster.access.commands
Merge a NormalizedNode tree onto a specific path.
TransactionMerge(YangInstanceIdentifier, NormalizedNode<?, ?>) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionMerge
 
TransactionModification - Class in org.opendaylight.controller.cluster.access.commands
An individual modification of a transaction's state.
TransactionPreCommitRequest - Class in org.opendaylight.controller.cluster.access.commands
A transaction request to perform the second, preCommit, step of the three-phase commit protocol.
TransactionPreCommitRequest(TransactionIdentifier, long, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionPreCommitRequest
 
TransactionPreCommitSuccess - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to a TransactionPreCommitRequest.
TransactionPreCommitSuccess(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionPreCommitSuccess
 
TransactionProxy - Class in org.opendaylight.controller.cluster.datastore
A transaction potentially spanning multiple backend shards.
TransactionProxy(AbstractTransactionContextFactory<?>, TransactionType) - Constructor for class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
TransactionPurgeRequest - Class in org.opendaylight.controller.cluster.access.commands
A transaction request to perform the final transaction transition, which is purging it from the protocol view, meaning the frontend has no further knowledge of the transaction.
TransactionPurgeRequest(TransactionIdentifier, long, ActorRef) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionPurgeRequest
 
TransactionPurgeResponse - Class in org.opendaylight.controller.cluster.access.commands
Successful reply to a TransactionPurgeRequest.
TransactionPurgeResponse(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionPurgeResponse
 
TransactionRateLimiter - Class in org.opendaylight.controller.cluster.datastore.utils
 
TransactionRateLimiter(ActorUtils) - Constructor for class org.opendaylight.controller.cluster.datastore.utils.TransactionRateLimiter
 
TransactionRateLimitingCallback - Class in org.opendaylight.controller.cluster.datastore
TransactionRateLimitingCallback computes the new transaction rate limit on the successful completion of a transaction.
TransactionReadyReplyMapper - Class in org.opendaylight.controller.cluster.datastore
A Mapper extracting the ActorSelection pointing to the actor which is backing a particular transaction.
TransactionReadyReplyMapper(ActorUtils, TransactionIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.TransactionReadyReplyMapper
 
TransactionRequest<T extends TransactionRequest<T>> - Class in org.opendaylight.controller.cluster.access.commands
Abstract base class for Requests involving specific transaction.
TransactionSuccess<T extends TransactionSuccess<T>> - Class in org.opendaylight.controller.cluster.access.commands
Abstract base class for RequestSuccesses involving specific transaction.
TransactionType - Enum in org.opendaylight.controller.cluster.datastore
 
TransactionWrite - Class in org.opendaylight.controller.cluster.access.commands
Modification to write (and replace) a subtree at specified path with another subtree.
TransactionWrite(YangInstanceIdentifier, NormalizedNode<?, ?>) - Constructor for class org.opendaylight.controller.cluster.access.commands.TransactionWrite
 
transferComplete() - Method in class org.opendaylight.controller.cluster.raft.RaftActorLeadershipTransferCohort
This method is invoked when leadership transfer was carried out and complete.
transferLeadership(RaftActorLeadershipTransferCohort) - Method in class org.opendaylight.controller.cluster.raft.behaviors.Leader
Attempts to transfer leadership to a follower as per the raft paper (§3.10) as follows: Start a timer (Stopwatch). Send an initial AppendEntries heartbeat to all followers. On AppendEntriesReply, check if the follower's new match Index matches the leader's last index If it matches, Send an additional AppendEntries to ensure the follower has applied all its log entries to its state. Send an ElectionTimeout to the follower to immediately start an election. Notify RaftActorLeadershipTransferCohort.transferComplete(). Otherwise if the election time out period elapses, notify RaftActorLeadershipTransferCohort.abortTransfer().
transformReadyReply(Future<Object>) - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
treeChangeListenerActors(Collection<ActorSelection>) - Method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState.Builder
 
trimLog(long) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
 
trimLog(long) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
Trims the in-memory log.
TwoNodeClusterRaftPolicy - Class in org.opendaylight.controller.cluster.datastore.policy
The TwoNodeClusterRaftPolicy is intended to be used in a two node deployment where when one instance of the controller goes down the other instance is to take over and move the state forward.
TwoNodeClusterRaftPolicy() - Constructor for class org.opendaylight.controller.cluster.datastore.policy.TwoNodeClusterRaftPolicy
 
TXN_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
 
type(String) - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier.Builder
 
type(String) - Method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardManagerIdentifier.Builder
 

U

UnboundedDequeBasedControlAwareMailbox - Class in org.opendaylight.controller.cluster.common.actor
An unbounded ControlAwareMailbox that also supports DequeBasedMessageQueueSemantics so it can be used with persistent actors which use stashing.
UnboundedDequeBasedControlAwareMailbox(ActorSystem.Settings, Config) - Constructor for class org.opendaylight.controller.cluster.common.actor.UnboundedDequeBasedControlAwareMailbox
 
UnifiedConfig - Interface in org.opendaylight.controller.cluster.common.actor
Represents a unified view of configuration.
UnInitializedFollowerSnapshotReply - Class in org.opendaylight.controller.cluster.raft.messages
Local message sent to self on receiving the InstallSnapshotReply from a follower indicating that the catch up of the follower has completed successfully for an AddServer operation.
UnInitializedFollowerSnapshotReply(String) - Constructor for class org.opendaylight.controller.cluster.raft.messages.UnInitializedFollowerSnapshotReply
 
UNKNOWN - org.opendaylight.controller.cluster.dom.api.LeaderLocation
The leader is residence is currently unknown.
UNKNOWN_DATA_STORE_TYPE - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
 
UnknownHistoryException - Exception in org.opendaylight.controller.cluster.access.commands
A RequestException indicating that the backend has received a request referencing an unknown history.
UnknownHistoryException(Long) - Constructor for exception org.opendaylight.controller.cluster.access.commands.UnknownHistoryException
 
unknownMessage(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
 
unknownMessage(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
 
UnknownMessageException - Exception in org.opendaylight.controller.cluster.datastore.exceptions
 
UnknownMessageException(Object) - Constructor for exception org.opendaylight.controller.cluster.datastore.exceptions.UnknownMessageException
 
unlockWrite(long) - Method in class org.opendaylight.controller.cluster.access.client.InversibleLock
 
unpauseLeader() - Method in class org.opendaylight.controller.cluster.datastore.Shard
 
unpauseLeader() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
This method is invoked when the actions hooked to the leader becoming paused failed to execute and the leader should resume normal operations.
unregister() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
This method is a wrapper for unregisterMBean with void return type so it can be invoked by dependency injection frameworks such as Spring and Blueprint.
unRegister(EventSource) - Method in class org.opendaylight.controller.messagebus.app.impl.EventSourceTopology
 
unregisterMBean() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
Unregisters this bean with the platform MBean server.
UnsignedLongRangeSet - Class in org.opendaylight.controller.cluster.datastore.utils
Utility RangeSet-like class, specialized for holding UnsignedLong.
UnsupportedRequestException - Exception in org.opendaylight.controller.cluster.access.concepts
General error raised when the recipient of a Request determines that it does not know how to handle the request.
UnsupportedRequestException(Request<?, ?>) - Constructor for exception org.opendaylight.controller.cluster.access.concepts.UnsupportedRequestException
 
unwrap() - Method in exception org.opendaylight.controller.cluster.access.concepts.RequestException
Unwraps the underlying failure.
unwrap() - Method in exception org.opendaylight.controller.cluster.access.concepts.RuntimeRequestException
 
Up - org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
 
update(long, String) - Method in interface org.opendaylight.controller.cluster.raft.ElectionTerm
This method updates the in-memory election term state.
update(long, String) - Method in class org.opendaylight.controller.cluster.raft.ImmutableElectionTerm
 
update(String, long, long) - Method in class org.opendaylight.controller.cluster.raft.behaviors.SyncStatusTracker
 
update(Map<String, Object>) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextIntrospector
Applies the given properties to the cached DatastoreContext and yields a new DatastoreContext instance which can be obtained via DatastoreContextIntrospector.getContext().
update(Map<String, Object>) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextPropertiesUpdater
 
UpdateActions(Collection<DOMActionInstance>, Collection<DOMActionInstance>) - Constructor for class org.opendaylight.controller.remote.rpc.registry.ActionRegistry.Messages.UpdateActions
 
updateAndPersist(long, String) - Method in interface org.opendaylight.controller.cluster.raft.ElectionTerm
This method updates the in-memory election term state and persists it so it can be recovered on next restart.
updateAndPersist(long, String) - Method in class org.opendaylight.controller.cluster.raft.ImmutableElectionTerm
 
updateConfigParams(ConfigParams) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
 
UpdateElectionTerm - Class in org.opendaylight.controller.cluster.raft.persisted
Message class to persist election term information.
UpdateElectionTerm(long, String) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.UpdateElectionTerm
 
updateLocalBucket(T) - Method in class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreActor
 
updateMinReplicaCount() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractLeader
 
updatePeerIds(ServerConfigurationPayload) - Method in interface org.opendaylight.controller.cluster.raft.RaftActorContext
Updates the peers and information to match the given ServerConfigurationPayload.
updatePeerIds(ServerConfigurationPayload) - Method in class org.opendaylight.controller.cluster.raft.RaftActorContextImpl
 
UpdateRemoteActionEndpoints(Map<Address, Optional<ActionRegistry.RemoteActionEndpoint>>) - Constructor for class org.opendaylight.controller.remote.rpc.registry.ActionRegistry.Messages.UpdateRemoteActionEndpoints
 
UpdateRemoteEndpoints(Map<Address, Optional<RpcRegistry.RemoteRpcEndpoint>>) - Constructor for class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.Messages.UpdateRemoteEndpoints
 
UpdateSchemaContext - Class in org.opendaylight.controller.cluster.datastore.messages
 
UpdateSchemaContext(EffectiveModelContext) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.UpdateSchemaContext
 
useLz4Compression(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
usesOperationLimiting() - Method in class org.opendaylight.controller.cluster.datastore.RemoteTransactionContext
 
useTellBasedProtocol(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
Util - Class in org.opendaylight.controller.messagebus.app.util
 

V

validate(long) - Method in class org.opendaylight.controller.cluster.access.client.InversibleLock
 
valueOf(short) - Static method in enum org.opendaylight.controller.cluster.access.ABIVersion
Return the ABIVersion corresponding to an unsigned short integer.
valueOf(short) - Static method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Return the PayloadVersion corresponding to an unsigned short integer.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.access.ABIVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.datastore.TransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.dom.api.LeaderLocation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.raft.RaftState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.cluster.raft.VotingState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.opendaylight.controller.cluster.access.ABIVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.datastore.TransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.dom.api.LeaderLocation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.raft.RaftState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.cluster.raft.VotingState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.EventSourceStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.yang.gen.v1.urn.cisco.params.xml.ns.yang.messagebus.eventsource.rev141202.JoinTopicStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.SupportType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
verify() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
 
verify() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
 
VersionedExternalizableMessage - Class in org.opendaylight.controller.cluster.datastore.messages
Abstract base class for a versioned Externalizable message.
VersionedExternalizableMessage() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
VersionedExternalizableMessage(short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
visitNode(int, String, NormalizedNode<?, ?>) - Method in interface org.opendaylight.controller.cluster.datastore.node.utils.NormalizedNodeVisitor
 
votedFor() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
Returns the id of the candidate that this server voted for in current term.
votedFor(String) - Method in class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
 
VOTING - org.opendaylight.controller.cluster.raft.VotingState
 
VOTING_NOT_INITIALIZED - org.opendaylight.controller.cluster.raft.VotingState
 
VotingState - Enum in org.opendaylight.controller.cluster.raft
Enumerates voting states for a peer.

W

waitTillReady() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
Deprecated.
wildcardToRegex(String) - Static method in class org.opendaylight.controller.messagebus.app.util.Util
CREDIT to http://www.rgagnon.com/javadetails/java-0515.html.
withConfigReader(AkkaConfigurationReader) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractConfig.Builder
 
withKey(NodeConnectorKey) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder
 
withKey(NodeKey) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeBuilder
 
withKey(NodeIdentifierKey) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.model.topology.general.rev131030.node.identifiers.NodeIdentifierBuilder
 
withKey(KnownClientsKey) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.get.known.clients._for.all.shards.output.shard.result.KnownClientsBuilder
 
withKey(ShardResultKey) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
 
withKey(ShardKey) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.clustering.prefix.shard.configuration.rev170110.prefix.shards.ShardBuilder
 
withUintAdaption() - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
 
wrapOutputStream(OutputStream) - Method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
 
write(byte[]) - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
 
write(byte[], int, int) - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
 
write(int) - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
 
write(YangInstanceIdentifier.PathArgument, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
 
write(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
 
write(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.TransactionProxy
 
write(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification.Proactive
 
write(YangInstanceIdentifier, NormalizedNode<?, ?>) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification.Reactive
 
WRITE - Static variable in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
WRITE_ONLY - org.opendaylight.controller.cluster.datastore.TransactionType
 
writeDataTreeCandidate(DataOutput, PayloadVersion, DataTreeCandidate) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput
 
writeDataTreeCandidate(DataOutput, DataTreeCandidate) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.AbstractRequestFailureProxy
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.AbstractRequestProxy
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.EmptyExternalizable
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
writeExternal(ObjectOutput) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.AbstractProxy
 
writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.raft.base.messages.EmptyExternalizableProxy
 
writeLock() - Method in class org.opendaylight.controller.cluster.access.client.InversibleLock
 
WriteModification - Class in org.opendaylight.controller.cluster.datastore.modification
WriteModification stores all the parameters required to write data to the specified path.
WriteModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
WriteModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
WriteModification(YangInstanceIdentifier, NormalizedNode<?, ?>) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 
writeNodeAndPath(DataOutput, YangInstanceIdentifier, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writeNodeAndPath(DataOutput, NormalizedNodeStreamVersion, YangInstanceIdentifier, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writeNormalizedNode(DataOutput, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writeNormalizedNode(DataOutput, NormalizedNodeStreamVersion, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writeOnlyTransactionOptimizationsEnabled(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
 
writePath(DataOutput, YangInstanceIdentifier) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writePath(DataOutput, NormalizedNodeStreamVersion, YangInstanceIdentifier) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writePathAndNode(DataOutput, YangInstanceIdentifier, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writePathAndNode(DataOutput, NormalizedNodeStreamVersion, YangInstanceIdentifier, NormalizedNode<?, ?>) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.stream.SerializationUtils
 
writeReplace() - Method in class org.opendaylight.controller.cluster.access.concepts.Message
 
writeReplace() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
 
writeReplace() - Method in interface org.opendaylight.controller.cluster.raft.persisted.MigratedSerializable
Return a serialization proxy.
writeTo(DataOutput) - Method in enum org.opendaylight.controller.cluster.access.ABIVersion
 
writeTo(DataOutput) - Method in enum org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.ClientIdentifier
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendType
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.LocalHistoryIdentifier
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.MemberName
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
 
writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendHistoryMetadata
 
writeTo(DataOutput) - Method in enum org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
 
writeTo(NormalizedNodeDataOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
 
writeTo(NormalizedNodeDataOutput) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
 
writeTo(NormalizedNodeDataOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
 
writeTo(NormalizedNodeDataOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
 

Y

YangTextSchemaSourceSerializationProxy - Class in org.opendaylight.controller.cluster.schema.provider.impl
YangTextSchemaSource serialization proxy.
YangTextSchemaSourceSerializationProxy(YangTextSchemaSource) - Constructor for class org.opendaylight.controller.cluster.schema.provider.impl.YangTextSchemaSourceSerializationProxy
 
yes(short) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
 
A B C D E F G H I J K L M N O P Q R S T U V W Y 
All Classes All Packages