Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- ABIVersion - Enum Class 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(FutureCallback<Empty>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
- ABORT - Enum constant in enum class org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
-
Abort protocol.
- ABORTED - Enum constant in enum class 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- AbortTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
-
Deprecated.
- AbortTransaction(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
-
Deprecated.
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- AbortTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbortTransactionReply
-
Deprecated.
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- AbstractBatchedModificationsCursor() - Constructor for class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
-
Deprecated.
- AbstractBuilder() - Constructor for class org.opendaylight.controller.cluster.raft.client.messages.OnDemandRaftState.AbstractBuilder
- AbstractCandidateCommand - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
- 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> - Class in org.opendaylight.controller.cluster.access.client
-
Base behavior attached to
AbstractClientActor. - AbstractClientConnection<T> - Class in org.opendaylight.controller.cluster.access.client
-
Base class for a connection to the backend.
- AbstractClientHandle<T> - 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> - 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, 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
DataTreeModificationCursorwhich tracks the current path. - AbstractDataTreeModificationCursor() - Constructor for class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
- AbstractEntityRequest<T> - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- AbstractEntityRequest<T> - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- AbstractExecute<T,
I> - Class in org.opendaylight.controller.remote.rpc.messages -
An abstract base class for invocation requests.
- AbstractIdentifiablePayload<T> - Class in org.opendaylight.controller.cluster.datastore.persisted
-
Abstract base class for
IdentifiablePayloads which hold a singleIdentifier. - AbstractIdentifiablePayload.SerialForm - Interface in org.opendaylight.controller.cluster.datastore.persisted
-
An
Externalizablewith default implementations we expect our implementations to comply with. - 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> - 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- AbstractModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
-
Deprecated.
- AbstractModification(short, YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
-
Deprecated.
- AbstractModification(YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
-
Deprecated.
- 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.
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- AbstractRead() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
-
Deprecated.
- AbstractRead(YangInstanceIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
-
Deprecated.
- 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> - 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
- AbstractResponse<T> - 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,
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> - Class in org.opendaylight.controller.cluster.datastore.shardmanager
- AbstractThreePhaseCommitMessage - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- AbstractThreePhaseCommitMessage() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
-
Deprecated.
- AbstractThreePhaseCommitMessage(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
-
Deprecated.
- 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 Class in org.opendaylight.controller.cluster.access
-
Abstract base exception used for reporting version mismatches from
ABIVersion. - AbstractVersionException - Exception Class 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(ContainerNode, Collection<? extends RpcError>) - Constructor for class org.opendaylight.controller.remote.rpc.messages.ActionResponse
- ActionRoutingTable - Class in org.opendaylight.controller.remote.rpc.registry
- activateDataCenter() - Method in class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- activateDataCenter() - Method in interface org.opendaylight.controller.eos.akka.DataCenterControl
-
Activates the Entity Ownership Service in the datacenter that this method is called.
- ActivateDataCenter - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- ActivateDataCenter(ActorRef<OwnerSupervisorReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.ActivateDataCenter
- ActivateEosDatacenter - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Activates the datacenter that the node this rpc is called on belongs to.
- ActivateEosDatacenterInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
- ActivateEosDatacenterInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Class that builds
ActivateEosDatacenterInputinstances. - ActivateEosDatacenterInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInputBuilder
-
Construct an empty builder.
- ActivateEosDatacenterInputBuilder(ActivateEosDatacenterInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInputBuilder
-
Construct a builder initialized with state from specified
ActivateEosDatacenterInput. - ActivateEosDatacenterOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
- ActivateEosDatacenterOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Class that builds
ActivateEosDatacenterOutputinstances. - ActivateEosDatacenterOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutputBuilder
-
Construct an empty builder.
- ActivateEosDatacenterOutputBuilder(ActivateEosDatacenterOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutputBuilder
-
Construct a builder initialized with state from specified
ActivateEosDatacenterOutput. - actor() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
-
Returns the actor associated with this behavior.
- ActorInitialized - Record Class in org.opendaylight.controller.cluster.datastore.messages
- ActorInitialized(ActorRef) - Constructor for record class org.opendaylight.controller.cluster.datastore.messages.ActorInitialized
-
Creates an instance of a
ActorInitializedrecord class. - 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
- actorRef() - Method in record class org.opendaylight.controller.cluster.datastore.messages.ActorInitialized
-
Returns the value of the
actorRefrecord component. - 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.MutableUnsignedLongSet
- addAll(UnsignedLongSet) - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- addAugmentation(Augmentation<DataStorePropertiesContainer>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<Entities>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<GetEntitiesInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<GetEntitiesOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<GetEntityInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<GetEntityOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<GetEntityOwnerInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<GetEntityOwnerOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<ActivateEosDatacenterInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<ActivateEosDatacenterOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutputBuilder
-
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<DeactivateEosDatacenterInput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInputBuilder
-
Add an augmentation to this builder's product.
- addAugmentation(Augmentation<DeactivateEosDatacenterOutput>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutputBuilder
-
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<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<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.
- 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
-
Deprecated.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
-
Deprecated.
- 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
- AddReplicasForAllShards - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
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
AddReplicasForAllShardsInputinstances. - AddReplicasForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
-
Construct an empty builder.
- AddReplicasForAllShardsInputBuilder(AddReplicasForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
-
Construct a builder initialized with state from specified
AddReplicasForAllShardsInput. - 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
AddReplicasForAllShardsOutputinstances. - AddReplicasForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
-
Construct an empty builder.
- AddReplicasForAllShardsOutputBuilder(AddReplicasForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
-
Construct a builder initialized with state from specified
AddReplicasForAllShardsOutput. - AddReplicasForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
-
Construct a new builder initialized from specified
ShardResultOutput. - 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 - 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 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Adds a replica of a shard to this node and joins it to an existing 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
AddShardReplicaInputinstances. - AddShardReplicaInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
-
Construct an empty builder.
- AddShardReplicaInputBuilder(AddShardReplicaInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
-
Construct a builder initialized with state from specified
AddShardReplicaInput. - AddShardReplicaInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
-
Construct a new builder initialized from specified
DatastoreShardId. - 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
AddShardReplicaOutputinstances. - AddShardReplicaOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
-
Construct an empty builder.
- AddShardReplicaOutputBuilder(AddShardReplicaOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
-
Construct a builder initialized with state from specified
AddShardReplicaOutput. - 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.commands.SkipTransactionsRequest
- 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
- 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.
- AkkaConfigFactory - Class in org.opendaylight.controller.cluster.akka.impl
- AkkaConfigurationReader - Interface in org.opendaylight.controller.cluster.common.actor
- AkkaEntityOwnershipService - Class in org.opendaylight.controller.eos.akka
-
DOMEntityOwnershipService implementation backed by native Akka clustering constructs.
- AkkaEntityOwnershipService(ActorSystem, BindingCodecTree) - Constructor for class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- AkkaEntityOwnershipService(ActorSystemProvider, RpcProviderService, BindingCodecTree) - Constructor for class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- ALREADY_EXISTS - Enum constant in enum class org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
-
For an AddServer request, the server to add already exists.
- AlreadyExistsException - Exception Class in org.opendaylight.controller.cluster.datastore.exceptions
- AlreadyExistsException(String) - Constructor for exception class 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
-
Deprecated.
- apply(DOMStoreReadTransaction) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
-
Deprecated.
- apply(DOMStoreReadTransaction) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
-
Deprecated.
- apply(DOMStoreWriteTransaction) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- apply(DOMStoreWriteTransaction) - Method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
-
Deprecated.
- 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
-
Deprecated.
- apply(DOMStoreWriteTransaction) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- apply(DataTreeModification) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- apply(DataTreeModification) - Method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
-
Deprecated.
- 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
-
Deprecated.
- apply(DataTreeModification) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- 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
- ARGON_VERSION - Static variable in class org.opendaylight.controller.cluster.raft.RaftVersions
- asByteSource() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
-
Returns a readable
ByteSourceview 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 Class in org.opendaylight.controller.cluster.messaging
-
A MessageSliceException indicating the message assembler has already been closed.
- AssemblerClosedException(Identifier) - Constructor for exception class org.opendaylight.controller.cluster.messaging.AssemblerClosedException
-
Constructs an instance.
- AssemblerSealedException - Exception Class in org.opendaylight.controller.cluster.messaging
-
A MessageSliceException indicating the message assembler has already been sealed.
- AssemblerSealedException(String) - Constructor for exception class org.opendaylight.controller.cluster.messaging.AssemblerSealedException
-
Constructs an instance.
- asVersion(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
-
Deprecated.
- asyncClose() - Method in class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- 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
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- 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
-
Return the specified augmentation, if it is present in this builder.
- 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
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- 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
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Return the specified augmentation, if it is present in this builder.
- augmentation(Class<E$$>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
-
Return the specified augmentation, if it is present in this builder.
- 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
-
Return the specified augmentation, if it is present in this builder.
- 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 class org.opendaylight.controller.cluster.access.client.InversibleLockException
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> - 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 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
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
BackupDatastoreInputinstances. - BackupDatastoreInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
Construct an empty builder.
- BackupDatastoreInputBuilder(BackupDatastoreInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
Construct a builder initialized with state from specified
BackupDatastoreInput. - 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
BackupDatastoreOutputinstances. - BackupDatastoreOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
-
Construct an empty builder.
- BackupDatastoreOutputBuilder(BackupDatastoreOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
-
Construct a builder initialized with state from specified
BackupDatastoreOutput. - 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- BatchedModifications() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- BatchedModifications(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- BatchedModificationsReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- BatchedModificationsReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
-
Deprecated.
- BatchedModificationsReply(int) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
-
Deprecated.
- 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
- bindingEquals(DataStorePropertiesContainer, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainer
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetEntitiesInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetEntitiesOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetEntityInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetEntityOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetEntityOwnerInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetEntityOwnerOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(Entities, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.Entities
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ActivateEosDatacenterInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ActivateEosDatacenterOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(AddReplicasForAllShardsInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(AddReplicasForAllShardsOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(AddShardReplicaInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(AddShardReplicaOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(BackupDatastoreInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(BackupDatastoreOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ChangeMemberVotingStatesForAllShardsInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ChangeMemberVotingStatesForAllShardsOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ChangeMemberVotingStatesForShardInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ChangeMemberVotingStatesForShardOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(DeactivateEosDatacenterInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(DeactivateEosDatacenterOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(FlipMemberVotingStatesForAllShardsInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(FlipMemberVotingStatesForAllShardsOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetKnownClientsForAllShardsInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetKnownClientsForAllShardsOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetShardRoleInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(GetShardRoleOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(LocateShardInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(LocateShardOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(MakeLeaderLocalInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(MakeLeaderLocalOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(RemoveAllShardReplicasInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(RemoveAllShardReplicasOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(RemoveShardReplicaInput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(RemoveShardReplicaOutput, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutput
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ShardResult1, Object) - Static 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
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(KnownClients, Object) - Static 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
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(LeaderActorRef, Object) - Static 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
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(Local, Object) - Static 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
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(MemberVotingState, Object) - Static 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
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingEquals(ShardResult, Object) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResult
-
Default implementation of
Object.equals(Object)contract for this interface. - bindingHashCode(DataStorePropertiesContainer) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainer
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetEntitiesInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetEntitiesOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetEntityInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetEntityOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetEntityOwnerInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetEntityOwnerOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(Entities) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.Entities
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ActivateEosDatacenterInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ActivateEosDatacenterOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(AddReplicasForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(AddReplicasForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(AddShardReplicaInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(AddShardReplicaOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(BackupDatastoreInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(BackupDatastoreOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ChangeMemberVotingStatesForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ChangeMemberVotingStatesForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ChangeMemberVotingStatesForShardInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ChangeMemberVotingStatesForShardOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(DeactivateEosDatacenterInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(DeactivateEosDatacenterOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(FlipMemberVotingStatesForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(FlipMemberVotingStatesForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetKnownClientsForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetKnownClientsForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetShardRoleInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(GetShardRoleOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(LocateShardInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(LocateShardOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(MakeLeaderLocalInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(MakeLeaderLocalOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(RemoveAllShardReplicasInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(RemoveAllShardReplicasOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(RemoveShardReplicaInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(RemoveShardReplicaOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutput
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ShardResult1) - Static 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
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(KnownClients) - Static 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
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(LeaderActorRef) - Static 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
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(Local) - Static 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
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(MemberVotingState) - Static 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
-
Default implementation of
Object.hashCode()contract for this interface. - bindingHashCode(ShardResult) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResult
-
Default implementation of
Object.hashCode()contract for this interface. - bindingToString(DataStorePropertiesContainer) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainer
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetEntitiesInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetEntitiesOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetEntityInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetEntityOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetEntityOwnerInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetEntityOwnerOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(Entities) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.Entities
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ActivateEosDatacenterInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ActivateEosDatacenterOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(AddReplicasForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(AddReplicasForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(AddShardReplicaInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(AddShardReplicaOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(BackupDatastoreInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(BackupDatastoreOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ChangeMemberVotingStatesForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ChangeMemberVotingStatesForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ChangeMemberVotingStatesForShardInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ChangeMemberVotingStatesForShardOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(DeactivateEosDatacenterInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(DeactivateEosDatacenterOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(FlipMemberVotingStatesForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(FlipMemberVotingStatesForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetKnownClientsForAllShardsInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetKnownClientsForAllShardsOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetShardRoleInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(GetShardRoleOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(LocateShardInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(LocateShardOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(MakeLeaderLocalInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(MakeLeaderLocalOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(RemoveAllShardReplicasInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(RemoveAllShardReplicasOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(RemoveShardReplicaInput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(RemoveShardReplicaOutput) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutput
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ShardResult1) - Static 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
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(KnownClients) - Static 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
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(LeaderActorRef) - Static 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
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(Local) - Static 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
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(MemberVotingState) - Static 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
-
Default implementation of
Object.toString()contract for this interface. - bindingToString(ShardResult) - Static method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResult
-
Default implementation of
Object.toString()contract for this interface. - BootstrapCommand - Class in org.opendaylight.controller.eos.akka.bootstrap.command
- BORON_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
-
Deprecated.
- BOUNDED_MAILBOX - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
- boundedMailboxCapacity() - Element in annotation interface 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> - Interface in org.opendaylight.controller.remote.rpc.registry.gossip
- 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 Class in org.opendaylight.controller.remote.rpc.registry.gossip
- BucketStoreActor<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.remote.rpc.RemoteOpsProviderConfig.Builder
- build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
A new
DataStorePropertiesContainerinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
A new
Entitiesinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInputBuilder
-
A new
GetEntitiesInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
A new
GetEntitiesOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
A new
GetEntityInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
A new
GetEntityOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
A new
GetEntityOwnerInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
A new
GetEntityOwnerOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInputBuilder
-
A new
ActivateEosDatacenterInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutputBuilder
-
A new
ActivateEosDatacenterOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInputBuilder
-
A new
AddReplicasForAllShardsInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder
-
A new
AddReplicasForAllShardsOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
-
A new
AddShardReplicaInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutputBuilder
-
A new
AddShardReplicaOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
A new
BackupDatastoreInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutputBuilder
-
A new
BackupDatastoreOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
-
A new
ChangeMemberVotingStatesForAllShardsInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
-
A new
ChangeMemberVotingStatesForAllShardsOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
A new
ChangeMemberVotingStatesForShardInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
-
A new
ChangeMemberVotingStatesForShardOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInputBuilder
-
A new
DeactivateEosDatacenterInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutputBuilder
-
A new
DeactivateEosDatacenterOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
-
A new
FlipMemberVotingStatesForAllShardsInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
-
A new
FlipMemberVotingStatesForAllShardsOutputinstance. - 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
-
A new
KnownClientsinstance. - 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
-
A new
ShardResult1instance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
-
A new
GetKnownClientsForAllShardsInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
-
A new
GetKnownClientsForAllShardsOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
A new
GetShardRoleInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
-
A new
GetShardRoleOutputinstance. - 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
-
A new
LeaderActorRefinstance. - 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
-
A new
Localinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
A new
LocateShardInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
-
A new
LocateShardOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
A new
MakeLeaderLocalInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
-
A new
MakeLeaderLocalOutputinstance. - 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
-
A new
MemberVotingStateinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
-
A new
RemoveAllShardReplicasInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
-
A new
RemoveAllShardReplicasOutputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
A new
RemoveShardReplicaInputinstance. - build() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
-
A new
RemoveShardReplicaOutputinstance. - 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
-
A new
ShardResultinstance. - 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
- bytes() - Method in interface org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.SerialForm
-
Return the serial form of this object contents, corresponding to
AbstractIdentifiablePayload.serialized.
C
- callbackPoolSize() - Element in annotation interface org.opendaylight.controller.cluster.databroker.DataBrokerCommitExecutor.Config
- callbackQueueSize() - Element in annotation interface org.opendaylight.controller.cluster.databroker.DataBrokerCommitExecutor.Config
- CAN_COMMIT_COMPLETE - Enum constant in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
- CAN_COMMIT_PENDING - Enum constant in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
- 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(FutureCallback<Empty>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
- CanCommitTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CanCommitTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
-
Deprecated.
- CanCommitTransaction(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
-
Deprecated.
- CanCommitTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CanCommitTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
- candidate() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload.CandidateTransaction
-
Returns the value of the
candidaterecord component. - candidate() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
-
Returns the value of the
candidaterecord component. - Candidate - Class in org.opendaylight.controller.cluster.raft.behaviors
-
The behavior of a RaftActor when it is in the Candidate raft state.
- Candidate - Enum constant in enum class org.opendaylight.controller.cluster.raft.RaftState
- Candidate(RaftActorContext) - Constructor for class org.opendaylight.controller.cluster.raft.behaviors.Candidate
- CandidateCleaner - Class in org.opendaylight.controller.eos.akka.owner.supervisor
-
Actor that can be spawned by all the supervisor implementations that executes clearing of candidates once candidate retrieval succeeds.
- CandidateRegistry - Class in org.opendaylight.controller.eos.akka.registry.candidate
-
Actor responsible for handling registrations of candidates into distributed-data.
- CandidateRegistryCommand - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
- CandidateRegistryInit - Class in org.opendaylight.controller.eos.akka.registry.candidate
- CandidateRegistryInit(ActorContext<CandidateRegistryCommand>, StashBuffer<CandidateRegistryCommand>, ActorRef<OwnerSupervisorCommand>) - Constructor for class org.opendaylight.controller.eos.akka.registry.candidate.CandidateRegistryInit
- CandidateRemovalFailed - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
- CandidateRemovalFailed(Throwable) - Constructor for class org.opendaylight.controller.eos.akka.registry.candidate.command.CandidateRemovalFailed
- CandidateRemovalFinished - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
- CandidateRemovalFinished() - Constructor for class org.opendaylight.controller.eos.akka.registry.candidate.command.CandidateRemovalFinished
- Candidates - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- CandidatesChanged - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- CandidatesChanged - Class in org.opendaylight.controller.eos.akka.registry.listener.type.command
-
Adapted notification from distributed-data sent to EntityTypeListenerActor when candidates change.
- CandidatesChanged(Replicator.SubscribeResponse<ORMap<DOMEntity, ORSet<String>>>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.CandidatesChanged
- CandidatesChanged(Replicator.SubscribeResponse<ORMap<DOMEntity, ORSet<String>>>) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.type.command.CandidatesChanged
- CandidateTransaction(TransactionIdentifier, DataTreeCandidate, NormalizedNodeStreamVersion) - Constructor for record class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload.CandidateTransaction
-
Creates an instance of a
CandidateTransactionrecord class. - 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(RaftEntryMeta, long) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
- capture(RaftEntryMeta, long) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
-
Initiates a capture snapshot.
- 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(RaftEntryMeta) - 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(RaftEntryMeta, long, String) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
- captureToInstall(RaftEntryMeta, 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(RaftEntryMeta, long) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
- captureWithForcedTrim(RaftEntryMeta, long) - Method in interface org.opendaylight.controller.cluster.raft.SnapshotState
-
Initiates a capture snapshot, while enforcing trimming of the log up to lastAppliedIndex.
- castRootNode(NormalizedNode) - Static method in class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather
-
Check whether a
NormalizedNoderepresents a root container and return it cast toContainerNode. - change() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.EntityOwnerChanged
- changeCurrentBehavior(RaftActorBehavior) - Method in class org.opendaylight.controller.cluster.raft.RaftActor
- ChangeMemberVotingStatesForAllShards - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
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
-
Class that builds
ChangeMemberVotingStatesForAllShardsInputinstances. - ChangeMemberVotingStatesForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
-
Construct an empty builder.
- ChangeMemberVotingStatesForAllShardsInputBuilder(ChangeMemberVotingStatesForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
-
Construct a builder initialized with state from specified
ChangeMemberVotingStatesForAllShardsInput. - ChangeMemberVotingStatesForAllShardsInputBuilder(MemberVotingStatesInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
-
Construct a new builder initialized from specified
MemberVotingStatesInput. - 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
-
Class that builds
ChangeMemberVotingStatesForAllShardsOutputinstances. - ChangeMemberVotingStatesForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
-
Construct an empty builder.
- ChangeMemberVotingStatesForAllShardsOutputBuilder(ChangeMemberVotingStatesForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
-
Construct a builder initialized with state from specified
ChangeMemberVotingStatesForAllShardsOutput. - ChangeMemberVotingStatesForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
-
Construct a new builder initialized from specified
ShardResultOutput. - ChangeMemberVotingStatesForShard - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Changes the voting states, either voting or non-voting, of cluster members for 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
-
Class that builds
ChangeMemberVotingStatesForShardInputinstances. - ChangeMemberVotingStatesForShardInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Construct an empty builder.
- ChangeMemberVotingStatesForShardInputBuilder(ChangeMemberVotingStatesForShardInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Construct a builder initialized with state from specified
ChangeMemberVotingStatesForShardInput. - ChangeMemberVotingStatesForShardInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Construct a new builder initialized from specified
DatastoreShardId. - ChangeMemberVotingStatesForShardInputBuilder(MemberVotingStatesInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Construct a new builder initialized from specified
MemberVotingStatesInput. - 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
-
Class that builds
ChangeMemberVotingStatesForShardOutputinstances. - ChangeMemberVotingStatesForShardOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
-
Construct an empty builder.
- ChangeMemberVotingStatesForShardOutputBuilder(ChangeMemberVotingStatesForShardOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutputBuilder
-
Construct a builder initialized with state from specified
ChangeMemberVotingStatesForShardOutput. - 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.
- 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.
- checkNotClosed() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- checkSealed() - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
- checkSealed() - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
- CHLORINE_SR2 - Enum constant in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ChunkedByteArray - Class in org.opendaylight.controller.cluster.io
- ChunkedOutputStream - Class in org.opendaylight.controller.cluster.io
-
An
OutputStreamimplementation which collects data is a series ofbyte[]chunks, each of which has a fixed maximum size. - ChunkedOutputStream(int, int) - Constructor for class org.opendaylight.controller.cluster.io.ChunkedOutputStream
- 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).
- ClearCandidates - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- ClearCandidates(Replicator.GetResponse<ORMap<DOMEntity, ORSet<String>>>, ClearCandidatesForMember) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidates
- ClearCandidatesForMember - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
-
Request sent from Candidate registration actors to clear the candidate from all entities.
- ClearCandidatesForMember(ActorRef<ClearCandidatesResponse>, String) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidatesForMember
- ClearCandidatesResponse - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
-
Response sent from OwnerSupervisor to the ClearCandidatesForMember request, notifying the caller that removal has finished.
- ClearCandidatesResponse() - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidatesResponse
- ClearCandidatesUpdateResponse - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- ClearCandidatesUpdateResponse(Replicator.UpdateResponse<ORMap<DOMEntity, ORSet<String>>>, ActorRef<ClearCandidatesResponse>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidatesUpdateResponse
- 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.
- Client - Enum constant in enum class org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
- CLIENT_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
- clientActor() - Method in record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Returns the value of the
clientActorrecord component. - clientActor() - Method in record class org.opendaylight.controller.cluster.raft.ClientRequestTracker
-
Returns the value of the
clientActorrecord component. - ClientActorBehavior<T> - 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
-
This class represents the following YANG schema fragment defined in module odl-controller-cds-types
- 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
- clientId() - Method in class org.opendaylight.controller.cluster.datastore.persisted.FrontendClientMetadata
- 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 - Record Class in org.opendaylight.controller.cluster.raft
-
Consensus forwarding tracker.
- ClientRequestTracker(long, ActorRef, Identifier) - Constructor for record class org.opendaylight.controller.cluster.raft.ClientRequestTracker
-
Creates an instance of a
ClientRequestTrackerrecord class. - 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.SkipTransactionsRequest
- cloneAsVersion(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.SkipTransactionsResponse
- 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.actors.dds.ClientLocalHistory
- close() - Method in interface org.opendaylight.controller.cluster.databroker.actors.dds.DataStoreClient
- close() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- close() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
- close() - Method in class org.opendaylight.controller.cluster.datastore.ReadWriteShardDataTreeTransaction
-
Close this transaction and mark it as closed, allowing idempotent invocations.
- close() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContextPropertiesUpdater
- close() - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- close() - Method in class org.opendaylight.controller.cluster.datastore.util.AbstractDataTreeModificationCursor
- close() - Method in class org.opendaylight.controller.cluster.io.ChunkedOutputStream
- 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.eos.akka.AkkaEntityOwnershipService
- close() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProvider
- close(FiniteDuration) - Method in class org.opendaylight.controller.cluster.akka.impl.ActorSystemProviderImpl
- CloseDataTreeNotificationListenerRegistration - Class in org.opendaylight.controller.cluster.datastore.messages
- CloseDataTreeNotificationListenerRegistrationReply - Class in org.opendaylight.controller.cluster.datastore.messages
- ClosedTransactionException - Exception Class in org.opendaylight.controller.cluster.access.commands
-
A
RequestExceptionindicating 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 viaClosedTransactionException.isSuccessful(). - ClosedTransactionException(boolean) - Constructor for exception class 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.
- closestVersion() - Method in exception class org.opendaylight.controller.cluster.access.AbstractVersionException
-
Return the closest version supported by this codebase.
- CloseTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CloseTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransaction
-
Deprecated.
- CloseTransaction(short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransaction
-
Deprecated.
- CloseTransactionChain - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CloseTransactionChain() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
-
Deprecated.
- CloseTransactionChain(LocalHistoryIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
-
Deprecated.
- CloseTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CloseTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionReply
-
Deprecated.
- cluster(ClusterWrapper) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
- ClusterAdminData - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
This module contains YANG RPC definitions for administering a cluster.
- ClusterAdminRpcService - Class in org.opendaylight.controller.cluster.datastore.admin
-
Implements the yang RPCs defined in the generated ClusterAdminService interface.
- ClusterAdminRpcService(DistributedDataStoreInterface, DistributedDataStoreInterface, DataCenterControl) - Constructor for class org.opendaylight.controller.cluster.datastore.admin.ClusterAdminRpcService
- 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(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, DOMStoreThreePhaseCommitCohort) - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- COMMIT - Static variable in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
- COMMIT_PENDING - Enum constant in enum class 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.
- COMMITTED - Enum constant in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
- CommitTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CommitTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
-
Deprecated.
- CommitTransaction(TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
-
Deprecated.
- CommitTransactionPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
-
Payload persisted when a transaction commits.
- CommitTransactionPayload.CandidateTransaction - Record Class in org.opendaylight.controller.cluster.datastore.persisted
- CommitTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CommitTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
-
Deprecated.
- CommonConfig - Class in org.opendaylight.controller.cluster.common.actor
- CommonConfig(Config) - Constructor for class org.opendaylight.controller.cluster.common.actor.CommonConfig
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- 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
- ConcurrentDOMDataBroker(DataBrokerCommitExecutor, DOMStore, DOMStore) - Constructor for class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- config() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
- Config - Enum constant in enum class 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
RequestFailurereported whenConnectClientRequestfails. - 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> - Class in org.opendaylight.controller.cluster.access.client
-
A connected connection.
- ConnectingClientConnection<T> - 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.
- container() - Method in record class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather.ShardContainer
-
Returns the value of the
containerrecord component. - contains(long) - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- contains(long) - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- 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
AbstractClientActorContextassociated with thisAbstractClientActor. - context() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
- convertSnapshot(ByteSource) - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
- cookie() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
- copyOf(Map<UnsignedLong, Boolean>) - Static method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- copyOf(ElectionTerm) - Static method in class org.opendaylight.controller.cluster.raft.ImmutableElectionTerm
- copyTo(ByteSink) - Method in class org.opendaylight.controller.cluster.io.ChunkedByteArray
- copyTo(DataOutput) - Method in class org.opendaylight.controller.cluster.io.ChunkedByteArray
- create() - Static method in class org.opendaylight.controller.eos.akka.owner.supervisor.CandidateCleaner
- create() - Static method in class org.opendaylight.controller.eos.akka.registry.candidate.CandidateRegistry
- create(ActorRef<OwnerSupervisorCommand>) - Static method in class org.opendaylight.controller.eos.akka.registry.candidate.CandidateRegistryInit
- create(ActorRef<OwnerSupervisorCommand>, BindingInstanceIdentifierCodec) - Static method in class org.opendaylight.controller.eos.akka.owner.checker.EntityRpcHandler
- create(ActorRef<OwnerSupervisorReply>, BindingInstanceIdentifierCodec) - Static method in class org.opendaylight.controller.eos.akka.owner.supervisor.OwnerSyncer
- create(String) - Static method in class org.opendaylight.controller.eos.akka.registry.listener.type.EntityTypeListenerRegistry
- create(String, ActorRef<OwnerSupervisorCommand>, BindingInstanceIdentifierCodec) - Static method in class org.opendaylight.controller.eos.akka.owner.checker.OwnerStateChecker
- create(String, String, DOMEntityOwnershipListener) - Static method in class org.opendaylight.controller.eos.akka.registry.listener.type.EntityTypeListenerActor
- create(String, MemberName, String) - Static method in class org.opendaylight.controller.cluster.datastore.identifiers.ShardIdentifier
- create(String, DOMEntity, ActorRef<TypeListenerCommand>) - Static method in class org.opendaylight.controller.eos.akka.registry.listener.owner.SingleEntityListenerActor
- 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(Map<DOMEntity, Set<String>>, Map<DOMEntity, String>, BindingInstanceIdentifierCodec) - Static method in class org.opendaylight.controller.eos.akka.owner.supervisor.OwnerSupervisor
- 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(LocalHistoryIdentifier, ImmutableUnsignedLongSet, int) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.SkipTransactionsPayload
- 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(BindingInstanceIdentifierCodec) - Static method in class org.opendaylight.controller.eos.akka.bootstrap.EOSMain
- create(BindingInstanceIdentifierCodec) - Static method in class org.opendaylight.controller.eos.akka.owner.supervisor.IdleSupervisor
- 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
- createFailure(T, long, RequestException) - Method in interface org.opendaylight.controller.cluster.access.concepts.RequestFailure.SerialForm
- 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
- createOutputStream(File) - Method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
- 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
- createReceive() - Method in class org.opendaylight.controller.eos.akka.bootstrap.EOSMain
- createReceive() - Method in class org.opendaylight.controller.eos.akka.owner.checker.EntityRpcHandler
- createReceive() - Method in class org.opendaylight.controller.eos.akka.owner.checker.OwnerStateChecker
- createReceive() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.CandidateCleaner
- createReceive() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.IdleSupervisor
- createReceive() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.OwnerSupervisor
- createReceive() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.OwnerSyncer
- createReceive() - Method in class org.opendaylight.controller.eos.akka.registry.candidate.CandidateRegistry
- createReceive() - Method in class org.opendaylight.controller.eos.akka.registry.candidate.CandidateRegistryInit
- createReceive() - Method in class org.opendaylight.controller.eos.akka.registry.listener.owner.SingleEntityListenerActor
- createReceive() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.EntityTypeListenerActor
- createReceive() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.EntityTypeListenerRegistry
- createReceiveRecover() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActor
- createReceiveRecover() - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
- 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
- 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 - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CreateTransaction() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- CreateTransaction(TransactionIdentifier, int, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- createTransactionChain() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
- createTransactionChain() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- CreateTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CreateTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- CreateTransactionReply(String, TransactionIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- current() - Static method in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Return the codebase-native ABI version.
- current() - Static method in enum class 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
- DataBrokerCommitExecutor - Class in org.opendaylight.controller.cluster.databroker
- DataBrokerCommitExecutor(DataBrokerCommitExecutor.Config) - Constructor for class org.opendaylight.controller.cluster.databroker.DataBrokerCommitExecutor
- DataBrokerCommitExecutor.Config - Annotation Interface in org.opendaylight.controller.cluster.databroker
- DataCenterActivated - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- DataCenterControl - Interface in org.opendaylight.controller.eos.akka
-
Service used to bring up/down the Entity Ownership Service service in individual datacenters.
- DataCenterDeactivated - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- dataExists(AbstractShardDataTreeTransaction<?>, DataExists) - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- dataExists(DataExists) - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
-
Deprecated.
- DataExists - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- DataExists() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExists
-
Deprecated.
- DataExists(YangInstanceIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExists
-
Deprecated.
- DataExistsReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- DataExistsReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
-
Deprecated.
- DataExistsReply(boolean, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
-
Deprecated.
- 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.
- 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
DatastoreContextIntrospectorinstances. - 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.
- 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.rev231229
-
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
- DataStoreProperties.ExportOnRecovery - Enum Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229
-
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.rev231229
-
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.rev231229
-
Class that builds
DataStorePropertiesContainerinstances. - DataStorePropertiesContainerBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Construct an empty builder.
- DataStorePropertiesContainerBuilder(DataStoreProperties) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Construct a new builder initialized from specified
DataStoreProperties. - DataStorePropertiesContainerBuilder(DataStorePropertiesContainer) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Construct a builder initialized with state from specified
DataStorePropertiesContainer. - 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 Class 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
- 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 - Record Class in org.opendaylight.controller.cluster.datastore.persisted
- DataTreeCandidateWithVersion(DataTreeCandidate, NormalizedNodeStreamVersion) - Constructor for record class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
-
Creates an instance of a
DataTreeCandidateWithVersionrecord class. - DataTreeChanged - Class in org.opendaylight.controller.cluster.datastore.messages
-
A message about a DataTree having been changed.
- DataTreeChanged(List<DataTreeCandidate>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.DataTreeChanged
- DataTreeChangedReply - Class in org.opendaylight.controller.cluster.datastore.messages
- DataTreeCohortRegistrationProxy<C> - Class in org.opendaylight.controller.cluster.datastore
- DataTreeListenerInfo - Class in org.opendaylight.controller.cluster.mgmt.api
-
Information about a registered listener.
- DataTreeListenerInfo(String, String, boolean, long) - Constructor for class org.opendaylight.controller.cluster.mgmt.api.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 - Record Class in org.opendaylight.controller.cluster.datastore.actors
- deactivateDataCenter() - Method in class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- deactivateDataCenter() - Method in interface org.opendaylight.controller.eos.akka.DataCenterControl
-
Deactivates the Entity Ownership Service in the datacenter that this method is called.
- DeactivateDataCenter - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- DeactivateDataCenter(ActorRef<OwnerSupervisorReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.DeactivateDataCenter
- DeactivateEosDatacenter - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Deactivates the datacenter that the node this rpc is called on belongs to.
- DeactivateEosDatacenterInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
- DeactivateEosDatacenterInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Class that builds
DeactivateEosDatacenterInputinstances. - DeactivateEosDatacenterInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInputBuilder
-
Construct an empty builder.
- DeactivateEosDatacenterInputBuilder(DeactivateEosDatacenterInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInputBuilder
-
Construct a builder initialized with state from specified
DeactivateEosDatacenterInput. - DeactivateEosDatacenterOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
- DeactivateEosDatacenterOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Class that builds
DeactivateEosDatacenterOutputinstances. - DeactivateEosDatacenterOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutputBuilder
-
Construct an empty builder.
- DeactivateEosDatacenterOutputBuilder(DeactivateEosDatacenterOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutputBuilder
-
Construct a builder initialized with state from specified
DeactivateEosDatacenterOutput. - DeadHistoryException - Exception Class in org.opendaylight.controller.cluster.access.commands
-
A
RequestExceptionindicating that the backend has received a request to create a history which has already been retired. - DeadHistoryException(RangeSet<UnsignedLong>) - Constructor for exception class org.opendaylight.controller.cluster.access.commands.DeadHistoryException
- DeadTransactionException - Exception Class in org.opendaylight.controller.cluster.access.commands
-
A
RequestExceptionindicating that the backend has received a request to create a transaction which has already been purged. - DeadTransactionException(RangeSet<UnsignedLong>) - Constructor for exception class 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_EXPORT_ON_RECOVERY - Static variable in class org.opendaylight.controller.cluster.datastore.DatastoreContext
- 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_EXPORT_BASE_DIR - 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_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(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.ClientTransaction
- 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
-
Deprecated.
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- DeleteModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- DeleteModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- DeleteModification(YangInstanceIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- 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
- Details - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- 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
- 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 Class in org.opendaylight.controller.cluster.common.actor
- distributedDataStore(AbstractDataStore) - Method in class org.opendaylight.controller.cluster.datastore.shardmanager.AbstractShardManagerCreator
- DistributedDataStoreClientActor - Class in org.opendaylight.controller.cluster.databroker.actors.dds
-
A
AbstractClientActorwhich 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.rev231229
-
This module contains the base YANG definitions for the distributed datastore provider implementation
- 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 - Enum constant in enum class 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
- domSourceValue(DOMSource) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- doSaveAsync(SnapshotMetadata, Object) - Method in class org.opendaylight.controller.cluster.persistence.LocalSnapshotStore
- 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.
- empty() - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Get empty instance of DataStorePropertiesContainer.
- EmptyState - Class in org.opendaylight.controller.cluster.raft.persisted
-
Empty Snapshot State implementation.
- 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
- endNode() - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- 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
- Entities - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- EntitiesBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output
-
Class that builds
Entitiesinstances. - EntitiesBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Construct an empty builder.
- EntitiesBuilder(Candidates) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Construct a new builder initialized from specified
Candidates. - EntitiesBuilder(Details) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Construct a new builder initialized from specified
Details. - EntitiesBuilder(EntityId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Construct a new builder initialized from specified
EntityId. - EntitiesBuilder(Entities) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Construct a builder initialized with state from specified
Entities. - EntitiesBuilder(Owner) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Construct a new builder initialized from specified
Owner. - EntitiesKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output
-
This class represents the key of
Entitiesclass. - EntitiesKey(EntityName, EntityType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesKey
-
Constructs an instance.
- EntitiesKey(EntitiesKey) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesKey
-
Creates a copy from Source Object.
- entity() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.EntityOwnerChanged
- EntityId - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- EntityName - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- EntityName(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
- EntityName(EntityName) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
-
Creates a copy from Source Object.
- EntityName(BindingInstanceIdentifier) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
- EntityNameBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
- EntityOwnerChanged - Class in org.opendaylight.controller.eos.akka.registry.listener.type.command
-
Notification sent to
EntityTypeListenerActorwhen there is an owner change for an Entity of a given type. - EntityOwnerChanged(DOMEntity, EntityOwnershipStateChange, boolean) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.type.command.EntityOwnerChanged
- EntityRpcHandler - Class in org.opendaylight.controller.eos.akka.owner.checker
-
Short-lived actor that is spawned purely for execution of rpcs from the entity-owners model.
- EntityRpcHandler(ActorContext<StateCheckerCommand>, ActorRef<OwnerSupervisorCommand>, BindingInstanceIdentifierCodec) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.EntityRpcHandler
- EntityType - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- EntityType(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityType
- EntityType(EntityType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityType
-
Creates a copy from Source Object.
- EntityTypeListenerActor - Class in org.opendaylight.controller.eos.akka.registry.listener.type
- EntityTypeListenerActor(ActorContext<TypeListenerCommand>, String, String, DOMEntityOwnershipListener) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.type.EntityTypeListenerActor
- EntityTypeListenerRegistry - Class in org.opendaylight.controller.eos.akka.registry.listener.type
- EntityTypeListenerRegistry(ActorContext<TypeListenerRegistryCommand>, String) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.type.EntityTypeListenerRegistry
- Envelope<T> - Class in org.opendaylight.controller.cluster.access.concepts
- EOSMain - Class in org.opendaylight.controller.eos.akka.bootstrap
- 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 record class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor.SetRegistration
-
Indicates whether some other object is "equal to" this one.
- 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 record class org.opendaylight.controller.cluster.datastore.messages.ActorInitialized
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.opendaylight.controller.cluster.datastore.messages.UpdateSchemaContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload.CandidateTransaction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather.ShardContainer
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- equals(Object) - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- equals(Object) - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- equals(Object) - Method in record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.opendaylight.controller.cluster.raft.ClientRequestTracker
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
- equals(Object) - Method in record class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
- 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.rev231229.HeartbeatIntervalType
- equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.NonZeroUint32Type
- equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.OperationTimeoutType
- equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.Percentage
- equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
- equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityType
- equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesKey
- equals(Object) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.NodeName
- 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
- error() - Method in class org.opendaylight.controller.cluster.common.actor.MessageTracker.Context
- execute(ClientActorBehavior<T>) - Method in interface org.opendaylight.controller.cluster.access.client.InternalCommand
-
Run command actions.
- ExecuteAction - Class in org.opendaylight.controller.remote.rpc.messages
- 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
Procedurein their context. - 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.
- ExecuteRpc - Class in org.opendaylight.controller.remote.rpc.messages
- exists() - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
-
Deprecated.
- 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
- 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
- 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.
- ExportJournal(ReplicatedLogEntry) - Constructor for class org.opendaylight.controller.cluster.datastore.actors.JsonExportActor.ExportJournal
- exportOnRecovery(DataStoreProperties.ExportOnRecovery) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
- ExportSnapshot(DataTreeCandidate, String) - Constructor for class org.opendaylight.controller.cluster.datastore.actors.JsonExportActor.ExportSnapshot
- 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.SkipTransactionsPayload
- externalizableProxy(byte[]) - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
- externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.concepts.Message
-
Instantiate a serialization proxy for this object for the target ABI version.
- 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.SkipTransactionsRequest
- externalizableProxy(ABIVersion) - Method in class org.opendaylight.controller.cluster.access.commands.SkipTransactionsResponse
- 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
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbortTransactionPayload
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CloseLocalHistoryPayload
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CreateLocalHistoryPayload
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DisableTrackingPayload
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.PurgeLocalHistoryPayload
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.PurgeTransactionPayload
- externalizableProxySize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.SkipTransactionsPayload
- externalizableProxySize(Function<byte[], ? extends AbstractIdentifiablePayload.SerialForm>) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
F
- failed(Identifier, MessageSliceException, ActorRef) - Static method in class org.opendaylight.controller.cluster.messaging.MessageSliceReply
- FAILED - Enum constant in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
- 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(Grouping) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set fields from given grouping argument.
- fieldsFrom(Grouping) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Set fields from given grouping argument.
- fieldsFrom(Grouping) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Set fields from given grouping argument.
- fieldsFrom(Grouping) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Set fields from given grouping argument.
- fieldsFrom(Grouping) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Set fields from given grouping argument.
- fieldsFrom(Grouping) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Set fields from given grouping argument.
- fieldsFrom(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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(Grouping) - 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
FileBackedOutputStreamcontaining the message data to slice. - FileBackedOutputStream - Class in org.opendaylight.controller.cluster.io
-
An
OutputStreamthat 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
ByteSourcereturned byFileBackedOutputStream.asByteSource()is finalized. - FileBackedOutputStreamFactory - Class in org.opendaylight.controller.cluster.io
-
A factory for creating
FileBackedOutputStreaminstances. - 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
FindLeadermessage, 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 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.
- FinishExport(String) - Constructor for class org.opendaylight.controller.cluster.datastore.actors.JsonExportActor.FinishExport
- 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.
- FlipMemberVotingStatesForAllShards - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
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
-
Class that builds
FlipMemberVotingStatesForAllShardsInputinstances. - FlipMemberVotingStatesForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
-
Construct an empty builder.
- FlipMemberVotingStatesForAllShardsInputBuilder(FlipMemberVotingStatesForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInputBuilder
-
Construct a builder initialized with state from specified
FlipMemberVotingStatesForAllShardsInput. - 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
-
Class that builds
FlipMemberVotingStatesForAllShardsOutputinstances. - FlipMemberVotingStatesForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
-
Construct an empty builder.
- FlipMemberVotingStatesForAllShardsOutputBuilder(FlipMemberVotingStatesForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
-
Construct a builder initialized with state from specified
FlipMemberVotingStatesForAllShardsOutput. - FlipMemberVotingStatesForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
-
Construct a new builder initialized from specified
ShardResultOutput. - 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
-
Deprecated.
- FLUORINE_VERSION - Static variable in class org.opendaylight.controller.cluster.raft.RaftVersions
- flush() - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- 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 - Enum constant in enum class 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.mgmt.api
-
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.mgmt.api.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
FrontendTypecorresponding to a string representation. - forName(String) - Static method in class org.opendaylight.controller.cluster.access.concepts.MemberName
- forName(String) - Static method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
-
Return the enumeration member whose
DataStoreProperties.ExportOnRecovery.getName()matches specified assigned name. - forName(String) - Static method in enum class 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 assigned name. - forSchemaContext(EffectiveModelContext) - Static method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
-
Create a new pruner bound to a SchemaContext.
- forValue(int) - Static method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
-
Return the enumeration member whose
DataStoreProperties.ExportOnRecovery.getIntValue()matches specified value. - forValue(int) - Static method in enum class 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ForwardedReadyTransaction(TransactionIdentifier, short, ReadWriteShardDataTreeTransaction, boolean, Optional<SortedSet<String>>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
-
Deprecated.
- forwardEntry(ConnectionEntry, long) - Method in class org.opendaylight.controller.cluster.access.client.ReconnectForwarder
- from(DOMRpcIdentifier, ContainerNode) - Static method in class org.opendaylight.controller.remote.rpc.messages.ExecuteRpc
- from(SchemaNodeIdentifier.Absolute, 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
-
Deprecated.
- fromBinaryJava(byte[], Class<?>) - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntrySerializer
- fromInt(int) - Static method in enum class org.opendaylight.controller.cluster.datastore.TransactionType
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- fromSerializable(Object) - Static method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- 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
-
Deprecated.
- fromStream(NormalizedNodeDataInput, short, ReusableStreamReceiver) - Static method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
-
Deprecated.
- fromStream(NormalizedNodeDataInput, short, ReusableStreamReceiver) - Static method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- FrontendClientMetadata - Class in org.opendaylight.controller.cluster.datastore.persisted
- FrontendClientMetadata(ClientIdentifier, ImmutableUnsignedLongSet, 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, UnsignedLongBitmap, ImmutableUnsignedLongSet) - 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
Identifieridentifying 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
-
This class represents the following YANG schema fragment defined in module odl-controller-cds-types
- 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 Class 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 Class 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
- gather(ActorUtils, Stream<FluentFuture<Optional<NormalizedNode>>>) - Static method in class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather
-
Reconstruct root container from a set of constituents.
- 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 - Enum constant in enum class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
-
Sent from Gossiper to BucketStore, response is an immutable
Map<Address, Bucket<?>>. - GET_BUCKET_VERSIONS - Enum constant in enum class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
-
Sent from Gossiper to BucketStore, response is an immutable
Map<Address, Long>. - 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
- 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
- getAddress() - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
- getAddress() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.InternalClusterEvent
- 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.
- 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.utils.ActorUtils
- getAssembledBytes() - Method in class org.opendaylight.controller.cluster.messaging.AssembledMessageState
-
Returns the assembled bytes as a ByteSource.
- 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.
- 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.rev231229.DataStoreProperties
-
Return backendAlivenessTimerIntervalInSeconds, or
nullif it is not present. - getBackendAlivenessTimerIntervalInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getBackendAlivenessTimerIntervalInSeconds(). - getBackendInfo() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientConnection
- getBackendInfo() - Method in class org.opendaylight.controller.cluster.access.client.ConnectedClientConnection
- getBackendInfo() - Method in class org.opendaylight.controller.cluster.access.client.ReconnectingClientConnection
- 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
- getBoundedMailboxCapacity() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return boundedMailboxCapacity, or
nullif it is not present. - getBoundedMailboxCapacity() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getBoundedMailboxCapacity(). - 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
-
Deprecated.
- getCandidate() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
- getCandidate() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidatesForMember
- getCandidate() - Method in class org.opendaylight.controller.eos.akka.registry.candidate.command.AbstractCandidateCommand
- 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
- getCandidateNodes() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.Candidates
-
Return candidateNodes, or
nullif it is not present. - getCandidateNodes() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Return current value associated with the property corresponding to
Candidates.getCandidateNodes(). - getCandidateNodes() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Return current value associated with the property corresponding to
Candidates.getCandidateNodes(). - getCandidateRegistry() - Method in class org.opendaylight.controller.eos.akka.bootstrap.command.RunningContext
- getCandidates() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntitiesBackendReply
- getCandidates() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntityBackendReply
- GetCandidates - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetCandidates(Replicator.GetResponse<ORMap<DOMEntity, ORSet<String>>>, ActorRef<GetEntitiesReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetCandidates
- GetCandidatesForEntity - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetCandidatesForEntity(Replicator.GetResponse<ORMap<DOMEntity, ORSet<String>>>, DOMEntity, ActorRef<GetEntityReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetCandidatesForEntity
- 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
- getClient() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
- getClientActor() - Method in class org.opendaylight.controller.cluster.raft.base.messages.ApplyState
- 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 class 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
- getCohortPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- getCommitCohortActors() - Method in class org.opendaylight.controller.cluster.datastore.messages.OnDemandShardState
- 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
- 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
- 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 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.rev231229.DataStoreProperties
-
Return customRaftPolicyImplementation, or
nullif it is not present. - getCustomRaftPolicyImplementation() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getCustomRaftPolicyImplementation(). - 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
-
Deprecated.
- 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
- 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.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.rev231229.DistributedDatastoreProviderData
-
Return dataStorePropertiesContainer, or
nullif it is not present. - getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getDataStoreType(). - getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getDataStoreType(). - getDataStoreType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
-
Return dataStoreType, or
nullif it is not present. - getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getDataStoreType(). - getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getDataStoreType(). - getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getDataStoreType(). - getDataStoreType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getDataStoreType(). - 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
-
Return current value associated with the property corresponding to
DatastoreShardId.getDataStoreType(). - 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
-
Return dataStoreType, guaranteed to be non-null.
- getDataTree() - Method in class org.opendaylight.controller.cluster.access.commands.ConnectClientSuccess
- getDataTree() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
- getDataTreeChangeListenerInfo() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardDataTreeListenerInfoMXBean
- 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.rev231229.HeartbeatIntervalType
- getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.NonZeroUint32Type
- getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.OperationTimeoutType
- getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.Percentage
- getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityNameBuilder
- getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityType
- getDefaultInstance(String) - Static method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.NodeName
- 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
- getDelegateListener() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.TypeListenerRegistryCommand
- 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
- getDistributedDataStoreClient(ActorRef, long, TimeUnit) - Static method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractDataStoreClientActor
- getDOMStoreTransaction() - Method in class org.opendaylight.controller.cluster.datastore.ShardReadTransaction
-
Deprecated.
- getDOMStoreTransaction() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- getDOMStoreTransaction() - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
-
Deprecated.
- 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
- getEnableMetricCapture() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return enableMetricCapture, or
nullif it is not present. - getEnableMetricCapture() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getEnableMetricCapture(). - getEnqueuedTicks() - Method in class org.opendaylight.controller.cluster.access.client.ConnectionEntry
- getEntities() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutput
-
Return entities, or
nullif it is not present. - getEntities() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
Return current value associated with the property corresponding to
GetEntitiesOutput.getEntities(). - GetEntities - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntitiesBackendReply - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- GetEntitiesBackendReply(Map<DOMEntity, String>, Map<DOMEntity, Set<String>>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntitiesBackendReply
- GetEntitiesBackendRequest - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- GetEntitiesBackendRequest(ActorRef<StatusReply<GetEntitiesBackendReply>>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntitiesBackendRequest
- GetEntitiesInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
- GetEntitiesInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
Class that builds
GetEntitiesInputinstances. - GetEntitiesInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInputBuilder
-
Construct an empty builder.
- GetEntitiesInputBuilder(GetEntitiesInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInputBuilder
-
Construct a builder initialized with state from specified
GetEntitiesInput. - GetEntitiesOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntitiesOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
Class that builds
GetEntitiesOutputinstances. - GetEntitiesOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
Construct an empty builder.
- GetEntitiesOutputBuilder(GetEntitiesOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
Construct a builder initialized with state from specified
GetEntitiesOutput. - GetEntitiesReply - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetEntitiesReply(Map<DOMEntity, Set<String>>, Map<DOMEntity, String>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntitiesReply
- GetEntitiesReply(GetEntitiesBackendReply) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntitiesReply
- GetEntitiesRequest - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetEntitiesRequest(ActorRef<GetEntitiesReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntitiesRequest
- getEntity() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.AbstractEntityRequest
- getEntity() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetCandidatesForEntity
- getEntity() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnerForEntity
- getEntity() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnershipState
- getEntity() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.InternalGetReply
- getEntity() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.SingleEntityOwnerDataResponse
- getEntity() - Method in class org.opendaylight.controller.eos.akka.registry.candidate.command.AbstractCandidateCommand
- GetEntity - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntityBackendReply - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- GetEntityBackendReply(String, Set<String>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntityBackendReply
- GetEntityBackendRequest - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- GetEntityBackendRequest(ActorRef<StatusReply<GetEntityBackendReply>>, EntityId) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntityBackendRequest
- GetEntityInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntityInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
Class that builds
GetEntityInputinstances. - GetEntityInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Construct an empty builder.
- GetEntityInputBuilder(EntityId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Construct a new builder initialized from specified
EntityId. - GetEntityInputBuilder(GetEntityInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Construct a builder initialized with state from specified
GetEntityInput. - GetEntityOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntityOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
Class that builds
GetEntityOutputinstances. - GetEntityOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Construct an empty builder.
- GetEntityOutputBuilder(Candidates) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Construct a new builder initialized from specified
Candidates. - GetEntityOutputBuilder(Details) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Construct a new builder initialized from specified
Details. - GetEntityOutputBuilder(GetEntityOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Construct a builder initialized with state from specified
GetEntityOutput. - GetEntityOutputBuilder(Owner) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Construct a new builder initialized from specified
Owner. - GetEntityOwner - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntityOwnerBackendReply - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- GetEntityOwnerBackendReply(String) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntityOwnerBackendReply
- GetEntityOwnerBackendRequest - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- GetEntityOwnerBackendRequest(ActorRef<StatusReply<GetEntityOwnerBackendReply>>, EntityId) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntityOwnerBackendRequest
- GetEntityOwnerInput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntityOwnerInputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
Class that builds
GetEntityOwnerInputinstances. - GetEntityOwnerInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Construct an empty builder.
- GetEntityOwnerInputBuilder(EntityId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Construct a new builder initialized from specified
EntityId. - GetEntityOwnerInputBuilder(GetEntityOwnerInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Construct a builder initialized with state from specified
GetEntityOwnerInput. - GetEntityOwnerOutput - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- GetEntityOwnerOutputBuilder - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
Class that builds
GetEntityOwnerOutputinstances. - GetEntityOwnerOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Construct an empty builder.
- GetEntityOwnerOutputBuilder(GetEntityOwnerOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Construct a builder initialized with state from specified
GetEntityOwnerOutput. - GetEntityOwnerOutputBuilder(Owner) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Construct a new builder initialized from specified
Owner. - GetEntityOwnerReply - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetEntityOwnerReply(String) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntityOwnerReply
- GetEntityOwnerRequest - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetEntityOwnerRequest(ActorRef<GetEntityOwnerReply>, EntityId) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntityOwnerRequest
- GetEntityReply - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetEntityReply(String, Set<String>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntityReply
- GetEntityReply(GetEntityBackendReply) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntityReply
- GetEntityRequest - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetEntityRequest(ActorRef<GetEntityReply>, EntityId) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntityRequest
- getEntityType() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.TypeListenerRegistryCommand
- 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
-
Return current value associated with the property corresponding to
ShardOperationResult.getErrorMessage(). - getErrorMessage() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
-
Return errorMessage, or
nullif it is not present. - getErrors() - Method in class org.opendaylight.controller.remote.rpc.messages.ActionResponse
- 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
- getExists() - Method in class org.opendaylight.controller.cluster.access.commands.ExistsTransactionSuccess
- getExportOnRecovery() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
- getExportOnRecovery() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return exportOnRecovery, or
nullif it is not present. - getExportOnRecovery() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getExportOnRecovery(). - getFailedReadTransactionsCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- 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
FileBackedOutputStreamFactoryinstance 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.rev231229.DataStoreProperties
-
Return fileBackedStreamingThresholdInMegabytes, or
nullif it is not present. - getFileBackedStreamingThresholdInMegabytes() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getFileBackedStreamingThresholdInMegabytes(). - getFilePath() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
-
Return filePath, or
nullif it is not present. - getFilePath() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
Return current value associated with the property corresponding to
BackupDatastoreInput.getFilePath(). - 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 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 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.rev231229.DataStoreProperties
-
Return frontendNoProgressTimeoutInSeconds, or
nullif it is not present. - getFrontendNoProgressTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getFrontendNoProgressTimeoutInSeconds(). - getFrontendRequestTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return frontendRequestTimeoutInSeconds, or
nullif it is not present. - getFrontendRequestTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getFrontendRequestTimeoutInSeconds(). - 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
-
Return generation, or
nullif it is not present. - 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
-
Return current value associated with the property corresponding to
ClientIdentifier.getGeneration(). - 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.mgmt.api.FollowerInfo
- getId() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
- 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.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
- 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.actors.dds.AbstractClientHandle
- getIdentifier() - Method in class org.opendaylight.controller.cluster.databroker.actors.dds.AbstractClientHistory
- getIdentifier() - Method in class org.opendaylight.controller.cluster.datastore.ReadWriteShardDataTreeTransaction
- getIdentifier() - Method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
-
Deprecated.
- 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.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
- getIfPresent(String) - Method in class org.opendaylight.controller.cluster.datastore.utils.PrimaryShardInfoFutureCache
- getImportedModules() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.YangModuleInfoImpl
- getImportedModules() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.YangModuleInfoImpl
- getImportedModules() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.YangModuleInfoImpl
- getImportedModules() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.YangModuleInfoImpl
- 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.ReplicatedLogEntry
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
RaftEntryMeta.index()istead. - GetInfo - Class in org.opendaylight.controller.cluster.datastore.messages
-
Local message sent to an actor to retrieve
DataTreeListenerInfofor 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.rev231229.DataStoreProperties
-
Return initialPayloadSerializedBufferCapacity, or
nullif it is not present. - getInitialPayloadSerializedBufferCapacity() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getInitialPayloadSerializedBufferCapacity(). - 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.rev231229.DataStoreProperties
-
Return initialSettleTimeoutMultiplier, or
nullif it is not present. - getInitialSettleTimeoutMultiplier() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getInitialSettleTimeoutMultiplier(). - 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 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() - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.YangModuleInfoImpl
-
Return the singleton instance of this class.
- getInstance() - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.YangModuleInfoImpl
-
Return the singleton instance of this class.
- getInstance() - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.YangModuleInfoImpl
-
Return the singleton instance of this class.
- getInstance() - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.YangModuleInfoImpl
-
Return the singleton instance of this class.
- getInstance(String) - Static method in class org.opendaylight.controller.cluster.reporting.MetricsReporter
- getInstanceIdentifier() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
- getIntValue() - Method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
- getIntValue() - Method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
- 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
- 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
-
Return knownClients, or
nullif it is not present. - 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
-
Return current value associated with the property corresponding to
ShardResult1.getKnownClients(). - GetKnownClients - Class in org.opendaylight.controller.cluster.datastore.messages
-
Request a shard to report the clients it knows about.
- GetKnownClientsForAllShards - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
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
GetKnownClientsForAllShardsInputinstances. - GetKnownClientsForAllShardsInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
-
Construct an empty builder.
- GetKnownClientsForAllShardsInputBuilder(GetKnownClientsForAllShardsInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInputBuilder
-
Construct a builder initialized with state from specified
GetKnownClientsForAllShardsInput. - 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
GetKnownClientsForAllShardsOutputinstances. - GetKnownClientsForAllShardsOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
-
Construct an empty builder.
- GetKnownClientsForAllShardsOutputBuilder(GetKnownClientsForAllShardsOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
-
Construct a builder initialized with state from specified
GetKnownClientsForAllShardsOutput. - GetKnownClientsForAllShardsOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
-
Construct a new builder initialized from specified
ShardResultOutput. - 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 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 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 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 interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- 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 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 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 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
-
Return leaderActorRef, or
nullif it is not present. - 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
-
Return current value associated with the property corresponding to
LeaderActorRef.getLeaderActorRef(). - 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.
- 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 interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- getListener() - Method in class org.opendaylight.controller.cluster.mgmt.api.DataTreeListenerInfo
- getListenerActorPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
- getListenerRegistrationPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeNotificationListenerReply
- getListenerRegistry() - Method in class org.opendaylight.controller.eos.akka.bootstrap.command.RunningContext
- 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
-
Return local, or
nullif it is not present. - 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
-
Return current value associated with the property corresponding to
Local.getLocal(). - 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.
- 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.
- 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.mgmt.api.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 interface org.opendaylight.controller.cluster.raft.ConfigParams
-
Returns the maximum size (in bytes) for the snapshot chunk sent from a Leader.
- getMaximumMessageSliceSize() - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- getMaximumMessageSliceSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return maximumMessageSliceSize, or
nullif it is not present. - getMaximumMessageSliceSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getMaximumMessageSliceSize(). - 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
- 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
Categoryproperty of the bean's ObjectName. - getMBeanName() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
-
Returns the
nameproperty of the bean's ObjectName. - getMBeanType() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
-
Returns the
typeproperty 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
-
Return member, or
nullif it is not present. - 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
-
Return current value associated with the property corresponding to
FrontendIdentifier.getMember(). - 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
-
Return member, guaranteed to be non-null.
- 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.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
-
Return memberName, or
nullif it is not present. - 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
-
Return current value associated with the property corresponding to
MemberVotingState.getMemberName(). - getMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
-
Return memberName, or
nullif it is not present. - getMemberName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
-
Return current value associated with the property corresponding to
RemoveAllShardReplicasInput.getMemberName(). - getMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
-
Return memberName, or
nullif it is not present. - getMemberName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Return current value associated with the property corresponding to
RemoveShardReplicaInput.getMemberName(). - getMemberNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
-
Return memberNode, or
nullif it is not present. - getMemberNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
-
Return current value associated with the property corresponding to
LocateShardOutput.getMemberNode(). - 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
-
Return current value associated with the property corresponding to
MemberVotingStatesInput.getMemberVotingState(). - getMemberVotingState() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Return current value associated with the property corresponding to
MemberVotingStatesInput.getMemberVotingState(). - getMemberVotingState() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MemberVotingStatesInput
-
Return memberVotingState, or
nullif it is not present. - getMessage() - Method in class org.opendaylight.controller.cluster.access.concepts.Envelope
-
Get the enclosed message.
- getMessage() - Method in exception class 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
- 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
-
Deprecated.
- getModifications() - Method in class org.opendaylight.controller.cluster.access.commands.ModifyTransactionRequest
- getModifications() - Method in interface org.opendaylight.controller.cluster.datastore.modification.CompositeModification
-
Deprecated.Get a list of modifications contained by this composite.
- getModifications() - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- getModifications() - Method in class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
-
Deprecated.
- getModuleInfo() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.YangModelBindingProviderImpl
- getModuleInfo() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.YangModelBindingProviderImpl
- getModuleInfo() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.YangModelBindingProviderImpl
- getModuleInfo() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.YangModelBindingProviderImpl
- 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 class org.opendaylight.controller.eos.akka.owner.checker.command.AbstractEntityRequest
- getName() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.AbstractEntityRequest
- getName() - Method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
- getName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityId
-
Return name, or
nullif it is not present. - getName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Return current value associated with the property corresponding to
EntityId.getName(). - getName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesKey
-
Return name, guaranteed to be non-null.
- getName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Return current value associated with the property corresponding to
EntityId.getName(). - getName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Return current value associated with the property corresponding to
EntityId.getName(). - getName() - Method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
- getName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.YangModuleInfoImpl
- getName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.YangModuleInfoImpl
- getName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.YangModuleInfoImpl
- getName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.YangModuleInfoImpl
- 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.mgmt.api.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.
- 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
-
Deprecated.
- getNotificationCount() - Method in class org.opendaylight.controller.cluster.mgmt.api.DataTreeListenerInfo
- getNotificationDispatcherPath() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
- getNumBatched() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
-
Deprecated.
- 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return operationTimeoutInSeconds, or
nullif it is not present. - getOperationTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getOperationTimeoutInSeconds(). - 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
- getOriginalMessage() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidates
- getOthers() - Method in class org.opendaylight.controller.cluster.access.commands.SkipTransactionsRequest
-
Return this
Message.getTarget()s siblingTransactionIdentifiers. - getOutput() - Method in class org.opendaylight.controller.remote.rpc.messages.AbstractResponse
- getOwner() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntityBackendReply
- getOwner() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntityOwnerBackendReply
- GetOwnerForEntity - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetOwnerForEntity(Replicator.GetResponse<LWWRegister<String>>, DOMEntity, ActorRef<GetEntityOwnerReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnerForEntity
- getOwnerNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Return current value associated with the property corresponding to
Owner.getOwnerNode(). - getOwnerNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Return current value associated with the property corresponding to
Owner.getOwnerNode(). - getOwnerNode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Return current value associated with the property corresponding to
Owner.getOwnerNode(). - getOwnerNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.Owner
-
Return ownerNode, or
nullif it is not present. - getOwners() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.GetEntitiesBackendReply
- getOwnershipState() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnershipStateReply
- getOwnershipState(DOMEntity) - Method in class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- GetOwnershipState - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetOwnershipState(DOMEntity, ActorRef<GetOwnershipStateReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnershipState
- GetOwnershipStateReply - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- GetOwnershipStateReply(EntityOwnershipState) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnershipStateReply
- getOwnerStateChecker() - Method in class org.opendaylight.controller.eos.akka.bootstrap.command.RunningContext
- getOwnerSupervisor() - Method in class org.opendaylight.controller.eos.akka.bootstrap.command.RunningContext
- getParticipatingShardNames() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- getParticipatingShardNames() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
-
Deprecated.
- getParticipatingShardNames() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
-
Deprecated.
- 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
-
Deprecated.
- 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
-
Deprecated.
- getPath() - Method in class org.opendaylight.controller.remote.rpc.messages.ExecuteAction
- 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 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
- 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 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 interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- 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
- getPersistent() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return persistent, or
nullif it is not present. - getPersistent() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getPersistent(). - 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 class 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 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 interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- getReadWriteTransactionCount() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- getRecoveryExportBaseDir() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
- getRecoveryExportBaseDir() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return recoveryExportBaseDir, or
nullif it is not present. - getRecoveryExportBaseDir() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getRecoveryExportBaseDir(). - 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.rev231229.DataStoreProperties
-
Return recoverySnapshotIntervalSeconds, or
nullif it is not present. - getRecoverySnapshotIntervalSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getRecoverySnapshotIntervalSeconds(). - getRegisteredPath() - Method in class org.opendaylight.controller.cluster.mgmt.api.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
-
Deprecated.
- getReplicas() - Method in class org.opendaylight.controller.cluster.datastore.config.ShardConfig
- 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
- 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
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.bootstrap.command.GetRunningContext
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.bootstrap.command.Terminate
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetCandidates
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetCandidatesForEntity
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnerForEntity
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnershipState
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.InternalGetReply
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.OwnerDataResponse
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.SingleEntityOwnerDataResponse
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.StateCheckerRequest
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.ActivateDataCenter
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidatesForMember
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidatesUpdateResponse
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.DeactivateDataCenter
- getReplyTo() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.OwnerSupervisorRequest
- 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
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetCandidates
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetCandidatesForEntity
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetOwnerForEntity
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.InternalGetReply
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.OwnerDataResponse
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.SingleEntityOwnerDataResponse
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.CandidatesChanged
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidates
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.ClearCandidatesUpdateResponse
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.InitialCandidateSync
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.InitialOwnerSync
- getResponse() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.OwnerChanged
- getResponse() - Method in class org.opendaylight.controller.eos.akka.registry.listener.owner.command.InitialOwnerSync
- getResponse() - Method in class org.opendaylight.controller.eos.akka.registry.listener.owner.command.OwnerChanged
- getResponse() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.CandidatesChanged
- 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.
- getResult() - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
-
Return the resulting normalized node.
- 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.GetShardRoleOutput
-
Return role, or
nullif it is not present. - getRole() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
-
Return current value associated with the property corresponding to
GetShardRoleOutput.getRole(). - 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.
- getRoles() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.InternalClusterEvent
- getRootNode() - Method in class org.opendaylight.controller.cluster.datastore.persisted.MetadataShardDataTreeSnapshot
- getRootNode() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardDataTreeSnapshot
-
Get the root data node contained in this snapshot.
- 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 class 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
- getRsp() - Method in class org.opendaylight.controller.eos.akka.registry.candidate.command.InternalUpdateResponse
- GetRunningContext - Class in org.opendaylight.controller.eos.akka.bootstrap.command
- GetRunningContext(ActorRef<RunningContext>) - Constructor for class org.opendaylight.controller.eos.akka.bootstrap.command.GetRunningContext
- getSchemaContext() - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
- getSchemaContext() - Method in class org.opendaylight.controller.cluster.datastore.utils.ActorUtils
- 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.
- getShardActor() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- 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.rev231229.DataStoreProperties
-
Return shardBatchedModificationCount, or
nullif it is not present. - getShardBatchedModificationCount() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardBatchedModificationCount(). - 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardCommitQueueExpiryTimeoutInSeconds, or
nullif it is not present. - getShardCommitQueueExpiryTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardCommitQueueExpiryTimeoutInSeconds(). - 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardElectionTimeoutFactor, or
nullif it is not present. - getShardElectionTimeoutFactor() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardElectionTimeoutFactor(). - getShardHeartbeatIntervalInMillis() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
- getShardHeartbeatIntervalInMillis() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardHeartbeatIntervalInMillis, or
nullif it is not present. - getShardHeartbeatIntervalInMillis() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardHeartbeatIntervalInMillis(). - 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardInitializationTimeoutInSeconds, or
nullif it is not present. - getShardInitializationTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardInitializationTimeoutInSeconds(). - getShardIsolatedLeaderCheckIntervalInMillis() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
- getShardIsolatedLeaderCheckIntervalInMillis() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardIsolatedLeaderCheckIntervalInMillis, or
nullif it is not present. - getShardIsolatedLeaderCheckIntervalInMillis() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardIsolatedLeaderCheckIntervalInMillis(). - getShardJournalRecoveryLogBatchSize() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
- getShardJournalRecoveryLogBatchSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardJournalRecoveryLogBatchSize, or
nullif it is not present. - getShardJournalRecoveryLogBatchSize() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardJournalRecoveryLogBatchSize(). - 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardLeaderElectionTimeoutInSeconds, or
nullif it is not present. - getShardLeaderElectionTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardLeaderElectionTimeoutInSeconds(). - getShardList() - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardManagerSnapshot
- 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
- 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 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
-
Return current value associated with the property corresponding to
DatastoreShardId.getShardName(). - getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getShardName(). - getShardName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
-
Return shardName, or
nullif it is not present. - getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getShardName(). - getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getShardName(). - getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getShardName(). - getShardName() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Return current value associated with the property corresponding to
DatastoreShardId.getShardName(). - 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
-
Return current value associated with the property corresponding to
DatastoreShardId.getShardName(). - 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
-
Return shardName, guaranteed to be non-null.
- 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
- getShardNames() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig
- 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
-
Return current value associated with the property corresponding to
ShardResultOutput.getShardResult(). - getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutputBuilder
-
Return current value associated with the property corresponding to
ShardResultOutput.getShardResult(). - getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutputBuilder
-
Return current value associated with the property corresponding to
ShardResultOutput.getShardResult(). - getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutputBuilder
-
Return current value associated with the property corresponding to
ShardResultOutput.getShardResult(). - getShardResult() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
-
Return current value associated with the property corresponding to
ShardResultOutput.getShardResult(). - getShardResult() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardResultOutput
-
Return shardResult, or
nullif it is not present. - 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 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Returns the current role for the requested module 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
GetShardRoleInputinstances. - GetShardRoleInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Construct an empty builder.
- GetShardRoleInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Construct a new builder initialized from specified
DatastoreShardId. - GetShardRoleInputBuilder(GetShardRoleInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Construct a builder initialized with state from specified
GetShardRoleInput. - 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
GetShardRoleOutputinstances. - GetShardRoleOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
-
Construct an empty builder.
- GetShardRoleOutputBuilder(GetShardRoleOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutputBuilder
-
Construct a builder initialized with state from specified
GetShardRoleOutput. - 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardSnapshotBatchCount, or
nullif it is not present. - getShardSnapshotBatchCount() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardSnapshotBatchCount(). - getShardSnapshotDataThreshold() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
- getShardSnapshotDataThreshold() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardSnapshotDataThreshold, or
nullif it is not present. - getShardSnapshotDataThreshold() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardSnapshotDataThreshold(). - getShardSnapshotDataThresholdPercentage() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
- getShardSnapshotDataThresholdPercentage() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardSnapshotDataThresholdPercentage, or
nullif it is not present. - getShardSnapshotDataThresholdPercentage() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardSnapshotDataThresholdPercentage(). - getShardSnapshots() - Method in class org.opendaylight.controller.cluster.datastore.persisted.DatastoreSnapshot
- 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
- 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardTransactionCommitQueueCapacity, or
nullif it is not present. - getShardTransactionCommitQueueCapacity() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardTransactionCommitQueueCapacity(). - 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardTransactionCommitTimeoutInSeconds, or
nullif it is not present. - getShardTransactionCommitTimeoutInSeconds() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardTransactionCommitTimeoutInSeconds(). - 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.rev231229.DataStoreProperties
-
Return shardTransactionIdleTimeoutInMinutes, or
nullif it is not present. - getShardTransactionIdleTimeoutInMinutes() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getShardTransactionIdleTimeoutInMinutes(). - getShardTransactionIdleTimeoutInSeconds() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreConfigurationMXBean
- 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.
- 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
- 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. 0 means that direct threshold is disabled and percentage is used instead.
- 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 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
- getSnapshotOnRootOverwrite() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return snapshotOnRootOverwrite, or
nullif it is not present. - getSnapshotOnRootOverwrite() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getSnapshotOnRootOverwrite(). - 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 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
- getState() - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
- getState() - Method in class org.opendaylight.controller.cluster.raft.persisted.Snapshot
- getStatRetrievalError() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- getStatRetrievalTime() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- getStatus() - Method in class org.opendaylight.controller.cluster.raft.messages.AbstractServerChangeReply
- 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
- getStreamVersion() - Method in enum class 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
-
Deprecated.
- getStreamVersion() - Method in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
Return the NormalizedNode stream version corresponding to this particular ABI.
- getString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
- getSucceeded() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder
-
Return current value associated with the property corresponding to
ShardOperationResult.getSucceeded(). - getSucceeded() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
-
Return succeeded, or
nullif it is not present. - 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.rev231229.DataStoreProperties
-
Return syncIndexThreshold, or
nullif it is not present. - getSyncIndexThreshold() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getSyncIndexThreshold(). - 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 interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
RaftEntryMeta.term()istead. - 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
- getThrowable() - Method in class org.opendaylight.controller.eos.akka.registry.candidate.command.CandidateRemovalFailed
- 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
-
Return timeout, or
nullif it is not present. - getTimeout() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
Return current value associated with the property corresponding to
BackupDatastoreInput.getTimeout(). - getTimeSinceLastActivity() - Method in class org.opendaylight.controller.cluster.mgmt.api.FollowerInfo
- getToIndex() - Method in class org.opendaylight.controller.cluster.raft.persisted.ApplyJournalEntries
- 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.
- 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
-
Deprecated.
- 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
-
Deprecated.
- 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
- 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 interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return transactionCreationInitialRateLimit, or
nullif it is not present. - getTransactionCreationInitialRateLimit() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getTransactionCreationInitialRateLimit(). - getTransactionCreationRateLimit() - Method in interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.DatastoreInfoMXBean
- getTransactionDebugContextEnabled() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return transactionDebugContextEnabled, or
nullif it is not present. - getTransactionDebugContextEnabled() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getTransactionDebugContextEnabled(). - getTransactionId() - Method in class org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier
- getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
-
Deprecated.
- getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
-
Deprecated.
- getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
-
Deprecated.
- getTransactionId() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- getTransactionIds() - Method in class org.opendaylight.controller.cluster.datastore.persisted.SkipTransactionsPayload
- getTransactionPath() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- getTransactionType() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- 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 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.ConcurrentDOMDataBroker
- getTxnClientVersion() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
-
Deprecated.
- 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
-
Deprecated.
- getType() - Method in class org.opendaylight.controller.cluster.datastore.modification.MergeModification
-
Deprecated.
- getType() - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
- getType() - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- getType() - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- 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.eos.akka.owner.checker.command.AbstractEntityRequest
- getType() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.AbstractEntityRequest
- getType() - Method in class org.opendaylight.controller.remote.rpc.messages.AbstractExecute
- getType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendIdentifier
-
Return type, or
nullif it is not present. - getType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityId
-
Return type, or
nullif it is not present. - getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Return current value associated with the property corresponding to
EntityId.getType(). - getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesKey
-
Return type, guaranteed to be non-null.
- getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Return current value associated with the property corresponding to
EntityId.getType(). - getType() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Return current value associated with the property corresponding to
EntityId.getType(). - 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
-
Return current value associated with the property corresponding to
FrontendIdentifier.getType(). - 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
-
Return type, guaranteed to be non-null.
- 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.
- getUseLz4Compression() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return useLz4Compression, or
nullif it is not present. - getUseLz4Compression() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Return current value associated with the property corresponding to
DataStoreProperties.getUseLz4Compression(). - 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.rev231229.HeartbeatIntervalType
- getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.NonZeroUint32Type
- getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.OperationTimeoutType
- getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.Percentage
- getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityType
- getValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.NodeName
- 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
-
Deprecated.
- getVersion() - Method in class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
-
Deprecated.
- getVersion() - Method in exception class org.opendaylight.controller.cluster.datastore.persisted.AbstractVersionException
-
Return the numeric version which has caused this exception.
- 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 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
- getVoting() - 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
-
Return voting, or
nullif it is not present. - getVoting() - 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
-
Return current value associated with the property corresponding to
MemberVotingState.getVoting(). - 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
ActorRefwhich 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
- 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
- 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.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
- handleJournalResponse(JournalProtocol.Response) - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
-
Receive and potentially handle a
JournalProtocolresponse. - handleJournalResponse(JournalProtocol.Response) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
- handleJournalResponse(JournalProtocol.Response) - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
- handleJournalResponse(JournalProtocol.Response) - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
- 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.JsonExportActor
- 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
-
Deprecated.
- handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardReadWriteTransaction
-
Deprecated.
- handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- handleReceive(Object) - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
-
Deprecated.
- handleReceive(Object) - Method in class org.opendaylight.controller.cluster.notifications.RoleChangeNotifier
- 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.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
- handleSnapshotResponse(SnapshotProtocol.Response) - Method in interface org.opendaylight.controller.cluster.DataPersistenceProvider
-
Receive and potentially handle a
SnapshotProtocolresponse. - handleSnapshotResponse(SnapshotProtocol.Response) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
- handleSnapshotResponse(SnapshotProtocol.Response) - Method in class org.opendaylight.controller.cluster.NonPersistentDataProvider
- handleSnapshotResponse(SnapshotProtocol.Response) - Method in class org.opendaylight.controller.cluster.PersistentDataProvider
- 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 record class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor.SetRegistration
-
Returns a hash code value for this object.
- 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 record class org.opendaylight.controller.cluster.datastore.messages.ActorInitialized
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.opendaylight.controller.cluster.datastore.messages.UpdateSchemaContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload.CandidateTransaction
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather.ShardContainer
-
Returns a hash code value for this object.
- hashCode() - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- hashCode() - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- hashCode() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- hashCode() - Method in record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.opendaylight.controller.cluster.raft.ClientRequestTracker
-
Returns a hash code value for this object.
- hashCode() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
- hashCode() - Method in record class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
-
Returns a hash code value for this object.
- hashCode() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
- 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.rev231229.HeartbeatIntervalType
- hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.NonZeroUint32Type
- hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.OperationTimeoutType
- hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.Percentage
- hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
- hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityType
- hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesKey
- hashCode() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.NodeName
- 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
- 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.rev231229
-
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
- HeartbeatIntervalType(HeartbeatIntervalType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.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.rev231229.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.
- 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
- IdentifiablePayload<T> - Class in org.opendaylight.controller.cluster.raft.messages
- IdentifiablePayload() - Constructor for class org.opendaylight.controller.cluster.raft.messages.IdentifiablePayload
- identifier() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
-
Deprecated.
- identifier() - Method in record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Returns the value of the
identifierrecord component. - identifier() - Method in record class org.opendaylight.controller.cluster.raft.ClientRequestTracker
-
Returns the value of the
identifierrecord component. - 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.
- IdleSupervisor - Class in org.opendaylight.controller.eos.akka.owner.supervisor
-
Initial Supervisor behavior that stays idle and only switches itself to the active behavior when its running in the primary datacenter, or is activated on demand.
- ignoreMessage(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedActor
- ignoreMessage(Object) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractUntypedPersistentActor
- immutableCopy() - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- immutableCopy() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- ImmutableElectionTerm - Class in org.opendaylight.controller.cluster.raft
-
Immutable implementation of ElectionTerm.
- ImmutableUnsignedLongSet - Class in org.opendaylight.controller.cluster.datastore.utils
- 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.cds.types.rev191024.OdlControllerCdsTypesData
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainer
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DistributedDatastoreProviderData
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.Candidates
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.Details
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityId
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.Entities
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntities
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntity
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwner
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.OdlEntityOwnersData
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.Owner
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenter
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShards
- 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.AddShardReplica
- 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.BackupDatastore
- 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.ChangeMemberVotingStatesForAllShards
- 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.ChangeMemberVotingStatesForShard
- 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.ClusterAdminData
- 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.DeactivateEosDatacenter
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutput
- implementedInterface() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShards
- 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.GetKnownClientsForAllShards
- 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.GetShardRole
- 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.LocateShard
- 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.MakeLeaderLocal
- 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.RemoveAllShardReplicas
- 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.RemoveShardReplica
- 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
- includeManifest() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
-
Deprecated.
- 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.
- IncrementTransactionSequenceRequest - Class in org.opendaylight.controller.cluster.access.commands
-
A blank transaction request.
- IncrementTransactionSequenceRequest(IncrementTransactionSequenceRequest, ABIVersion) - Constructor for class org.opendaylight.controller.cluster.access.commands.IncrementTransactionSequenceRequest
- 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.
- index() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
- index() - Method in interface org.opendaylight.controller.cluster.raft.RaftEntryMeta
-
Returns the index of the entry.
- inexactReadFrom(DataInput) - Static method in enum class org.opendaylight.controller.cluster.access.ABIVersion
- init(String) - Method in class org.opendaylight.controller.cluster.datastore.DataTreeCohortRegistrationProxy
- 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
- InitialCandidateSync - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- InitialCandidateSync(Replicator.GetResponse<ORMap<DOMEntity, ORSet<String>>>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.InitialCandidateSync
- initializeForPath(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
-
Initialize this pruner for processing a node at specified path.
- InitialOwnerSync - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- InitialOwnerSync - Class in org.opendaylight.controller.eos.akka.registry.listener.owner.command
- InitialOwnerSync(Replicator.GetResponse<LWWRegister<String>>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.InitialOwnerSync
- InitialOwnerSync(Replicator.GetResponse<LWWRegister<String>>) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.owner.command.InitialOwnerSync
- 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
- inJeopardy() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.EntityOwnerChanged
- 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>, short) - 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
-
Deprecated.
- instance(short) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
-
Deprecated.
- INSTANCE - Static variable in class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
-
Deprecated.
- 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.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.eos.akka.owner.supervisor.command.DataCenterActivated
- INSTANCE - Static variable in class org.opendaylight.controller.eos.akka.owner.supervisor.command.DataCenterDeactivated
- INSTANCE - Static variable in class org.opendaylight.controller.eos.akka.registry.listener.type.command.TerminateListener
- InternalClusterEvent - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- InternalCommand<T> - Interface in org.opendaylight.controller.cluster.access.client
-
This interface is used to pass the unit of work via the actors mailbox.
- InternalGetReply - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- InternalGetReply(Replicator.GetResponse<LWWRegister<String>>, DOMEntity, ActorRef<GetOwnershipStateReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.InternalGetReply
- internalSwitchBehavior(RaftActorBehavior) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
- internalSwitchBehavior(RaftState) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
- InternalUpdateResponse - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
- InternalUpdateResponse(Replicator.UpdateResponse<ORMap<DOMEntity, ORSet<String>>>) - Constructor for class org.opendaylight.controller.eos.akka.registry.candidate.command.InternalUpdateResponse
- INVALID_REQUEST - Enum constant in enum class org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
-
Some part of the request is invalid.
- 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 Class in org.opendaylight.controller.cluster.access.client
-
Exception thrown from
InversibleLock.optimisticRead()and can be used to wait for the racing write to complete usingInversibleLockException.awaitResolution(). - invoke(GetEntitiesInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntities
- invoke(GetEntityInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntity
- invoke(GetEntityOwnerInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwner
- invoke(ActivateEosDatacenterInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenter
- invoke(AddReplicasForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShards
- invoke(AddShardReplicaInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplica
- invoke(BackupDatastoreInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastore
- invoke(ChangeMemberVotingStatesForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShards
- invoke(ChangeMemberVotingStatesForShardInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShard
- invoke(DeactivateEosDatacenterInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenter
- invoke(FlipMemberVotingStatesForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShards
- invoke(GetKnownClientsForAllShardsInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShards
- invoke(GetShardRoleInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRole
- invoke(LocateShardInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShard
- invoke(MakeLeaderLocalInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocal
- invoke(RemoveAllShardReplicasInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicas
- invoke(RemoveShardReplicaInput) - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplica
- isActive() - Method in class org.opendaylight.controller.cluster.mgmt.api.FollowerInfo
- isApplying() - Method in class org.opendaylight.controller.cluster.raft.SnapshotManager
- isCandidateRegistered(DOMEntity) - Method in class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- 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
-
Deprecated.
- isDoCommitOnReady() - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
-
Deprecated.
- isDoImmediateCommit() - Method in class org.opendaylight.controller.cluster.datastore.messages.ForwardedReadyTransaction
-
Deprecated.
- 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
- isEmpty() - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- isEmpty() - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- isEmpty() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- isEnabled() - Method in class org.opendaylight.controller.cluster.datastore.messages.EnableNotification
- isEnabled() - Method in class org.opendaylight.controller.cluster.mgmt.api.DataTreeListenerInfo
- 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.LegacySerializable
-
Deprecated, for removal: This API element is subject to removal in a future version.
- 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 - Enum constant in enum class 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
- 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
-
Deprecated.
- 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 class org.opendaylight.controller.cluster.access.client.RequestTimeoutException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.commands.ClosedTransactionException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.commands.DeadHistoryException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.commands.DeadTransactionException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.commands.NotLeaderException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.commands.OutOfOrderRequestException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.commands.OutOfSequenceEnvelopeException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.commands.UnknownHistoryException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.concepts.RequestException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.concepts.RetiredGenerationException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.concepts.RuntimeRequestException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.access.concepts.UnsupportedRequestException
- isRetriable() - Method in exception class org.opendaylight.controller.cluster.messaging.MessageSliceException
-
Returns whether or not the original operation can be retried.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.AbortTransaction
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.AbortTransactionReply
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransaction
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransaction
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransaction
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CommitTransactionReply
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
-
Deprecated.
- isSerializedType(Object) - Static method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- isShardConfigured(String) - Method in interface org.opendaylight.controller.cluster.datastore.config.Configuration
- isShardConfigured(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ConfigurationImpl
- 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
- 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 class org.opendaylight.controller.cluster.access.commands.ClosedTransactionException
- isTransactionDebugContextEnabled() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
- isUseLz4Compression() - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext
- 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 interface org.opendaylight.controller.cluster.datastore.jmx.mbeans.shard.ShardStatsMXBean
- isVoting() - Method in class org.opendaylight.controller.cluster.mgmt.api.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 record class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
-
Returns the value of the
isVotingrecord component. - 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
J
- journalPluginId() - Method in class org.opendaylight.controller.cluster.datastore.Shard
- Json - Enum constant in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
- JsonExportActor - Class in org.opendaylight.controller.cluster.datastore.actors
- JsonExportActor.ExportJournal - Class in org.opendaylight.controller.cluster.datastore.actors
- JsonExportActor.ExportSnapshot - Class in org.opendaylight.controller.cluster.datastore.actors
- JsonExportActor.FinishExport - Class in org.opendaylight.controller.cluster.datastore.actors
K
- key() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.Entities
- key() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Return current value associated with the property corresponding to
key(). - 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
-
Return current value associated with the property corresponding to
KnownClients.key(). - 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
-
Return current value associated with the property corresponding to
ShardResult.key(). - KEY - Static variable in class org.opendaylight.controller.eos.akka.registry.candidate.CandidateRegistry
- 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
KnownClientsinstances. - 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
-
Construct an empty builder.
- 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
-
Construct a new builder initialized from specified
ClientIdentifier. - 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
-
Construct a new builder initialized from specified
FrontendIdentifier. - 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
-
Construct a builder initialized with state from specified
KnownClients. - 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
-
This class represents the key of
KnownClientsclass. - 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
-
Constructs an instance.
- 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
- lastMeta() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
- lastMeta() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
-
Return the last replicated log entry in the log or null of not found.
- 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 - Enum constant in enum class 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
LeaderActorRefinstances. - 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
-
Construct an empty builder.
- 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
-
Construct a builder initialized with state from specified
LeaderActorRef. - leaderAddress() - Method in class org.opendaylight.controller.cluster.raft.messages.AppendEntries
- LeaderInstallSnapshotState - Class in org.opendaylight.controller.cluster.raft.behaviors
-
Encapsulates the leader state and logic for sending snapshot chunks to a follower.
- LeaderLocation - Enum Class 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.
- LeadershipTransferFailedException - Exception Class in org.opendaylight.controller.cluster.raft
- LeadershipTransferFailedException(String) - Constructor for exception class org.opendaylight.controller.cluster.raft.LeadershipTransferFailedException
- LeadershipTransferFailedException(String, Throwable) - Constructor for exception class 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
- LegacySerializable - Interface in org.opendaylight.controller.cluster.raft.persisted
-
Deprecated.
- ListenerCommand - Class in org.opendaylight.controller.eos.akka.registry.listener.owner.command
- LITHIUM_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
-
Deprecated.
- 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 - Enum constant in enum class 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
Localinstances. - 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
-
Construct an empty builder.
- 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
-
Construct a builder initialized with state from specified
Local. - LocalHistoryFailure - Class in org.opendaylight.controller.cluster.access.commands
-
Generic
RequestFailureinvolving aLocalHistoryRequest. - 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> - 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
- localShardDataTree() - Method in class org.opendaylight.controller.cluster.datastore.messages.ShardLeaderStateChanged
- 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 Class 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 class 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 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
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
LocateShardInputinstances. - LocateShardInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Construct an empty builder.
- LocateShardInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Construct a new builder initialized from specified
DatastoreShardId. - LocateShardInputBuilder(LocateShardInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Construct a builder initialized with state from specified
LocateShardInput. - 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
LocateShardOutputinstances. - LocateShardOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
-
Construct an empty builder.
- LocateShardOutputBuilder(LocateShardOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
-
Construct a builder initialized with state from specified
LocateShardOutput. - log - Variable in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
-
Used for message logging.
- log - Variable in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteActionRegistryMXBeanImpl
- log - Variable in class org.opendaylight.controller.remote.rpc.registry.mbeans.RemoteRpcRegistryMXBeanImpl
- 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
- logIndex() - Method in record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Returns the value of the
logIndexrecord component. - logIndex() - Method in record class org.opendaylight.controller.cluster.raft.ClientRequestTracker
-
Returns the value of the
logIndexrecord component. - logName() - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
- lookupMeta(long) - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLog
-
Return metadata about a replicated entry.
- lt(ABIVersion) - Method in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Return
trueif this version is earier than someotherversion. - 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
- 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 - Class in org.opendaylight.controller.cluster.datastore.messages
-
Message sent to local shard to try to gain shard leadership.
- MakeLeaderLocal - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Attempts to move the shard leader of the given module based shard to the local node.
- 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
MakeLeaderLocalInputinstances. - MakeLeaderLocalInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Construct an empty builder.
- MakeLeaderLocalInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Construct a new builder initialized from specified
DatastoreShardId. - MakeLeaderLocalInputBuilder(MakeLeaderLocalInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Construct a builder initialized with state from specified
MakeLeaderLocalInput. - 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
MakeLeaderLocalOutputinstances. - MakeLeaderLocalOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
-
Construct an empty builder.
- MakeLeaderLocalOutputBuilder(MakeLeaderLocalOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutputBuilder
-
Construct a builder initialized with state from specified
MakeLeaderLocalOutput. - 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
- 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
- MemberDownEvent - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- MemberDownEvent(Address, Set<String>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.MemberDownEvent
- 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
-
This class represents the following YANG schema fragment defined in module odl-controller-cds-types
- 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.
- MemberReachableEvent - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- MemberReachableEvent(Address, Set<String>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.MemberReachableEvent
- MemberUnreachableEvent - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- MemberUnreachableEvent(Address, Set<String>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.MemberUnreachableEvent
- MemberUpEvent - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- MemberUpEvent(Address, Set<String>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.MemberUpEvent
- 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
MemberVotingStateinstances. - 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
-
Construct an empty builder.
- 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
-
Construct a builder initialized with state from specified
MemberVotingState. - 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(YangInstanceIdentifier.PathArgument, NormalizedNode) - Method in class org.opendaylight.controller.cluster.datastore.utils.AbstractBatchedModificationsCursor
-
Deprecated.
- 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.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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- MergeModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MergeModification
-
Deprecated.
- MergeModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MergeModification
-
Deprecated.
- MergeModification(YangInstanceIdentifier, NormalizedNode) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MergeModification
-
Deprecated.
- message() - Method in interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- message(T) - Method in class org.opendaylight.controller.cluster.messaging.SliceOptions.Builder
-
Sets the message to slice.
- Message<T,
C> - Class in org.opendaylight.controller.cluster.access.concepts -
An abstract concept of a Message.
- Message.SerialForm<T,
C> - Interface in org.opendaylight.controller.cluster.access.concepts -
Externalizable proxy for use with
Messagesubclasses. - 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 Class in org.opendaylight.controller.cluster.messaging
-
An exception indicating a message slice failure.
- MessageSliceException(String, boolean) - Constructor for exception class org.opendaylight.controller.cluster.messaging.MessageSliceException
-
Constructs an instance.
- MessageSliceException(String, Throwable) - Constructor for exception class 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
AbstractVersionedShardDataTreeSnapshotwhich 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() - Element in annotation interface 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.
- modelContext() - Method in record class org.opendaylight.controller.cluster.datastore.messages.UpdateSchemaContext
-
Returns the value of the
modelContextrecord component. - modelContext() - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
- 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
ModifyTransactionRequestmessage 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
ModifyTransactionRequestwhich does not have aPersistenceProtocol. - 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(XMLNamespace, 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- MutableCompositeModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- MutableCompositeModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- mutableCopy() - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- mutableCopy() - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- mutableCopy() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- MutableUnsignedLongSet - Class in org.opendaylight.controller.cluster.datastore.utils
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
- nameSpace(String) - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleConfig.Builder
- nanosSinceLastActivity() - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
-
Returns the time since the last activity occurred for the follower.
- 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. a new snapshot should be created after recovery.
- NEON_SR2_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
-
Deprecated.
- 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(RaftEntryMeta, 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
- newInstance() - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStreamFactory
-
Creates a new
FileBackedOutputStreamwith the settings configured for this factory. - newInstance(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
-
Deprecated.
- newInstance(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExists
-
Deprecated.
- newInstance(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
-
Deprecated.
- 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, Map<String, Object>) - Method in interface org.opendaylight.controller.cluster.datastore.DatastoreContextIntrospectorFactory
-
Create a new
DatastoreContextIntrospectorinitialized with specified properties. - newInstance(LogicalDatastoreType, Map<String, Object>) - Method in class org.opendaylight.controller.cluster.datastore.DefaultDatastoreContextIntrospectorFactory
- newInstance(LogicalDatastoreType, Map<String, Object>) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDatastoreContextIntrospectorFactory
- 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.utils.PruningDataTreeModification
- newOnDemandRaftStateBuilder() - Method in class org.opendaylight.controller.cluster.datastore.Shard
- newOnDemandRaftStateBuilder() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
- newRaftActorRecoverySupport() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
- newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
- newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- newReadOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
- newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- newReadWriteTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- 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
SharedFileBackedOutputStreamwith the settings configured for this factory. - 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.
- newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ClientBackedDataStore
- newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- newWriteOnlyTransaction() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- no(short) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
- NO_INDEX - Static variable in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
- NO_LEADER - Enum constant in enum class 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
- NodeName - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- NodeName(String) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.NodeName
- NodeName(NodeName) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.NodeName
-
Creates a copy from Source Object.
- NON_PERSISTENT_JOURNAL_ID - Static variable in class org.opendaylight.controller.cluster.datastore.Shard
- NON_VOTING - Enum constant in enum class org.opendaylight.controller.cluster.raft.VotingState
- nonnullDataStorePropertiesContainer() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DistributedDatastoreProviderData
-
Return dataStorePropertiesContainer, or an empty instance if it is not present.
- nonnullEntities() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutput
-
Return entities, or an empty list if it is not present.
- 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
-
Return knownClients, or an empty list if it is not present.
- nonnullMemberVotingState() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MemberVotingStatesInput
-
Return memberVotingState, or an empty list if it is not present.
- nonnullShardResult() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardResultOutput
-
Return shardResult, or an empty list if it is not present.
- 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.rev231229
-
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
- NonZeroUint32Type(NonZeroUint32Type) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.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.rev231229.NonZeroUint32Type
- 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
NormalizedNodeVisitorthrough 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 Class in org.opendaylight.controller.cluster.datastore.exceptions
-
Exception indicating a shard has no current leader.
- NoShardLeaderException(String) - Constructor for exception class org.opendaylight.controller.cluster.datastore.exceptions.NoShardLeaderException
- NoShardLeaderException(String, String) - Constructor for exception class org.opendaylight.controller.cluster.datastore.exceptions.NoShardLeaderException
- NoShardLeaderException(ShardIdentifier) - Constructor for exception class org.opendaylight.controller.cluster.datastore.exceptions.NoShardLeaderException
- NOT_SUPPORTED - Enum constant in enum class org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
-
An unsupported request, for example removing the leader in a single node cluster.
- Notification - Enum constant in enum class org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
- NOTIFICATION_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
- notifyOnCompleteTasks(Throwable, T) - Method in class org.opendaylight.controller.cluster.datastore.utils.CompositeOnComplete
- 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 Class in org.opendaylight.controller.cluster.datastore.exceptions
- NotInitializedException(String) - Constructor for exception class org.opendaylight.controller.cluster.datastore.exceptions.NotInitializedException
- NotLeaderException - Exception Class 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 class org.opendaylight.controller.cluster.access.commands.NotLeaderException
O
- OdlControllerCdsTypesData - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
-
Common type definitions related to clustered data store.
- OdlEntityOwnersData - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
An initial cut at modeling entity ownership status information in a way which not dependent on the datastore.
- of() - Static method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- of() - Static method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- of() - Static method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- of(long...) - Static method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- of(long, boolean) - Static method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- Off - Enum constant in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
- ofName(String) - Static method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
-
Return the enumeration member whose
DataStoreProperties.ExportOnRecovery.getName()matches specified assigned name. - ofName(String) - Static method in enum class 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 assigned name. - ofValue(int) - Static method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
-
Return the enumeration member whose
DataStoreProperties.ExportOnRecovery.getIntValue()matches specified value. - ofValue(int) - Static method in enum class 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. - OK - Enum constant in enum class 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.
- onClose() - Method in record class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor.SetRegistration
-
Returns the value of the
onCloserecord component. - 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.
- onDatastoreContextUpdated(DatastoreContextFactory) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
- onDatastoreContextUpdated(DatastoreContextFactory) - Method in interface org.opendaylight.controller.cluster.datastore.DatastoreContextPropertiesUpdater.Listener
- 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,
T> - 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
- 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.
- 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
- onVotingStateChangeComplete() - Method in class org.opendaylight.controller.cluster.raft.RaftActor
-
This method is called on the leader when a voting change operation completes.
- openStream() - Method in class org.opendaylight.controller.cluster.io.ChunkedByteArray
- Operational - Enum constant in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
- 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.rev231229
-
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
- OperationTimeoutType(OperationTimeoutType) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.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.rev231229.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.mgmt.api - package org.opendaylight.controller.cluster.mgmt.api
- 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.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.eos.akka - package org.opendaylight.controller.eos.akka
- org.opendaylight.controller.eos.akka.bootstrap - package org.opendaylight.controller.eos.akka.bootstrap
- org.opendaylight.controller.eos.akka.bootstrap.command - package org.opendaylight.controller.eos.akka.bootstrap.command
- org.opendaylight.controller.eos.akka.owner.checker - package org.opendaylight.controller.eos.akka.owner.checker
- org.opendaylight.controller.eos.akka.owner.checker.command - package org.opendaylight.controller.eos.akka.owner.checker.command
- org.opendaylight.controller.eos.akka.owner.supervisor - package org.opendaylight.controller.eos.akka.owner.supervisor
- org.opendaylight.controller.eos.akka.owner.supervisor.command - package org.opendaylight.controller.eos.akka.owner.supervisor.command
- org.opendaylight.controller.eos.akka.registry.candidate - package org.opendaylight.controller.eos.akka.registry.candidate
- org.opendaylight.controller.eos.akka.registry.candidate.command - package org.opendaylight.controller.eos.akka.registry.candidate.command
- org.opendaylight.controller.eos.akka.registry.listener.owner - package org.opendaylight.controller.eos.akka.registry.listener.owner
- org.opendaylight.controller.eos.akka.registry.listener.owner.command - package org.opendaylight.controller.eos.akka.registry.listener.owner.command
- org.opendaylight.controller.eos.akka.registry.listener.type - package org.opendaylight.controller.eos.akka.registry.listener.type
- org.opendaylight.controller.eos.akka.registry.listener.type.command - package org.opendaylight.controller.eos.akka.registry.listener.type.command
- org.opendaylight.controller.md.sal.common.util.jmx - package org.opendaylight.controller.md.sal.common.util.jmx
- 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.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.rev231229 - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229
- org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
- org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output - package org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output
- 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.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024 - package org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
- org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229 - package org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229
- org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev - package org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
- org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013 - package org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
- OSGiActorSystemProvider - Class in org.opendaylight.controller.cluster.akka.osgi.impl
- OSGiActorSystemProvider(AkkaConfigurationReader, BundleContext) - Constructor for class org.opendaylight.controller.cluster.akka.osgi.impl.OSGiActorSystemProvider
- OSGiClusterAdmin - Class in org.opendaylight.controller.cluster.datastore.admin
- OSGiClusterAdmin(DistributedDataStoreInterface, DistributedDataStoreInterface, RpcProviderService, DataCenterControl) - 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(DOMSchemaService, ActorSystemProvider, DatastoreContextIntrospectorFactory, DatastoreSnapshotRestore, ModuleShardConfigProvider, ComponentFactory<OSGiDOMStore>, Map<String, Object>) - Constructor for class org.opendaylight.controller.cluster.datastore.OSGiDistributedDataStore
- OSGiDOMStore - Class in org.opendaylight.controller.cluster.datastore
-
OSGi manifestation of a the distributed datastore, as represented by
AbstractDataStore. - OSGiDOMStore(Map<String, ?>) - Constructor for class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- OSGiRemoteOpsProvider - Class in org.opendaylight.controller.remote.rpc
- OSGiRemoteOpsProvider(ActorSystemProvider, DOMRpcProviderService, DOMRpcService, DOMActionProviderService, DOMActionService, OSGiRemoteOpsProvider.Config) - Constructor for class org.opendaylight.controller.remote.rpc.OSGiRemoteOpsProvider
- OSGiRemoteOpsProvider.Config - Annotation Interface in org.opendaylight.controller.remote.rpc
- OutOfOrderRequestException - Exception Class in org.opendaylight.controller.cluster.access.commands
-
A
RequestExceptionindicating that the backend has received a Request whose sequence does not match the next expected sequence for the target. - OutOfOrderRequestException(long) - Constructor for exception class org.opendaylight.controller.cluster.access.commands.OutOfOrderRequestException
- OutOfSequenceEnvelopeException - Exception Class in org.opendaylight.controller.cluster.access.commands
-
A
RequestExceptionindicating that the backend has received a RequestEnvelope whose sequence does not match the next expected sequence. - OutOfSequenceEnvelopeException(long) - Constructor for exception class org.opendaylight.controller.cluster.access.commands.OutOfSequenceEnvelopeException
- Owner - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
This class represents the following YANG schema fragment defined in module odl-entity-owners
- OwnerChanged - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- OwnerChanged - Class in org.opendaylight.controller.eos.akka.registry.listener.owner.command
-
Notification from distributed-data sent to the SingleEntityListenerActor when owner changes for the tracked entity.
- OwnerChanged(Replicator.SubscribeResponse<LWWRegister<String>>) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.owner.command.OwnerChanged
- OwnerChanged(Replicator.UpdateResponse<LWWRegister<String>>) - Constructor for class org.opendaylight.controller.eos.akka.owner.supervisor.command.OwnerChanged
- OwnerDataResponse - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- OwnerDataResponse(Replicator.GetResponse<LWWRegister<String>>, ActorRef<GetEntitiesReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.OwnerDataResponse
- OwnerStateChecker - Class in org.opendaylight.controller.eos.akka.owner.checker
- ownerSupervisor - Variable in class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- OwnerSupervisor - Class in org.opendaylight.controller.eos.akka.owner.supervisor
-
Responsible for tracking candidates and assigning ownership of entities.
- OwnerSupervisorCommand - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- OwnerSupervisorReply - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- OwnerSupervisorRequest<T> - Class in org.opendaylight.controller.eos.akka.owner.supervisor.command
- OwnerSyncer - Class in org.opendaylight.controller.eos.akka.owner.supervisor
-
Behavior that retrieves current candidates/owners from distributed-data and switches to OwnerSupervisor when the sync has finished.
P
- PastVersionException - Exception Class 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 Class 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_CONSTANTS - Static variable in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendType
- 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.messages
-
An instance of a
Payloadclass is meant to be used as the Payload forAppendEntries. - Payload() - Constructor for class org.opendaylight.controller.cluster.raft.messages.Payload
- PayloadVersion - Enum Class 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.
- peerId() - Method in record class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
-
Returns the value of the
peerIdrecord component. - 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.
- 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.rev231229
-
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
- Percentage(Percentage) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.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.rev231229.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.remote.rpc.registry.gossip.BucketStoreActor
- PersistenceProtocol - Enum Class 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.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.
- PHOSPHORUS_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
-
Deprecated.
- 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
- POTASSIUM - Enum constant in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Oldest ABI version we support.
- POTASSIUM - Enum constant in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
ABI version shipped enabled
2023.09 Potassium. - POTASSIUM_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
- PRE_COMMIT_COMPLETE - Enum constant in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
- PRE_COMMIT_PENDING - Enum constant in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
- preCommit(FutureCallback<DataTreeCandidate>) - Method in class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort
- PreLeader - Class in org.opendaylight.controller.cluster.raft.behaviors
-
The behavior of a RaftActor when it is in the PreLeader state.
- PreLeader - Enum constant in enum class 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.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
- PrimaryNotFoundException - Exception Class in org.opendaylight.controller.cluster.datastore.exceptions
- PrimaryNotFoundException(String) - Constructor for exception class 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 - Enum constant in enum class 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
-
Deprecated.
- processResponse(Object, SettableFuture<Optional<NormalizedNode>>) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadData
-
Deprecated.
- processResponse(Object, SettableFuture<T>) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
-
Deprecated.
- 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(Effect) - Static method in class org.opendaylight.controller.cluster.common.actor.QuarantinedMonitorActor
- 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(TransactionType, AbstractShardDataTreeTransaction<?>, ActorRef, DatastoreContext, ShardStats) - Static method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- 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
- props(EffectiveModelContext, String) - Static method in class org.opendaylight.controller.cluster.datastore.actors.JsonExportActor
- 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. the frontend has removed it from its tracking.
- 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.
- 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.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainer
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.Entities
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntities
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntity
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwner
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenter
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShards
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplica
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastore
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShards
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShard
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenter
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShards
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.FlipMemberVotingStatesForAllShardsOutput
-
YANG identifier of the statement represented by this class.
- 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
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShards
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetKnownClientsForAllShardsOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRole
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
-
YANG identifier of the statement represented by this class.
- 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
-
YANG identifier of the statement represented by this class.
- 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
-
YANG identifier of the statement represented by this class.
- 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
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShard
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocal
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalOutput
-
YANG identifier of the statement represented by this class.
- 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
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicas
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplica
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
-
YANG identifier of the statement represented by this class.
- QNAME - Static variable in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutput
-
YANG identifier of the statement represented by this class.
- 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
-
YANG identifier of the statement represented by this class.
- qnameOf(String) - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.YangModuleInfoImpl
-
Create an interned
QNamewith specifiedlocalNameand namespace/revision of this module. - qnameOf(String) - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.YangModuleInfoImpl
-
Create an interned
QNamewith specifiedlocalNameand namespace/revision of this module. - qnameOf(String) - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.YangModuleInfoImpl
-
Create an interned
QNamewith specifiedlocalNameand namespace/revision of this module. - qnameOf(String) - Static method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.YangModuleInfoImpl
-
Create an interned
QNamewith specifiedlocalNameand namespace/revision of this module. - 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.
- RaftEntryMeta - Interface in org.opendaylight.controller.cluster.raft
-
Metadata about a RAFT journal entry.
- 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 Class in org.opendaylight.controller.cluster.raft
- RaftVersions - Class in org.opendaylight.controller.cluster.raft
-
Enumerates the raft versions.
- ranges() - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- ranges() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- rangeSize() - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- rangeSize() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- 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(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_ONLY - Enum constant in enum class org.opendaylight.controller.cluster.datastore.TransactionType
- READ_WRITE - Enum constant in enum class org.opendaylight.controller.cluster.datastore.TransactionType
- readData(AbstractShardDataTreeTransaction<?>, ReadData) - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- readData(ReadData) - Method in class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
-
Deprecated.
- ReadData - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ReadData() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadData
-
Deprecated.
- ReadData(YangInstanceIdentifier, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadData
-
Deprecated.
- ReadDataReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ReadDataReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
-
Deprecated.
- ReadDataReply(NormalizedNode, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
-
Deprecated.
- readDataTreeCandidate(DataInput, ReusableStreamReceiver) - Static method in class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput
- readExternal(byte[]) - Method in interface org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.SerialForm
-
Restore state from specified serialized form.
- readExternal(ObjectInput, T, long) - Method in interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- readExternal(ObjectInput, T, long, ActorRef) - Method in interface org.opendaylight.controller.cluster.access.concepts.Request.SerialForm
- readExternal(ObjectInput) - Method in interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- readExternal(ObjectInput) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- readExternal(ObjectInput) - Method in interface org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.SerialForm
- readExternal(ObjectInput, T, long) - Method in interface org.opendaylight.controller.cluster.access.concepts.Request.SerialForm
- readExternal(ObjectInput, T, long) - Method in interface org.opendaylight.controller.cluster.access.concepts.RequestFailure.SerialForm
- readFrom(DataInput) - Static method in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Read an
ABIVersionfrom aDataInput. - readFrom(DataInput) - Static method in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
Read an
PayloadVersionfrom aDataInput. - readFrom(DataInput, int) - Static method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- readFrom(DataInput) - Static method in enum class 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
- readFrom(DataInput) - Static method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- readFrom(DataInput, int) - Static method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- readFrom(ObjectInput, int, int) - Static method in class org.opendaylight.controller.cluster.io.ChunkedByteArray
- readinessFuture() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
- readinessFuture(SettableFuture<Empty>) - 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 interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- readResolve() - Method in interface org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.SerialForm
-
Resolve this proxy to an actual
AbstractIdentifiablePayload. - readTarget(DataInput) - Method in interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- readTarget(DataInput) - Method in interface org.opendaylight.controller.cluster.access.commands.TransactionRequest.SerialForm
- 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
- readVersionInfo(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.utils.PruningDataTreeModification
- 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.utils.PruningDataTreeModification
- READY - Enum constant in enum class org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
-
Transaction is ready.
- READY - Enum constant in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
- ReadyLocalTransaction - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ReadyLocalTransaction(TransactionIdentifier, DataTreeModification, boolean, Optional<SortedSet<String>>) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
-
Deprecated.
- ReadyLocalTransactionSerializer - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ReadyLocalTransactionSerializer(ExtendedActorSystem) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransactionSerializer
-
Deprecated.
- ReadyTransactionReply - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ReadyTransactionReply() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- ReadyTransactionReply(String) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- ReadyTransactionReply(String, short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- 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> - Class in org.opendaylight.controller.cluster.access.client
-
An
AbstractClientConnectionwhich is being reconnected after having timed out. - recoveryExportBaseDir(String) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
- 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.
- 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
- registerCandidate(DOMEntity) - Method in class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- RegisterCandidate - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
-
Sent to Candidate registry to register the candidate for a given entity.
- RegisterCandidate(DOMEntity, String) - Constructor for class org.opendaylight.controller.eos.akka.registry.candidate.command.RegisterCandidate
- registerCommitCohort(DOMDataTreeIdentifier, DOMDataTreeCommitCohort) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
- registerCommitCohort(DOMDataTreeIdentifier, DOMDataTreeCommitCohort) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- RegisterDataTreeChangeListener - Class in org.opendaylight.controller.cluster.datastore.messages
-
Request a
DOMDataTreeChangeListenerregistration 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
- 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
- registerLegacyTreeChangeListener(YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
-
Deprecated, for removal: This API element is subject to removal in a future version.
- registerLegacyTreeChangeListener(YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- registerListener(String, DOMEntityOwnershipListener) - Method in class org.opendaylight.controller.eos.akka.AkkaEntityOwnershipService
- RegisterListener - Class in org.opendaylight.controller.eos.akka.registry.listener.type.command
-
Register a DOMEntityOwnershipListener for a given entity-type.
- RegisterListener(String, DOMEntityOwnershipListener) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.type.command.RegisterListener
- 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
- registerTreeChangeListener(YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
- registerTreeChangeListener(YangInstanceIdentifier, DOMDataTreeChangeListener) - Method in class org.opendaylight.controller.cluster.datastore.OSGiDOMStore
- registration() - Method in record class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor.SetRegistration
-
Returns the value of the
registrationrecord component. - REMOTE - Enum constant in enum class 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 Class 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
- 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 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
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
RemoveAllShardReplicasInputinstances. - RemoveAllShardReplicasInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
-
Construct an empty builder.
- RemoveAllShardReplicasInputBuilder(RemoveAllShardReplicasInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
-
Construct a builder initialized with state from specified
RemoveAllShardReplicasInput. - 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
RemoveAllShardReplicasOutputinstances. - RemoveAllShardReplicasOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
-
Construct an empty builder.
- RemoveAllShardReplicasOutputBuilder(RemoveAllShardReplicasOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
-
Construct a builder initialized with state from specified
RemoveAllShardReplicasOutput. - RemoveAllShardReplicasOutputBuilder(ShardResultOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder
-
Construct a new builder initialized from specified
ShardResultOutput. - removeAugmentation(Class<? extends Augmentation<DataStorePropertiesContainer>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<Entities>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<GetEntitiesInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesInputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<GetEntitiesOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<GetEntityInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<GetEntityOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<GetEntityOwnerInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<GetEntityOwnerOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<ActivateEosDatacenterInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterInputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<ActivateEosDatacenterOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ActivateEosDatacenterOutputBuilder
-
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<DeactivateEosDatacenterInput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterInputBuilder
-
Remove an augmentation from this builder's product.
- removeAugmentation(Class<? extends Augmentation<DeactivateEosDatacenterOutput>>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DeactivateEosDatacenterOutputBuilder
-
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<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<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.
- 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
- RemovePreviousCandidates - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
-
Message sent to candidate registry initial behavior by self to trigger and retrigger(in case of failures) removal of candidates registered by the previous iteration of this node.
- RemovePreviousCandidates() - Constructor for class org.opendaylight.controller.eos.akka.registry.candidate.command.RemovePreviousCandidates
- 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 - 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 - Interface in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
Removes an existing replica of a shard from this node via the RemoveServer mechanism as described in the Raft paper.
- 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
RemoveShardReplicaInputinstances. - RemoveShardReplicaInputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Construct an empty builder.
- RemoveShardReplicaInputBuilder(DatastoreShardId) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Construct a new builder initialized from specified
DatastoreShardId. - RemoveShardReplicaInputBuilder(RemoveShardReplicaInput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Construct a builder initialized with state from specified
RemoveShardReplicaInput. - 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
RemoveShardReplicaOutputinstances. - RemoveShardReplicaOutputBuilder() - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
-
Construct an empty builder.
- RemoveShardReplicaOutputBuilder(RemoveShardReplicaOutput) - Constructor for class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaOutputBuilder
-
Construct a builder initialized with state from specified
RemoveShardReplicaOutput. - 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
- Replicate - Record Class in org.opendaylight.controller.cluster.raft.base.messages
- Replicate(long, boolean, ActorRef, Identifier) - Constructor for record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Creates an instance of a
Replicaterecord class. - 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,
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
- Request.SerialForm<T,
C> - Interface in org.opendaylight.controller.cluster.access.concepts - 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 Class in org.opendaylight.controller.cluster.access.concepts
-
A failure cause behind a
RequestFailureto process aRequest. - RequestException(String) - Constructor for exception class org.opendaylight.controller.cluster.access.concepts.RequestException
- RequestException(String, Throwable) - Constructor for exception class org.opendaylight.controller.cluster.access.concepts.RequestException
- 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
- RequestFailure.SerialForm<T,
C> - Interface in org.opendaylight.controller.cluster.access.concepts -
Externalizable proxy for use with
RequestFailuresubclasses. - 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,
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
- RequestSuccess.SerialForm<T,
C> - Interface in org.opendaylight.controller.cluster.access.concepts - RequestTimeoutException - Exception Class in org.opendaylight.controller.cluster.access.client
- RequestTimeoutException(String) - Constructor for exception class 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
- requireBackendAlivenessTimerIntervalInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return backendAlivenessTimerIntervalInSeconds, guaranteed to be non-null.
- requireBoundedMailboxCapacity() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return boundedMailboxCapacity, guaranteed to be non-null.
- requireCandidateNodes() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.Candidates
-
Return candidateNodes, guaranteed to be non-null.
- requireCustomRaftPolicyImplementation() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return customRaftPolicyImplementation, guaranteed to be non-null.
- requireDataStoreType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
-
Return dataStoreType, guaranteed to be non-null.
- requireEnableMetricCapture() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return enableMetricCapture, guaranteed to be non-null.
- requireErrorMessage() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
-
Return errorMessage, guaranteed to be non-null.
- requireExportOnRecovery() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return exportOnRecovery, guaranteed to be non-null.
- requireFileBackedStreamingThresholdInMegabytes() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return fileBackedStreamingThresholdInMegabytes, guaranteed to be non-null.
- requireFilePath() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
-
Return filePath, guaranteed to be non-null.
- requireFrontendNoProgressTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return frontendNoProgressTimeoutInSeconds, guaranteed to be non-null.
- requireFrontendRequestTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return frontendRequestTimeoutInSeconds, guaranteed to be non-null.
- requireGeneration() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.ClientIdentifier
-
Return generation, guaranteed to be non-null.
- requireInitialPayloadSerializedBufferCapacity() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return initialPayloadSerializedBufferCapacity, guaranteed to be non-null.
- requireInitialSettleTimeoutMultiplier() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return initialSettleTimeoutMultiplier, guaranteed to be non-null.
- requireLeaderActorRef() - 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
-
Return leaderActorRef, guaranteed to be non-null.
- requireLocal() - 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
-
Return local, guaranteed to be non-null.
- requireMaximumMessageSliceSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return maximumMessageSliceSize, guaranteed to be non-null.
- requireMember() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendIdentifier
-
Return member, guaranteed to be non-null.
- requireMemberName() - 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
-
Return memberName, guaranteed to be non-null.
- requireMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput
-
Return memberName, guaranteed to be non-null.
- requireMemberName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput
-
Return memberName, guaranteed to be non-null.
- requireName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityId
-
Return name, guaranteed to be non-null.
- requireOperationTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return operationTimeoutInSeconds, guaranteed to be non-null.
- requireOwnerNode() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.Owner
-
Return ownerNode, guaranteed to be non-null.
- requirePersistent() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return persistent, guaranteed to be non-null.
- requireRecoveryExportBaseDir() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return recoveryExportBaseDir, guaranteed to be non-null.
- requireRecoverySnapshotIntervalSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return recoverySnapshotIntervalSeconds, guaranteed to be non-null.
- requireRole() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleOutput
-
Return role, guaranteed to be non-null.
- requireShardBatchedModificationCount() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardBatchedModificationCount, guaranteed to be non-null.
- requireShardCommitQueueExpiryTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardCommitQueueExpiryTimeoutInSeconds, guaranteed to be non-null.
- requireShardElectionTimeoutFactor() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardElectionTimeoutFactor, guaranteed to be non-null.
- requireShardHeartbeatIntervalInMillis() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardHeartbeatIntervalInMillis, guaranteed to be non-null.
- requireShardInitializationTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardInitializationTimeoutInSeconds, guaranteed to be non-null.
- requireShardIsolatedLeaderCheckIntervalInMillis() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardIsolatedLeaderCheckIntervalInMillis, guaranteed to be non-null.
- requireShardJournalRecoveryLogBatchSize() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardJournalRecoveryLogBatchSize, guaranteed to be non-null.
- requireShardLeaderElectionTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardLeaderElectionTimeoutInSeconds, guaranteed to be non-null.
- requireShardName() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DatastoreShardId
-
Return shardName, guaranteed to be non-null.
- requireShardSnapshotBatchCount() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardSnapshotBatchCount, guaranteed to be non-null.
- requireShardSnapshotDataThreshold() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardSnapshotDataThreshold, guaranteed to be non-null.
- requireShardSnapshotDataThresholdPercentage() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardSnapshotDataThresholdPercentage, guaranteed to be non-null.
- requireShardTransactionCommitQueueCapacity() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardTransactionCommitQueueCapacity, guaranteed to be non-null.
- requireShardTransactionCommitTimeoutInSeconds() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardTransactionCommitTimeoutInSeconds, guaranteed to be non-null.
- requireShardTransactionIdleTimeoutInMinutes() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return shardTransactionIdleTimeoutInMinutes, guaranteed to be non-null.
- requireSnapshotOnRootOverwrite() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return snapshotOnRootOverwrite, guaranteed to be non-null.
- requireSucceeded() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ShardOperationResult
-
Return succeeded, guaranteed to be non-null.
- requireSyncIndexThreshold() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return syncIndexThreshold, guaranteed to be non-null.
- requireTimeout() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput
-
Return timeout, guaranteed to be non-null.
- requireTransactionCreationInitialRateLimit() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return transactionCreationInitialRateLimit, guaranteed to be non-null.
- requireTransactionDebugContextEnabled() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return transactionDebugContextEnabled, guaranteed to be non-null.
- requireType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.FrontendIdentifier
-
Return type, guaranteed to be non-null.
- requireType() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityId
-
Return type, guaranteed to be non-null.
- requireUseLz4Compression() - Method in interface org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties
-
Return useLz4Compression, guaranteed to be non-null.
- requireVoting() - 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
-
Return voting, guaranteed to be non-null.
- 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.utils.ActorUtils
- 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.
- 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.
- resourceName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.YangModuleInfoImpl
- resourceName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.YangModuleInfoImpl
- resourceName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.YangModuleInfoImpl
- resourceName() - Method in class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.YangModuleInfoImpl
- Response<T,
C> - Class in org.opendaylight.controller.cluster.access.concepts -
Abstract counterpart to a
Request. - Response.SerialForm<T,
C> - Interface in org.opendaylight.controller.cluster.access.concepts - ResponseEnvelope<T> - 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
- RetiredGenerationException - Exception Class in org.opendaylight.controller.cluster.access.concepts
-
General error raised when the recipient of a
Requestdetermines that the request contains aClientIdentifierwhich corresponds to an outdated generation. - RetiredGenerationException(long, long) - Constructor for exception class 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
-
Deprecated.
- returnCloseTransactionReply() - Method in class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- 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
- 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.
- RootScatterGather - Class in org.opendaylight.controller.cluster.datastore.utils
-
Utility methods for dealing with datastore root
ContainerNodewith respect to module shards. - RootScatterGather.ShardContainer<T> - Record Class in org.opendaylight.controller.cluster.datastore.utils
- RoutingTable - Class in org.opendaylight.controller.remote.rpc.registry
- RpcErrorsException - Exception Class in org.opendaylight.controller.remote.rpc
-
An Exception for transferring RpcErrors.
- RpcErrorsException(String, Iterable<? extends RpcError>) - Constructor for exception class 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(ContainerNode) - Constructor for class org.opendaylight.controller.remote.rpc.messages.RpcResponse
- RunningContext - Class in org.opendaylight.controller.eos.akka.bootstrap.command
- RunningContext(ActorRef<TypeListenerRegistryCommand>, ActorRef<CandidateRegistryCommand>, ActorRef<StateCheckerCommand>, ActorRef<OwnerSupervisorCommand>) - Constructor for class org.opendaylight.controller.eos.akka.bootstrap.command.RunningContext
- RuntimeRequestException - Exception Class in org.opendaylight.controller.cluster.access.concepts
-
General error raised when the recipient of a
Requestfails to process a request. - RuntimeRequestException(String, Throwable) - Constructor for exception class org.opendaylight.controller.cluster.access.concepts.RuntimeRequestException
S
- 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
- scalarValue(Object) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- scatterAll(ContainerNode, Function<YangInstanceIdentifier.PathArgument, T>, Stream<T>) - Static method in class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather
- scatterTouched(ContainerNode, Function<YangInstanceIdentifier.PathArgument, T>) - Static method in class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather
-
Split root container into per-shard root containers.
- scheduleElection(FiniteDuration) - Method in class org.opendaylight.controller.cluster.raft.behaviors.AbstractRaftActorBehavior
-
Schedule a new election.
- schemaContextProvider(Supplier<EffectiveModelContext>) - Method in class org.opendaylight.controller.cluster.datastore.Shard.AbstractBuilder
- self() - Method in class org.opendaylight.controller.cluster.access.client.AbstractClientActorBehavior
-
Return an
ActorRefof this ClientActor. - self() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
- 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
- sendFailure(RequestException, long) - Method in class org.opendaylight.controller.cluster.access.concepts.RequestEnvelope
-
Respond to this envelope with a
RequestFailurecaused by specifiedRequestException. - 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.
- sendImmediate() - Method in record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Returns the value of the
sendImmediaterecord component. - 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 - Enum constant in enum class 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.MetadataShardDataTreeSnapshot
- serialize(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.persisted.ShardDataTreeSnapshot
- serialized() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
- serializedSize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
- serializedSize() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
- serializedSize() - Method in class org.opendaylight.controller.cluster.raft.messages.Payload
-
Return the estimate of serialized size of this payload when passed through serialization.
- serializedSize() - Method in class org.opendaylight.controller.cluster.raft.persisted.NoopPayload
- serializedSize() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
- serializedSize() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
- serializedSize() - Method in interface org.opendaylight.controller.cluster.raft.ReplicatedLogEntry
-
Return the estimate of serialized size of this entry when passed through serialization.
- 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 Class 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 - Record Class in org.opendaylight.controller.cluster.raft.persisted
-
Server information.
- ServerInfo(String, boolean) - Constructor for record class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
-
Creates an instance of a
ServerInforecord class. - 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
- 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.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getBackendAlivenessTimerIntervalInSeconds()to the specified value. - setBoundedMailboxCapacity(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getBoundedMailboxCapacity()to the specified value. - setCandidateElectionTimeoutDivisor(long) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- setCandidateNodes(List<NodeName>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Set the property corresponding to
Candidates.getCandidateNodes()to the specified value. - setCandidateNodes(List<NodeName>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Set the property corresponding to
Candidates.getCandidateNodes()to the specified value. - setCloseable(AutoCloseable) - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
- 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
- setCustomRaftPolicyImplementation(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getCustomRaftPolicyImplementation()to the specified value. - 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.AddShardReplicaInputBuilder
-
Set the property corresponding to
DatastoreShardId.getDataStoreType()to the specified value. - setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Set the property corresponding to
DatastoreShardId.getDataStoreType()to the specified value. - setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Set the property corresponding to
DatastoreShardId.getDataStoreType()to the specified value. - setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Set the property corresponding to
DatastoreShardId.getDataStoreType()to the specified value. - setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Set the property corresponding to
DatastoreShardId.getDataStoreType()to the specified value. - setDataStoreType(DataStoreType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Set the property corresponding to
DatastoreShardId.getDataStoreType()to the specified value. - 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
-
Set the property corresponding to
DatastoreShardId.getDataStoreType()to the specified value. - setDelegate(DataPersistenceProvider) - Method in class org.opendaylight.controller.cluster.DelegatingPersistentDataProvider
- setDoCommitOnReady(boolean) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- 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.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getEnableMetricCapture()to the specified value. - setEntities(Map<EntitiesKey, Entities>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntitiesOutputBuilder
-
Set the property corresponding to
GetEntitiesOutput.getEntities()to the specified value. - 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
-
Set the property corresponding to
ShardOperationResult.getErrorMessage()to the specified value. - setExportOnRecovery(DataStoreProperties.ExportOnRecovery) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getExportOnRecovery()to the specified value. - 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.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getFileBackedStreamingThresholdInMegabytes()to the specified value. - setFilePath(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
Set the property corresponding to
BackupDatastoreInput.getFilePath()to the specified value. - setFrontendNoProgressTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getFrontendNoProgressTimeoutInSeconds()to the specified value. - setFrontendRequestTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getFrontendRequestTimeoutInSeconds()to the specified value. - 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
-
Set the property corresponding to
ClientIdentifier.getGeneration()to the specified value. - setHeartBeatInterval(FiniteDuration) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- setInitialPayloadSerializedBufferCapacity(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getInitialPayloadSerializedBufferCapacity()to the specified value. - setInitialSettleTimeoutMultiplier(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getInitialSettleTimeoutMultiplier()to the specified value. - setIsolatedLeaderCheckInterval(FiniteDuration) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- setJournalRecoveryLogBatchSize(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- 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
-
Set the property corresponding to
ShardResult1.getKnownClients()to the specified value. - 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
- 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
-
Set the property corresponding to
LeaderActorRef.getLeaderActorRef()to the specified value. - 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
-
Set the property corresponding to
Local.getLocal()to the specified value. - setMatchIndex(long) - Method in class org.opendaylight.controller.cluster.raft.FollowerLogInformation
-
Sets the index of the follower's highest log entry.
- setMaximumMessageSliceSize(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- setMaximumMessageSliceSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getMaximumMessageSliceSize()to the specified value. - 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
-
Set the property corresponding to
FrontendIdentifier.getMember()to the specified value. - 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
-
Set the property corresponding to
MemberVotingState.getMemberName()to the specified value. - setMemberName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInputBuilder
-
Set the property corresponding to
RemoveAllShardReplicasInput.getMemberName()to the specified value. - setMemberName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Set the property corresponding to
RemoveShardReplicaInput.getMemberName()to the specified value. - setMemberNode(MemberNode) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardOutputBuilder
-
Set the property corresponding to
LocateShardOutput.getMemberNode()to the specified value. - setMemberVotingState(List<MemberVotingState>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForAllShardsInputBuilder
-
Set the property corresponding to
MemberVotingStatesInput.getMemberVotingState()to the specified value. - setMemberVotingState(List<MemberVotingState>) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Set the property corresponding to
MemberVotingStatesInput.getMemberVotingState()to the specified value. - setMessage(C) - Method in interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- setName(EntityName) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Set the property corresponding to
EntityId.getName()to the specified value. - setName(EntityName) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Set the property corresponding to
EntityId.getName()to the specified value. - setName(EntityName) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Set the property corresponding to
EntityId.getName()to the specified value. - 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.
- 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.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getOperationTimeoutInSeconds()to the specified value. - setOwnerNode(NodeName) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Set the property corresponding to
Owner.getOwnerNode()to the specified value. - setOwnerNode(NodeName) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOutputBuilder
-
Set the property corresponding to
Owner.getOwnerNode()to the specified value. - setOwnerNode(NodeName) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerOutputBuilder
-
Set the property corresponding to
Owner.getOwnerNode()to the specified value. - setPath(YangInstanceIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.modification.AbstractModification
-
Deprecated.
- 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.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getPersistent()to the specified value. - 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
-
Deprecated.
- setReady(Optional<SortedSet<String>>) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- setRecoveryExportBaseDir(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getRecoveryExportBaseDir()to the specified value. - setRecoverySnapshotIntervalSeconds(int) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- setRecoverySnapshotIntervalSeconds(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getRecoverySnapshotIntervalSeconds()to the specified value. - SetRegistration(Registration, Runnable) - Constructor for record class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor.SetRegistration
-
Creates an instance of a
SetRegistrationrecord class. - setRemoteVersion(short) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyLocalTransaction
-
Deprecated.
- 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.GetShardRoleOutputBuilder
-
Set the property corresponding to
GetShardRoleOutput.getRole()to the specified value. - 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
- setShardBatchedModificationCount(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardBatchedModificationCount()to the specified value. - setShardCommitQueueExpiryTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardCommitQueueExpiryTimeoutInSeconds()to the specified value. - setShardElectionTimeoutFactor(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardElectionTimeoutFactor()to the specified value. - setShardHeartbeatIntervalInMillis(HeartbeatIntervalType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardHeartbeatIntervalInMillis()to the specified value. - setShardInitializationTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardInitializationTimeoutInSeconds()to the specified value. - setShardIsolatedLeaderCheckIntervalInMillis(HeartbeatIntervalType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardIsolatedLeaderCheckIntervalInMillis()to the specified value. - setShardJournalRecoveryLogBatchSize(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardJournalRecoveryLogBatchSize()to the specified value. - setShardLeaderElectionTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardLeaderElectionTimeoutInSeconds()to the specified value. - setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInputBuilder
-
Set the property corresponding to
DatastoreShardId.getShardName()to the specified value. - setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ChangeMemberVotingStatesForShardInputBuilder
-
Set the property corresponding to
DatastoreShardId.getShardName()to the specified value. - setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.GetShardRoleInputBuilder
-
Set the property corresponding to
DatastoreShardId.getShardName()to the specified value. - setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.LocateShardInputBuilder
-
Set the property corresponding to
DatastoreShardId.getShardName()to the specified value. - setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.MakeLeaderLocalInputBuilder
-
Set the property corresponding to
DatastoreShardId.getShardName()to the specified value. - setShardName(String) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInputBuilder
-
Set the property corresponding to
DatastoreShardId.getShardName()to the specified value. - 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
-
Set the property corresponding to
DatastoreShardId.getShardName()to the specified value. - 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
-
Set the property corresponding to
ShardResultOutput.getShardResult()to the specified value. - 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
-
Set the property corresponding to
ShardResultOutput.getShardResult()to the specified value. - 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
-
Set the property corresponding to
ShardResultOutput.getShardResult()to the specified value. - 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
-
Set the property corresponding to
ShardResultOutput.getShardResult()to the specified value. - 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
-
Set the property corresponding to
ShardResultOutput.getShardResult()to the specified value. - setShardSnapshotBatchCount(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardSnapshotBatchCount()to the specified value. - setShardSnapshotDataThreshold(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardSnapshotDataThreshold()to the specified value. - setShardSnapshotDataThresholdPercentage(Percentage) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardSnapshotDataThresholdPercentage()to the specified value. - setShardTransactionCommitQueueCapacity(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardTransactionCommitQueueCapacity()to the specified value. - setShardTransactionCommitTimeoutInSeconds(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardTransactionCommitTimeoutInSeconds()to the specified value. - setShardTransactionIdleTimeoutInMinutes(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getShardTransactionIdleTimeoutInMinutes()to the specified value. - 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
- 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.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getSnapshotOnRootOverwrite()to the specified value. - 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.
- 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
-
Set the property corresponding to
ShardOperationResult.getSucceeded()to the specified value. - 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.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getSyncIndexThreshold()to the specified value. - setTempFileDirectory(String) - Method in class org.opendaylight.controller.cluster.raft.DefaultConfigParamsImpl
- setTimeout(Uint32) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInputBuilder
-
Set the property corresponding to
BackupDatastoreInput.getTimeout()to the specified value. - 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
-
Deprecated.
- setTransactionCreationInitialRateLimit(NonZeroUint32Type) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getTransactionCreationInitialRateLimit()to the specified value. - setTransactionDebugContextEnabled(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getTransactionDebugContextEnabled()to the specified value. - 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
-
Set the property corresponding to
FrontendIdentifier.getType()to the specified value. - setType(EntityType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Set the property corresponding to
EntityId.getType()to the specified value. - setType(EntityType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityInputBuilder
-
Set the property corresponding to
EntityId.getType()to the specified value. - setType(EntityType) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.GetEntityOwnerInputBuilder
-
Set the property corresponding to
EntityId.getType()to the specified value. - setUseLz4Compression(Boolean) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStorePropertiesContainerBuilder
-
Set the property corresponding to
DataStoreProperties.getUseLz4Compression()to the specified value. - 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
-
Set the property corresponding to
MemberVotingState.getVoting()to the specified value. - setVotingState(VotingState) - Method in class org.opendaylight.controller.cluster.raft.PeerInfo
- shard() - Method in record class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather.ShardContainer
-
Returns the value of the
shardrecord component. - Shard - Class in org.opendaylight.controller.cluster.datastore
-
A Shard represents a portion of the logical data tree.
- Shard - Enum constant in enum class org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
- SHARD_DISPATCHER_PATH - Static variable in class org.opendaylight.controller.cluster.common.actor.Dispatchers
- Shard.AbstractBuilder<T,
S> - 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
- 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
- ShardContainer(T, ContainerNode) - Constructor for record class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather.ShardContainer
-
Creates an instance of a
ShardContainerrecord class. - 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. it does not expose public interfaces and assumes it is only ever called from a single thread.
- 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 Class 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.
- ShardDataTreeNotificationPublisherActor<T> - 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> - Class in org.opendaylight.controller.cluster.datastore.persisted
-
Base class for various bits of metadata attached to a
MetadataShardDataTreeSnapshot. - 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
- 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
- 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 Class in org.opendaylight.controller.cluster.datastore.exceptions
-
Exception indicating a shard leader is not responding to messages.
- ShardLeaderNotRespondingException(String, Throwable) - Constructor for exception class 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(List<String>) - Constructor for class org.opendaylight.controller.cluster.datastore.persisted.ShardManagerSnapshot
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ShardReadTransaction(AbstractShardDataTreeTransaction<?>, ActorRef, ShardStats) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardReadTransaction
-
Deprecated.
- ShardReadWriteTransaction - Class in org.opendaylight.controller.cluster.datastore
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ShardReadWriteTransaction(ReadWriteShardDataTreeTransaction, ActorRef, ShardStats) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardReadWriteTransaction
-
Deprecated.
- 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
-
This class represents the following YANG schema fragment defined in module cluster-admin
- 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
ShardResult1instances. - 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
-
Construct an empty builder.
- 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
-
Construct a builder initialized with state from specified
ShardResult1. - 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
ShardResultinstances. - 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
-
Construct an empty builder.
- 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
-
Construct a new builder initialized from specified
DatastoreShardId. - 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
-
Construct a builder initialized with state from specified
ShardResult. - 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
-
Construct a new builder initialized from specified
ShardOperationResult. - ShardResultKey - Class in org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output
-
This class represents the key of
ShardResultclass. - 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
-
Constructs an instance.
- 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
- 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
- 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) - Constructor for class org.opendaylight.controller.cluster.datastore.shardstrategy.ShardStrategyFactory
- ShardTransaction - Class in org.opendaylight.controller.cluster.datastore
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ShardTransaction(ActorRef, ShardStats, TransactionIdentifier) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardTransaction
-
Deprecated.
- 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
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ShardWriteTransaction(ReadWriteShardDataTreeTransaction, ActorRef, ShardStats) - Constructor for class org.opendaylight.controller.cluster.datastore.ShardWriteTransaction
-
Deprecated.
- 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 class org.opendaylight.controller.cluster.access.ABIVersion
-
Return the unsigned short integer identifying this version.
- shortValue() - Method in enum class 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 - Class in org.opendaylight.controller.cluster.raft.client.messages
-
Message sent to a raft actor to shutdown gracefully.
- simple() - Static method in class org.opendaylight.controller.cluster.io.InputOutputStreamFactory
- SIMPLE - Enum constant in enum class org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
-
Simple commit protocol.
- SimpleDataStoreClientActor - Class in org.opendaylight.controller.cluster.databroker.actors.dds
-
A
AbstractClientActorwhich acts as the point of contact for DistributedDataStore. - SimpleReplicatedLogEntry - Class in org.opendaylight.controller.cluster.raft.persisted
-
A
ReplicatedLogEntryimplementation. - 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
SimpleReplicatedLogEntrythat optimizes serialization. - SimpleReplicatedLogEntrySerializer(ExtendedActorSystem) - Constructor for class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntrySerializer
- SingleEntityListenerActor - Class in org.opendaylight.controller.eos.akka.registry.listener.owner
-
Keeps track of owners for a single entity, which is mapped to a single LWWRegister in distributed-data.
- SingleEntityListenerActor(ActorContext<ListenerCommand>, String, DOMEntity, ActorRef<TypeListenerCommand>) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.owner.SingleEntityListenerActor
- SingleEntityOwnerDataResponse - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- SingleEntityOwnerDataResponse(Replicator.GetResponse<LWWRegister<String>>, DOMEntity, ActorRef<GetEntityReply>) - Constructor for class org.opendaylight.controller.eos.akka.owner.checker.command.SingleEntityOwnerDataResponse
- 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.datastore.utils.UnsignedLongBitmap
- size() - Method in class org.opendaylight.controller.cluster.io.ChunkedByteArray
- size() - Method in class org.opendaylight.controller.cluster.io.ChunkedOutputStream
- size() - Method in class org.opendaylight.controller.cluster.raft.AbstractReplicatedLogImpl
- size() - Method in class org.opendaylight.controller.cluster.raft.messages.Payload
-
Return the estimate of in-memory size of this payload.
- 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 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
- SkipTransactionsPayload - Class in org.opendaylight.controller.cluster.datastore.persisted
-
Payload persisted when a local history is instructed some transaction identifiers, i.e. the frontend has used them for other purposes.
- SkipTransactionsRequest - Class in org.opendaylight.controller.cluster.access.commands
-
Request to skip a number of
TransactionIdentifiers within a {code local history}. - SkipTransactionsRequest(TransactionIdentifier, long, ActorRef, Collection<UnsignedLong>) - Constructor for class org.opendaylight.controller.cluster.access.commands.SkipTransactionsRequest
- SkipTransactionsResponse - Class in org.opendaylight.controller.cluster.access.commands
-
Successful reply to a
SkipTransactionsRequest. - SkipTransactionsResponse(TransactionIdentifier, long) - Constructor for class org.opendaylight.controller.cluster.access.commands.SkipTransactionsResponse
- 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_VERSION - Static variable in class org.opendaylight.controller.cluster.datastore.DataStoreVersions
-
Deprecated.
- start() - Method in class org.opendaylight.controller.remote.rpc.RemoteOpsProvider
- startAnydataNode(YangInstanceIdentifier.NodeIdentifier, Class<?>) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startAnyxmlNode(YangInstanceIdentifier.NodeIdentifier, Class<?>) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startChoiceNode(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startContainerNode(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startLeafNode(YangInstanceIdentifier.NodeIdentifier) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startLeafSet(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startLeafSetEntryNode(YangInstanceIdentifier.NodeWithValue<?>) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- 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.
- startMapEntryNode(YangInstanceIdentifier.NodeIdentifierWithPredicates, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startMapNode(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startOrderedLeafSet(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startOrderedMapNode(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startUnkeyedList(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- startUnkeyedListItem(YangInstanceIdentifier.NodeIdentifier, int) - Method in class org.opendaylight.controller.cluster.datastore.node.utils.transformer.ReusableNormalizedNodePruner
- 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
- StateCheckerCommand - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- StateCheckerReply - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- StateCheckerRequest<T> - Class in org.opendaylight.controller.eos.akka.owner.checker.command
- 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
- streamVersion() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload.CandidateTransaction
-
Returns the value of the
streamVersionrecord component. - stringValue() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
-
Return a String representing the value of this union.
- subscribeToMemberEvents(ActorRef) - Method in interface org.opendaylight.controller.cluster.datastore.ClusterWrapper
- subscribeToMemberEvents(ActorRef) - Method in class org.opendaylight.controller.cluster.datastore.ClusterWrapperImpl
- 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
- supervisorStrategy() - Method in class org.opendaylight.controller.remote.rpc.OpsManager
- 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
- term() - Method in class org.opendaylight.controller.cluster.raft.persisted.SimpleReplicatedLogEntry
- term() - Method in interface org.opendaylight.controller.cluster.raft.RaftEntryMeta
-
Returns the term of the entry.
- Terminate - Class in org.opendaylight.controller.eos.akka.bootstrap.command
- Terminate(ActorRef<Empty>) - Constructor for class org.opendaylight.controller.eos.akka.bootstrap.command.Terminate
- TerminateListener - Class in org.opendaylight.controller.eos.akka.registry.listener.type.command
-
Sent to the listener actor to stop it on demand ie during listener unregistration.
- 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 - Enum constant in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Version which is newer than any other version.
- TEST_FUTURE_VERSION - Enum constant in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
Version which is newer than any other version.
- TEST_PAST_VERSION - Enum constant in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Version which is older than any other version.
- TEST_PAST_VERSION - Enum constant in enum class 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. - THREE_PHASE - Enum constant in enum class org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
-
Three-phase commit protocol (3PC).
- throwNSE() - Method in class org.opendaylight.controller.cluster.access.concepts.Message
- ticker() - Method in class org.opendaylight.controller.cluster.access.client.ClientActorContext
-
Return the time ticker for this
ClientActorContext. - TIMEOUT - Enum constant in enum class 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 Class in org.opendaylight.controller.cluster.datastore.exceptions
- TimeoutException(String, Exception) - Constructor for exception class 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
-
Deprecated.
- 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
- toOutput() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntityOwnerReply
- toOutput() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntityReply
- toOutput(BindingInstanceIdentifierCodec) - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntitiesReply
- toPersistentId() - Method in class org.opendaylight.controller.cluster.access.concepts.FrontendIdentifier
- toRangeSet() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- toRequestFailure(RequestException) - Method in class org.opendaylight.controller.cluster.access.concepts.Request
-
Return a
RequestFailurefor this request, caused by aRequestException. - 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
-
Deprecated.
- 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.actors.dds.AbstractClientHandle
- toString() - Method in class org.opendaylight.controller.cluster.databroker.ConcurrentDOMDataBroker
- toString() - Method in class org.opendaylight.controller.cluster.datastore.ReadWriteShardDataTreeTransaction
- toString() - Method in record class org.opendaylight.controller.cluster.datastore.actors.DataTreeNotificationListenerRegistrationActor.SetRegistration
-
Returns a string representation of this record class.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.config.ModuleShardConfiguration
- 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
-
Deprecated.
- toString() - Method in record class org.opendaylight.controller.cluster.datastore.messages.ActorInitialized
-
Returns a string representation of this record class.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.AddShardReplica
- toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
-
Deprecated.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
- 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
-
Deprecated.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- 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
-
Deprecated.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.LocalPrimaryShardFound
- 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.RemoveShardReplica
- toString() - Method in record class org.opendaylight.controller.cluster.datastore.messages.UpdateSchemaContext
-
Returns a string representation of this record class.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
-
Deprecated.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload
- toString() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload.CandidateTransaction
-
Returns a string representation of this record class.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
- toString() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
-
Returns a string representation of this record class.
- 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 record class org.opendaylight.controller.cluster.datastore.utils.RootScatterGather.ShardContainer
-
Returns a string representation of this record class.
- toString() - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- toString() - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- toString() - Method in class org.opendaylight.controller.cluster.datastore.utils.MutableUnsignedLongSet
- toString() - Method in class org.opendaylight.controller.cluster.io.ChunkedByteArray
- 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 record class org.opendaylight.controller.cluster.raft.base.messages.Replicate
-
Returns a string representation of this record class.
- 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 record class org.opendaylight.controller.cluster.raft.ClientRequestTracker
-
Returns a string representation of this record class.
- 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 record class org.opendaylight.controller.cluster.raft.persisted.ServerInfo
-
Returns a string representation of this record class.
- 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.eos.akka.owner.checker.command.AbstractEntityRequest
- toString() - Method in class org.opendaylight.controller.eos.akka.owner.checker.command.GetEntitiesRequest
- toString() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.CandidatesChanged
- toString() - Method in class org.opendaylight.controller.eos.akka.owner.supervisor.command.InternalClusterEvent
- toString() - Method in class org.opendaylight.controller.eos.akka.registry.candidate.command.AbstractCandidateCommand
- toString() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.CandidatesChanged
- toString() - Method in class org.opendaylight.controller.eos.akka.registry.listener.type.command.EntityOwnerChanged
- 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.controller.remote.rpc.registry.ActionRegistry.Messages.UpdateActions
- toString() - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.Messages.AddOrUpdateRoutes
- toString() - Method in class org.opendaylight.controller.remote.rpc.registry.RpcRegistry.Messages.RemoveRoutes
- 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.rev231229.HeartbeatIntervalType
- toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.NonZeroUint32Type
- toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.OperationTimeoutType
- toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.Percentage
- toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityName
- toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.EntityType
- toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesKey
- toString() - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.NodeName
- 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
- toThreadExecutorStats() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.ThreadExecutorStatsMXBeanImpl
-
Returns a
ThreadExecutorStatsinstance containing a snapshot of the statistic metrics. - toVariant() - Method in class org.opendaylight.controller.cluster.io.ChunkedOutputStream
- 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 - Enum constant in enum class 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
ModifyTransactionRequestorCommitLocalTransactionRequest. - 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
ModifyTransactionRequestorCommitLocalTransactionRequest. - 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
TransactionModificationwhich 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
RequestFailureinvolving aTransactionRequest. - transactionId() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload.CandidateTransaction
-
Returns the value of the
transactionIdrecord component. - 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
NormalizedNodetree 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
- 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
- TransactionRequest<T> - Class in org.opendaylight.controller.cluster.access.commands
-
Abstract base class for
Requests involving specific transaction. - TransactionRequest.SerialForm<T> - Interface in org.opendaylight.controller.cluster.access.commands
- TransactionSuccess<T> - Class in org.opendaylight.controller.cluster.access.commands
-
Abstract base class for
RequestSuccesses involving specific transaction. - TransactionType - Enum Class 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, notifyRaftActorLeadershipTransferCohort.abortTransfer(). - 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
- TypeListenerCommand - Class in org.opendaylight.controller.eos.akka.registry.listener.type.command
- TypeListenerRegistryCommand - Class in org.opendaylight.controller.eos.akka.registry.listener.type.command
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 - Enum constant in enum class 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 Class in org.opendaylight.controller.cluster.access.commands
-
A
RequestExceptionindicating that the backend has received a request referencing an unknown history. - UnknownHistoryException(Long) - Constructor for exception class 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 Class in org.opendaylight.controller.cluster.datastore.exceptions
- UnknownMessageException(Object) - Constructor for exception class 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.
- UnregisterCandidate - Class in org.opendaylight.controller.eos.akka.registry.candidate.command
-
Sent to CandidateRegistry to unregister the candidate for a given entity.
- UnregisterCandidate(DOMEntity, String) - Constructor for class org.opendaylight.controller.eos.akka.registry.candidate.command.UnregisterCandidate
- UnregisterListener - Class in org.opendaylight.controller.eos.akka.registry.listener.type.command
-
Unregister a listener from the EntityTypeListenerRegistry.
- UnregisterListener(String, DOMEntityOwnershipListener) - Constructor for class org.opendaylight.controller.eos.akka.registry.listener.type.command.UnregisterListener
- unregisterMBean() - Method in class org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean
-
Unregisters this bean with the platform MBean server.
- UnsignedLongBitmap - Class in org.opendaylight.controller.cluster.datastore.utils
-
A more efficient equivalent of
ImmutableMap<UnsignedLong, Boolean>. - UnsupportedRequestException - Exception Class in org.opendaylight.controller.cluster.access.concepts
-
General error raised when the recipient of a
Requestdetermines that it does not know how to handle the request. - UnsupportedRequestException(Request<?, ?>) - Constructor for exception class org.opendaylight.controller.cluster.access.concepts.UnsupportedRequestException
- unwrap() - Method in exception class org.opendaylight.controller.cluster.access.concepts.RequestException
-
Unwraps the underlying failure.
- unwrap() - Method in exception class org.opendaylight.controller.cluster.access.concepts.RuntimeRequestException
- 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 - Record Class in org.opendaylight.controller.cluster.datastore.messages
- UpdateSchemaContext(EffectiveModelContext) - Constructor for record class org.opendaylight.controller.cluster.datastore.messages.UpdateSchemaContext
-
Creates an instance of a
UpdateSchemaContextrecord class. - useLz4Compression(boolean) - Method in class org.opendaylight.controller.cluster.datastore.DatastoreContext.Builder
V
- validate(long) - Method in class org.opendaylight.controller.cluster.access.client.InversibleLock
- valueOf(short) - Static method in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Return the
ABIVersioncorresponding to an unsigned short integer. - valueOf(short) - Static method in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
Return the
PayloadVersioncorresponding to an unsigned short integer. - valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.datastore.TransactionType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.dom.api.LeaderLocation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.raft.RaftState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.cluster.raft.VotingState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.opendaylight.controller.cluster.access.ABIVersion
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.access.commands.PersistenceProtocol
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.common.actor.Dispatchers.DispatcherType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.datastore.ShardDataTreeCohort.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.datastore.TransactionType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.dom.api.LeaderLocation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.raft.messages.ServerChangeStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.raft.RaftState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.cluster.raft.VotingState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.controller.remote.rpc.registry.gossip.BucketStoreAccess.Singletons
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.DataStoreProperties.ExportOnRecovery
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class 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 class, 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
- version() - Method in exception class org.opendaylight.controller.cluster.access.AbstractVersionException
-
Return the numeric version which has caused this exception.
- version() - Method in record class org.opendaylight.controller.cluster.datastore.persisted.DataTreeCandidateInputOutput.DataTreeCandidateWithVersion
-
Returns the value of the
versionrecord component. - VersionedExternalizableMessage - Class in org.opendaylight.controller.cluster.datastore.messages
-
Deprecated, for removal: This API element is subject to removal in a future version.
- VersionedExternalizableMessage() - Constructor for class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
-
Deprecated.
- VersionedExternalizableMessage(short) - Constructor for class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
-
Deprecated.
- 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 - Enum constant in enum class org.opendaylight.controller.cluster.raft.VotingState
- VOTING_NOT_INITIALIZED - Enum constant in enum class org.opendaylight.controller.cluster.raft.VotingState
- VotingState - Enum Class in org.opendaylight.controller.cluster.raft
-
Enumerates voting states for a peer.
W
- waitTillReady() - Method in class org.opendaylight.controller.cluster.datastore.AbstractDataStore
-
Deprecated.
- withConfigReader(AkkaConfigurationReader) - Method in class org.opendaylight.controller.cluster.common.actor.AbstractConfig.Builder
- withKey(EntitiesKey) - Method in class org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.get.entities.output.EntitiesBuilder
-
Set the key value corresponding to
key()to the specified value. - 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
-
Set the key value corresponding to
KnownClients.key()to the specified value. - 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
-
Set the key value corresponding to
ShardResult.key()to the specified value. - 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.ChunkedOutputStream
- write(byte[], int, int) - Method in class org.opendaylight.controller.cluster.io.FileBackedOutputStream
- write(int) - Method in class org.opendaylight.controller.cluster.io.ChunkedOutputStream
- 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
-
Deprecated.
- 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.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 - Enum constant in enum class 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
- writeEntriesTo(DataOutput, int) - Method in class org.opendaylight.controller.cluster.datastore.utils.UnsignedLongBitmap
- writeExternal(ObjectOutput, C) - Method in interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- writeExternal(ObjectOutput) - Method in interface org.opendaylight.controller.cluster.access.concepts.Message.SerialForm
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractRead
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.AbstractThreePhaseCommitMessage
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModifications
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.BatchedModificationsReply
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CloseTransactionChain
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransaction
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.CreateTransactionReply
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.DataExistsReply
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadDataReply
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.ReadyTransactionReply
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.RegisterDataTreeChangeListener
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.messages.VersionedExternalizableMessage
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- writeExternal(ObjectOutput) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- writeExternal(ObjectOutput) - Method in interface org.opendaylight.controller.cluster.datastore.persisted.AbstractIdentifiablePayload.SerialForm
- writeExternal(ObjectOutput, C) - Method in interface org.opendaylight.controller.cluster.access.concepts.Request.SerialForm
- writeExternal(ObjectOutput, C) - Method in interface org.opendaylight.controller.cluster.access.concepts.RequestFailure.SerialForm
- writeExternal(ObjectOutput, C) - Method in interface org.opendaylight.controller.cluster.access.concepts.RequestSuccess.SerialForm
- writeLock() - Method in class org.opendaylight.controller.cluster.access.client.InversibleLock
- WriteModification - Class in org.opendaylight.controller.cluster.datastore.modification
-
Deprecated, for removal: This API element is subject to removal in a future version.
- WriteModification() - Constructor for class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- WriteModification(short) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- WriteModification(YangInstanceIdentifier, NormalizedNode) - Constructor for class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
- 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
- writeRangesTo(DataOutput, int) - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- 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 class org.opendaylight.controller.cluster.datastore.persisted.CommitTransactionPayload
- writeReplace() - Method in class org.opendaylight.controller.cluster.raft.messages.Payload
-
Return the serialization proxy for this object.
- writeReplace() - Method in interface org.opendaylight.controller.cluster.raft.persisted.MigratedSerializable
-
Return a serialization proxy.
- writeReplace() - Method in class org.opendaylight.controller.cluster.raft.persisted.NoopPayload
- writeReplace() - Method in class org.opendaylight.controller.cluster.raft.persisted.ServerConfigurationPayload
- writeTo(DataOutput) - Method in enum class org.opendaylight.controller.cluster.access.ABIVersion
- writeTo(DataOutput) - Method in enum class 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 class org.opendaylight.controller.cluster.datastore.persisted.PayloadVersion
- writeTo(DataOutput) - Method in class org.opendaylight.controller.cluster.datastore.utils.ImmutableUnsignedLongSet
- writeTo(NormalizedNodeDataOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.DeleteModification
-
Deprecated.
- writeTo(NormalizedNodeDataOutput) - Method in interface org.opendaylight.controller.cluster.datastore.modification.Modification
- writeTo(NormalizedNodeDataOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.MutableCompositeModification
-
Deprecated.
- writeTo(NormalizedNodeDataOutput) - Method in class org.opendaylight.controller.cluster.datastore.modification.WriteModification
-
Deprecated.
Y
- YangModelBindingProviderImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
-
The
YangModelBindingProviderforodl-controller-cds-typesmodule. - YangModelBindingProviderImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229
-
The
YangModelBindingProviderfordistributed-datastore-providermodule. - YangModelBindingProviderImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
The
YangModelBindingProviderforodl-entity-ownersmodule. - YangModelBindingProviderImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
The
YangModelBindingProviderforcluster-adminmodule. - YangModelBindingProviderImpl() - Constructor for class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024.YangModelBindingProviderImpl
-
Construct a new provider.
- YangModelBindingProviderImpl() - Constructor for class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229.YangModelBindingProviderImpl
-
Construct a new provider.
- YangModelBindingProviderImpl() - Constructor for class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev.YangModelBindingProviderImpl
-
Construct a new provider.
- YangModelBindingProviderImpl() - Constructor for class org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.YangModelBindingProviderImpl
-
Construct a new provider.
- YangModuleInfoImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.cds.types.rev191024
-
The
ResourceYangModuleInfoforodl-controller-cds-typesmodule. - YangModuleInfoImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.config.distributed.datastore.provider.rev231229
-
The
ResourceYangModuleInfofordistributed-datastore-providermodule. - YangModuleInfoImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.entity.owners.norev
-
The
ResourceYangModuleInfoforodl-entity-ownersmodule. - YangModuleInfoImpl - Class in org.opendaylight.yang.svc.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013
-
The
ResourceYangModuleInfoforcluster-adminmodule. - YangTextSchemaSourceSerializationProxy - Class in org.opendaylight.controller.cluster.schema.provider.impl
-
YangTextSourceserialization proxy. - YangTextSchemaSourceSerializationProxy(YangTextSource) - Constructor for class org.opendaylight.controller.cluster.schema.provider.impl.YangTextSchemaSourceSerializationProxy
- yes(short) - Static method in class org.opendaylight.controller.cluster.datastore.messages.CanCommitTransactionReply
-
Deprecated.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
PayloadVersion.POTASSIUMinstead.