All Classes and Interfaces
Class
Description
Enumeration of all ABI versions supported by this implementation of the client access API.
Request to abort a local transaction.
Payload persisted when a transaction is aborted.
Base class for a DataTreeModificationCursor that publishes to BatchedModifications instance(s).
Frontend actor which takes care of persisting generations and creates an appropriate ClientIdentifier.
AbstractClientActorBehavior<C extends org.opendaylight.controller.cluster.access.client.AbstractClientActorContext>
Base behavior attached to
AbstractClientActor
.Base class for a connection to the backend.
AbstractClientHandle<T extends org.opendaylight.controller.cluster.databroker.actors.dds.AbstractProxyTransaction>
Abstract superclass of both ClientSnapshot and ClientTransaction.
Abstract base class for client view of a history.
Base implementation of a distributed DOMStore.
Abstract
DataTreeModificationCursor
which tracks the current path.An abstract base class for invocation requests.
Abstract base class for
IdentifiablePayload
s which hold a single Identifier
.An
Externalizable
with default implementations we expect our implementations to comply with.The behavior of a RaftActor when it is in the Leader state.
Abstract base class for
Request
s involving specific transactions local to a member node.Base class to be used for all simple modifications that can be applied to a DOMStoreTransaction.
Abstract base for an MXBean implementation class.
Abstract class that provides common code for a RaftActor behavior.
Abstract base class for ReadData and DataExists messages.
Abstract base class for
TransactionRequest
s accessing data as visible in the isolated context of a particular
transaction.Abstract base class for
TransactionRequest
s accessing transaction state without modifying it.Abstract class handling the mapping of
logical LogEntry Index and the physical list index.
An abstract base class for invocation responses.
Common class for routing tables.
Abstract base class for a server configuration change reply.
Abstract base class for
DOMStoreThreePhaseCommitCohort
instances returned by this
implementation.Base class for a 3PC message.
Actor with its behaviour metered.
Actor with its behaviour metered.
Abstract base exception used for reporting version mismatches from
ABIVersion
.Abstract base exception used for reporting version mismatches from
PayloadVersion
.Registry to look up cluster nodes that have registered for a given Action.
All messages used by the ActionRegistry.
Activates the datacenter that the node this rpc is called on belongs to.
Class that builds
ActivateEosDatacenterInput
instances.Class that builds
ActivateEosDatacenterOutput
instances.Interface that provides an akka ActorSystem instance.
Listener interface for notification of ActorSystem changes from an ActorSystemProvider.
The ActorUtils class contains utility methods which could be used by non-actors (like DistributedDataStore) to work
with actors a little more easily.
Adds replicas on this node for all currently defined shards.
Class that builds
AddReplicasForAllShardsInput
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
AddReplicasForAllShardsOutput
instances.Message sent to add a new server/replica (§4.1).
Reply to an AddServer message (§4.1).
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.
Adds a replica of a shard to this node and joins it to an existing cluster.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
AddShardReplicaInput
instances.Class that builds
AddShardReplicaOutput
instances.DOMEntityOwnershipService implementation backed by native Akka clustering constructs.
Invoked by leader to replicate log entries (§5.3); also used as heartbeat (§5.2).
Reply for the AppendEntries message.
This is an internal message that is stored in the akka's persistent journal.
Internal message, issued by follower to its actor.
Local message sent by a RaftActor to itself to signal state has been applied to the state machine.
Maintains the state of an assembled message.
A MessageSliceException indicating the message assembler has already been closed.
A MessageSliceException indicating the message assembler has already been sealed.
Basic information about how to talk to the backend.
Caching resolver which resolves a cookie to a leader
ActorRef
.Creates a backup file of the datastore state
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
BackupDatastoreInput
instances.Class that builds
BackupDatastoreOutput
instances.Message used to batch write, merge, delete modification operations to the ShardTransaction actor.
The reply for the BatchedModifications message.
Marker interface for data which is able to be held in a
Bucket
.Convenience access to
BucketStoreActor
.A store that syncs its data across nodes in the cluster.
The behavior of a RaftActor when it is in the Candidate raft state.
Actor that can be spawned by all the supervisor implementations that executes clearing of candidates once
candidate retrieval succeeds.
Actor responsible for handling registrations of candidates into distributed-data.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Adapted notification from distributed-data sent to EntityTypeListenerActor when candidates change.
Changes the voting states, either voting or non-voting, of cluster members for
all shards.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
ChangeMemberVotingStatesForAllShardsInput
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
ChangeMemberVotingStatesForAllShardsOutput
instances.Changes the voting states, either voting or non-voting, of cluster members for
shard.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
ChangeMemberVotingStatesForShardInput
instances.Class that builds
ChangeMemberVotingStatesForShardOutput
instances.Message sent to change the raft voting status for servers.
A local message sent to the ShardManager to change the raft voting status for members of a shard.
Internal message sent to the leader after persistence is complete to check if replication consensus has been reached.
An
OutputStream
implementation which collects data is a series of byte[]
chunks, each of which has
a fixed maximum size.Request sent from Candidate registration actors to clear the candidate from all entities.
Response sent from OwnerSupervisor to the ClearCandidatesForMember request, notifying the caller that removal has
finished.
A behavior, which handles messages sent to a
AbstractClientActor
.Connection reconnect cohort, driven by this class.
Interface for client actor configuration parameters.
An actor context associated with this
AbstractClientActor
.Implements a distributed DOMStore using ClientActor.
This class represents the following YANG schema fragment defined in module odl-controller-cds-types
A cluster-wide unique identifier of a frontend instance.
Identifier of a particular client.
Client-side view of a local history.
Snapshot of the datastore state.
Client-side view of a transaction.
A
RequestException
indicating that the backend has received a request for a transaction which has already
been closed, either via a successful commit or abort (which is indicated via ClosedTransactionException.isSuccessful()
.Payload persisted when a local history is closed cleanly.
This module contains YANG RPC definitions for administering a cluster.
Implements the yang RPCs defined in the generated ClusterAdminService interface.
Request to commit a local transaction.
MXBean interface for retrieving write Tx commit statistics.
Payload persisted when a transaction commits.
CompositeModification contains a list of modifications that need to be applied to the DOMStore.
An OnComplete implementation that aggrgates other OnComplete tasks.
ConcurrentDOMDataBroker commits transactions concurrently.
Configuration Parameter interface for configuring the Raft consensus system.
A
RequestFailure
reported when ConnectClientRequest
fails.Request to connect a frontend instance to the backend.
Successful reply to an
ConnectClientRequest
.A connected connection.
Single entry in a
AbstractClientConnection
.Payload persisted when a local history is created.
Request to create a new local history.
A message sent to the ShardManager to dynamically create a new shard.
Service used to bring up/down the Entity Ownership Service service in individual datacenters.
DataPersistenceProvider provides methods to persist data and is an abstraction of the akka-persistence persistence
API.
Client interface for interacting with the frontend actor.
MXBean interface for data store configuration.
Contains contextual data for a data store.
Factory for creating DatastoreContext instances.
Introspects on a DatastoreContext instance to set its properties via reflection.
Factory for creating
DatastoreContextIntrospector
instances.Update DatastoreContext settings on invoke update method.
JMX bean for general datastore info.
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
Class that builds
DataStorePropertiesContainer
instances.Grouping holding combined identifiers of a shard -- its name and datastore type
Stores a snapshot of the internal state of a data store.
Stores a list of DatastoreSnapshot instances.
This class looks for a previously saved data store backup file in a directory and, if found, de-serializes
the DatastoreSnapshot instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Defines version numbers where ask-based protocol is concerned.
Utility serialization/deserialization for
DataTreeCandidate
.A message about a DataTree having been changed.
Information about a registered listener.
Utility class to output DataTreeModifications in readable format.
Actor co-located with a shard.
Deactivates the datacenter that the node this rpc is called on belongs to.
Class that builds
DeactivateEosDatacenterInput
instances.Class that builds
DeactivateEosDatacenterOutput
instances.A
RequestException
indicating that the backend has received a request to create a history which has already
been retired.A
RequestException
indicating that the backend has received a request to create a transaction which has
already been purged.Default implementation of the ConfigParams.
This class looks for a previously saved data store backup file in a directory and, if found, de-serializes
the DatastoreSnapshot instances.
The DefaultShardStrategy basically puts all data into the default shard.
A DataPersistenceProvider implementation that delegates to another implementation.
Internal message that is stored in the akka's persistent journal to delete journal entries.
DeleteModification store all the parameters required to delete a path from the data tree.
Request to destroy a local history.
This class represents the following YANG schema fragment defined in module odl-entity-owners
DisableElectionsRaftPolicy can be used for actors that does not
participate in shard election.
Deprecated, for removal: This API element is subject to removal in a future version.
This implementation is destined for removal,
A
AbstractClientActor
which acts as the point of contact for DistributedDataStore.The public interface exposed by an AbstractDataStore via the OSGi registry.
This module contains the base YANG definitions for the distributed datastore
provider implementation
ElectionTerm contains information about a RaftActors election term.
Local message sent to indicate the current election term has timed out.
Externalizable with no data.
Empty Snapshot State implementation.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Class that builds
Entities
instances.This class represents the key of
Entities
class.
This class represents the following YANG schema fragment defined in module odl-entity-owners
This class represents the following YANG schema fragment defined in module odl-entity-owners
Notification sent to EntityTypeListenerActor when there is an owner change for an Entity of a given type.
Short-lived actor that is spawned purely for execution of rpcs from the entity-owners model.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Interface implemented by Actors, who can schedule invocation of a
Procedure
in their context.A transaction request to query if a particular path exists in the current view of a particular transaction.
Successful reply to an
ExistsTransactionRequest
.Unfortunately Akka's explicit ask pattern does not work with its Java API, as it fails to invoke passed message.
An
OutputStream
that starts buffering to a byte array, but switches to file buffering once the data
reaches a configurable size.A factory for creating
FileBackedOutputStream
instances.Implementation of ModuleShardConfigProvider that reads the module and shard configuration from files.
Request to locate the leader raft actor.
Reply to
FindLeader
message, containing the address of the leader actor, as known to the raft actor which
sent the message.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.
The FindPrimary message is used to locate the primary of any given shard.
Implementation of
ThreadPool
using fixed number of threads wraps
ExecutorService
.Implementation of
ThreadPool
using flexible number of threads wraps
ExecutorService
.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.
Class that builds
FlipMemberVotingStatesForAllShardsInput
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
FlipMemberVotingStatesForAllShardsOutput
instances.A local message sent to the ShardManager to flip the raft voting states for members of a shard.
The behavior of a RaftActor in the Follower raft state.
A bean class containing a snapshot of information for a follower returned from GetOnDemandRaftStats.
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.
The state of the followers log as known by the Leader.
Transaction ReadyTransaction message that is forwarded to the local Shard from the ShardTransaction.
A cluster-wide unique identifier of a frontend type located at a cluster member.
Identifier of a particular frontend.
An
Identifier
identifying a data store frontend type, which is able to access the data store backend.
This class represents the following YANG schema fragment defined in module odl-controller-cds-types
Exception thrown from
ABIVersion.valueOf(short)
when the specified version is too new to be supported
by the codebase.Exception thrown from
PayloadVersion.valueOf(short)
when the specified version is too new to be supported
by the codebase.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Class that builds
GetEntitiesInput
instances.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Class that builds
GetEntitiesOutput
instances.
This class represents the following YANG schema fragment defined in module odl-entity-owners
This class represents the following YANG schema fragment defined in module odl-entity-owners
Class that builds
GetEntityInput
instances.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Class that builds
GetEntityOutput
instances.
This class represents the following YANG schema fragment defined in module odl-entity-owners
This class represents the following YANG schema fragment defined in module odl-entity-owners
Class that builds
GetEntityOwnerInput
instances.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Class that builds
GetEntityOwnerOutput
instances.Local message sent to an actor to retrieve
DataTreeListenerInfo
for reporting.Request a shard to report the clients it knows about.
Request all shards to report their known frontend clients.
Class that builds
GetKnownClientsForAllShardsInput
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
GetKnownClientsForAllShardsOutput
instances.Reply to
GetKnownClients
.Local message sent to a RaftActor to obtain a snapshot of statistical information.
Local message sent to a Shard to retrieve its data tree instance.
Message sent to the local ShardManager to request the current role for the given shard.
Returns the current role for the requested module shard.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
GetShardRoleInput
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
GetShardRoleOutput
instances.Reply to GetShardRole, containing the current role of the shard if present on the ShardManager.
Internal client message to get a snapshot of the current state based on whether or not persistence is enabled.
Reply to GetSnapshot that returns a serialized Snapshot instance.
Gossiper that syncs bucket store across nodes in the cluster.
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
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.
Immutable implementation of ElectionTerm.
A blank transaction request.
Successful reply to an
IncrementTransactionSequenceRequest
.Message sent from a leader to install a snapshot chunk on a follower.
This interface is used to pass the unit of work via the actors mailbox.
A lock implementation which allows users to perform optimistic reads and validate them in a fashion similar
to
StampedLock
.Exception thrown from
InversibleLock.optimisticRead()
and can be used to wait for the racing write
to complete using InversibleLockException.awaitResolution()
.Leader which is termed as isolated.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
KnownClients
instances.This class represents the key of
KnownClients
class.The behavior of a RaftActor when it is in the Leader state.
Class that builds
LeaderActorRef
instances.Encapsulates the leader state and logic for sending snapshot chunks to a follower.
Enumeration of possible shard leader locations relative to the local node.
Listener for shard leader location changes.
Registration of a
LeaderLocationListener
.A local message initiated internally from the RaftActor when some state of a leader has changed.
Message sent from a leader to its followers to indicate leadership transfer is starting.
Deprecated.
Class that builds
Local
instances.Generic
RequestFailure
involving a LocalHistoryRequest
.Globally-unique identifier of a local history.
Abstract base class for
Request
s involving specific local history.Success class for
RequestSuccess
es involving a specific local history.Local message sent in reply to FindPrimaryShard to indicate the primary shard is local to the caller.
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.
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.
Exception thrown when attempting to find a local shard but it doesn't exist.
Akka SnapshotStore implementation backed by the local file system.
Return the transport-level information about where a shard has a home.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
LocateShardInput
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
LocateShardOutput
instances.Message sent to local shard to try to gain shard leadership.
Attempts to move the shard leader of the given module based shard to the local
node.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
MakeLeaderLocalInput
instances.Class that builds
MakeLeaderLocalOutput
instances.Type-safe encapsulation of a cluster member name.
This class represents the following YANG schema fragment defined in module odl-controller-cds-types
Location of the hypothetical cluster member node.
The list of member voting states
Class that builds
MemberVotingState
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
MergeModification stores all the parameters required to merge data into the specified path.
An abstract concept of a Message.
Externalizable proxy for use with
Message
subclasses.This class re-assembles messages sliced into smaller chunks by
MessageSlicer
.Represents a sliced message chunk.
An exception indicating a message slice failure.
This class slices messages into smaller chunks.
The reply message for
MessageSlice
.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.
An
AbstractVersionedShardDataTreeSnapshot
which contains additional metadata.Represents behaviour that can be exhibited by actors of type
AbstractActor
Maintains metrics registry that is provided to reporters.
Transitional marker interface for use with evolution of serializable classes held in persistence.
Represents a modification to the data store.
A transaction request to apply a particular set of operations on top of the current transaction.
A reusable builder for creating
ModifyTransactionRequest
message instances.Response to a
ModifyTransactionRequest
which does not have a PersistenceProtocol
.Encapsulates configuration for a module.
Interface for a class that provides module and shard configuration information.
Encapsulates information for adding a new module shard configuration.
MutableCompositeModification is just a mutable version of a CompositeModification.
Implementation of
ThreadFactory
.
This class represents the following YANG schema fragment defined in module odl-entity-owners
A DataPersistenceProvider implementation with persistence disabled, essentially a no-op.
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
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.
Implementation of PeerAddressResolver that does nothing.
An akka Procedure that does nothing.
RaftActorSnapshotCohort implementation that does nothing.
NormalizedNodeNavigator walks a
NormalizedNodeVisitor
through the NormalizedNode.Utility class to output NormalizedNodes as XML.
Exception indicating a shard has no current leader.
General error raised when the recipient of a Request is not the correct backend to talk to.
Common type definitions related to clustered data store.
An initial cut at modeling entity ownership status information in a way which
not dependent on the datastore.
The response to a GetOnDemandRaftState message.
OnDemandRaftState.AbstractBuilder<B extends OnDemandRaftState.AbstractBuilder<B,T>,T extends OnDemandRaftState>
Extends OnDemandRaftState to add Shard state.
Message sent to a data tree change listener actor to indicate there is no initial data.
Class for limiting operations.
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
This class acts as a supervisor, creates all the actors, resumes them, if an exception is thrown.
Global bootstrap component.
OSGi manifestation of a the distributed datastore, as represented by
AbstractDataStore
.A
RequestException
indicating that the backend has received a Request whose sequence does not match the
next expected sequence for the target.A
RequestException
indicating that the backend has received a RequestEnvelope whose sequence does not match
the next expected sequence.
This class represents the following YANG schema fragment defined in module odl-entity-owners
Notification from distributed-data sent to the SingleEntityListenerActor when owner changes for the tracked entity.
Responsible for tracking candidates and assigning ownership of entities.
Behavior that retrieves current candidates/owners from distributed-data and switches to OwnerSupervisor when the
sync has finished.
Exception thrown from
ABIVersion.valueOf(short)
when the specified version is too old and no longer
supported by the codebase.Exception thrown from
PayloadVersion.valueOf(short)
when the specified version is too old and no longer
supported by the codebase.An instance of a
Payload
class is meant to be used as the Payload for AppendEntries
.Enumeration of all ABI versions supported by this implementation of persistence.
Interface to resolve raft actor peer addresses.
Stores information about a raft peer.
This class represents the following YANG schema fragment defined in module distributed-datastore-provider
Enumeration of transaction persistence protocols.
A DataPersistenceProvider implementation with persistence enabled.
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.
The behavior of a RaftActor when it is in the PreLeader state.
Local message DTO that contains information about the primary shard.
Maintains a cache of PrimaryShardInfo Future instances per shard.
The PruningDataTreeModification first removes all entries from the data which do not belong in the schemaContext
before delegating it to the actual DataTreeModification.
A PruningDataTreeModification which always performs pruning before attempting an operation.
A PruningDataTreeModification which performs pruning only when an operation results in an
SchemaValidationFailedException
.Payload persisted when a local history is completely purged, i.e.
Request to purge a local history.
Payload persisted when a transaction is purged from the frontend.
This class listens to Akka RemotingLifecycleEvent events to detect when this node has been
quarantined by another.
RaftActor encapsulates a state machine that needs to be kept synchronized
in a cluster.
The interface for a class that implements a specific behavior of a RaftActor.
The RaftActorContext contains that portion of the RaftActors state that
needs to be shared with it's behaviors.
Implementation of the RaftActorContext interface.
A raft actor support class that participates in leadership transfer.
Interface for a class that participates in raft actor persistence recovery.
Interface for a class that participates in raft actor snapshotting.
The RaftPolicy is intended to change the default behavior of Raft.
Interface implemented by all requests exchanged in the Raft protocol.
Enumerates the raft versions.
A transaction request to read a particular path exists in the current view of a particular transaction.
Successful reply to an
ReadTransactionRequest
.Message notifying the shard leader to apply modifications which have been
prepared locally against its DataTree.
Specialized message transformer, which transforms a
ReadyLocalTransaction
into a BatchedModifications
message.Forwarder class responsible for routing requests from the previous connection incarnation back to the originator,
which can then convert them as appropriate.
An
AbstractClientConnection
which is being reconnected after having timed out.Sent to Candidate registry to register the candidate for a given entity.
Request a
DOMDataTreeChangeListener
registration be made on the shard leader.Successful reply to a notification listener registration request.
Local ShardManager message to register a callback to be notified of shard availability changes.
Register a DOMEntityOwnershipListener for a given entity-type.
Message sent from the listener of Role Change messages to register itself to the Role Change Notifier.
Reply message sent from a RoleChangeNotifier to the Role Change Listener.
A remote message sent to locate the primary shard.
This is the base class which initialize all the actors, listeners and
default RPc implementation so remote invocation of rpcs.
Local or remote message sent in reply to FindPrimaryShard to indicate the primary shard is remote to the caller.
JMX bean to check remote rpc registry.
Provides schema sources from
RemoteYangTextSourceProvider
.A remote yang text source provider provides serializable yang text sources.
Remote schema provider implementation backed by local schema provider.
Removes replicas for all shards on this node.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
RemoveAllShardReplicasInput
instances.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
RemoveAllShardReplicasOutput
instances.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.
Message sent to remove a replica (§4.1).
Reply to a RemoveServer message (§4.1).
A message sent to the ShardManager to dynamically remove a local shard
replica available in this node.
Removes an existing replica of a shard from this node via the RemoveServer
mechanism as described in the Raft paper.
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
RemoveShardReplicaInput
instances.Class that builds
RemoveShardReplicaOutput
instances.Represents the ReplicatedLog that needs to be kept in sync by the RaftActor.
Represents one entry in the replicated log.
A request message concept.
A failure cause behind a
RequestFailure
to process a Request
.A failure response to a
Request
.Externalizable proxy for use with
RequestFailure
subclasses.Message sent to leader to transfer leadership to a particular follower.
A successful reply to a
Request
.Invoked by candidates to gather votes (§5.2).
Abstract counterpart to a
Request
.General error raised when the recipient of a
Request
determines that the request contains
a ClientIdentifier
which corresponds to an outdated generation.The NormalizedNodePruner removes all nodes from the input NormalizedNode that do not have a corresponding
schema element in the passed in SchemaContext.
Role Change message initiated internally from the Raft Actor when a the behavior/role changes.
Notification message representing a Role change of a cluster member.
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.
Utility methods for dealing with datastore root
ContainerNode
with respect to module shards.An Exception for transferring RpcErrors.
Registry to look up cluster nodes that have registered for a given RPC.
All messages used by the RpcRegistry.
General error raised when the recipient of a
Request
fails to process a request.Interface representing scheduled
ThreadPool
.Implementation of
ScheduledThreadPool
wraps
ScheduledExecutorService
.This messages is sent via a schedule to the Leader to prompt it to send a heart beat to its followers.
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.
Provides various utility methods for serialization and de-serialization.
A general server change reply.
Enumerates server configuration change status reply codes.
Payload data for server configuration log entries.
Server information.
The ServerRemoved message is sent to a server which has been removed successfully from the ServerConfiguration.
A Shard represents a portion of the logical data tree.
Encapsulated configuration for a shard.
Internal shard state, similar to a DOMStore, but optimized for use in the actor system, e.g.
Actor used to generate and publish DataTreeChange notifications.
MXBean interface for reporting shard data tree change listener information.
ShardDataTreeNotificationPublisherActor<T extends org.opendaylight.controller.cluster.datastore.ShardDataTreeNotificationPublisher>
Actor used to generate and publish data tree notifications.
Abstract base class for snapshots of the ShardDataTree.
Base class for various bits of metadata attached to a
MetadataShardDataTreeSnapshot
.Exception indicating a shard leader is not responding to messages.
A local message derived from LeaderStateChanged containing additional Shard-specific info that is sent
when some state of the shard leader has changed.
Represents the persisted snapshot state for the ShardManager.
This class represents the following YANG schema fragment defined in module cluster-admin
Actor for a shard read transaction.
Actor for a shard read/write transaction.
The list of results, one per shard
This class represents the following YANG schema fragment defined in module cluster-admin
Class that builds
ShardResult1
instances.Class that builds
ShardResult
instances.This class represents the key of
ShardResult
class.
This class represents the following YANG schema fragment defined in module cluster-admin
This is an offload actor, which is given an isolated snapshot of the data tree.
Encapsulates the snapshot State for a Shard.
MXBean interface for shard stats.
The role of ShardStrategy is to figure out which shards a given piece of data belongs to.
The ShardTransaction Actor represents a remote transaction that delegates all actions to DOMDataReadWriteTransaction.
Actor for a shard write-only transaction.
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.
Message sent to a raft actor to shutdown gracefully.
A
AbstractClientActor
which acts as the point of contact for DistributedDataStore.A
ReplicatedLogEntry
implementation.Specialized serializer for
SimpleReplicatedLogEntry
that optimizes serialization.Keeps track of owners for a single entity, which is mapped to a single LWWRegister in distributed-data.
Payload persisted when a local history is instructed some transaction identifiers, i.e.
Request to skip a number of
TransactionIdentifier
s within a {code local history}.Successful reply to a
SkipTransactionsRequest
.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.
Maintains the state of a sliced message.
Options for slicing a message with
MessageSlicer.slice(SliceOptions)
.Represents a snapshot of the raft data.
Implementations of this interface are used as the state payload for a snapshot.
Internal message sent when a snapshot capture is complete.
Manages the capturing of snapshots for a RaftActor.
Interface for a snapshot phase state.
A reply message indicating success.
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.
Sent to the listener actor to stop it on demand ie during listener unregistration.
A RaftPolicy that disables elections so that we can then specify exactly which Shard Replica should be
Leader.
A bean class that holds various thread executor statistic metrics.
MXBean interface for thread executor statistic metrics.
MXBean implementation of the ThreadExecutorStatsMXBean interface that retrieves statistics
from a backing
ExecutorService
.Interface representing thread pool.
ThreePhaseCommitCohortProxy represents a set of remote cohort proxies.
Message sent to a follower to force an immediate election time out.
A transaction request to perform the abort step of the three-phase commit protocol.
Successful reply to a coordinated commit request initiated by a
ModifyTransactionRequest
or CommitLocalTransactionRequest
.Successful reply to a coordinated commit request initiated by a
ModifyTransactionRequest
or CommitLocalTransactionRequest
.Successful reply to a coordinated commit request.
A
TransactionModification
which has a data component.Delete a particular path.
A transaction request to perform the final, doCommit, step of the three-phase commit protocol.
Generic
RequestFailure
involving a TransactionRequest
.Globally-unique identifier of a transaction.
Merge a
NormalizedNode
tree onto a specific path.An individual modification of a transaction's state.
A transaction request to perform the second, preCommit, step of the three-phase commit protocol.
Successful reply to a
TransactionPreCommitRequest
.A transaction potentially spanning multiple backend shards.
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.
Successful reply to a
TransactionPurgeRequest
.TransactionRateLimitingCallback computes the new transaction rate limit on the successful completion of a
transaction.
A
Mapper
extracting the ActorSelection
pointing to the actor which
is backing a particular transaction.Abstract base class for
Request
s involving specific transaction.Abstract base class for
RequestSuccess
es involving specific transaction.Modification to write (and replace) a subtree at specified path with another subtree.
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.
An unbounded ControlAwareMailbox that also supports DequeBasedMessageQueueSemantics so it can be used with
persistent actors which use stashing.
Represents a unified view of configuration.
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.
A
RequestException
indicating that the backend has received a request referencing an unknown history.Sent to CandidateRegistry to unregister the candidate for a given entity.
Unregister a listener from the EntityTypeListenerRegistry.
A more efficient equivalent of
ImmutableMap<UnsignedLong, Boolean>
.General error raised when the recipient of a
Request
determines that it does not know how to handle
the request.Message class to persist election term information.
Abstract base class for a versioned Externalizable message.
Enumerates voting states for a peer.
WriteModification stores all the parameters required to write data to the specified path.
YangTextSchemaSource
serialization proxy.