Index

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

A

AbstractAsyncPrimitive<A extends AsyncPrimitive,​S> - Class in io.atomix.primitive
Abstract base class for primitives that interact with Raft replicated state machines via proxy.
AbstractPrimitiveService<C> - Class in io.atomix.primitive.service
Raft service.
accept(Consumer<C>) - Method in interface io.atomix.primitive.session.Session
Sends an event to the client via the client proxy.
accept(Consumer<S>) - Method in interface io.atomix.primitive.proxy.ProxySession
Submits an empty operation to the given partition.
acceptAll(Consumer<S>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Submits an empty operation to all partitions.
acceptBy(String, Consumer<S>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Submits an empty operation to the owning partition for the given key.
acceptOn(PartitionId, Consumer<S>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Submits an empty operation to the given partition.
active() - Method in enum io.atomix.primitive.session.Session.State
 
ADD - io.atomix.primitive.protocol.set.SetDelegateEvent.Type
Element added to set.
addAndGet(long) - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Atomically adds the given value to the current value.
addEventListener(EventType, Consumer<PrimitiveEvent>) - Method in interface io.atomix.primitive.session.SessionClient
Adds an event listener.
addListener(MapDelegateEventListener<K, V>) - Method in interface io.atomix.primitive.protocol.map.MapDelegate
Adds the specified listener to the map which will be notified whenever the mappings in the map are changed.
addListener(SetDelegateEventListener<E>) - Method in interface io.atomix.primitive.protocol.set.SetDelegate
Adds the specified listener to the set which will be notified whenever the entries in the set are changed.
addListener(ValueDelegateEventListener<V>) - Method in interface io.atomix.primitive.protocol.value.ValueDelegate
Registers the specified listener to be notified whenever the atomic value is updated.
addListener(SessionListener) - Method in interface io.atomix.primitive.session.Sessions
Adds a listener to the sessions.
addStateChangeListener(Consumer<PrimitiveState>) - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
addStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.DistributedPrimitive
Registers a listener to be called when the primitive's state changes.
addStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.log.LogClient
Registers a session state change listener.
addStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.log.LogSession
Registers a session state change listener.
addStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Registers a session state change listener.
addStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.proxy.ProxySession
Registers a session state change listener.
addStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.session.SessionClient
Registers a session state change listener.
append(byte[]) - Method in interface io.atomix.primitive.log.LogProducer
Appends the given entry to the log.
apply(Commit<byte[]>) - Method in class io.atomix.primitive.service.AbstractPrimitiveService
 
apply(Commit<byte[]>) - Method in interface io.atomix.primitive.service.PrimitiveService
Applies a commit to the state machine.
apply(Commit<byte[]>) - Method in interface io.atomix.primitive.service.ServiceExecutor
Applies the given commit to the executor.
apply(Function<S, R>) - Method in interface io.atomix.primitive.proxy.ProxySession
Submits an empty operation to the given partition.
applyAll(Function<S, R>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Submits an empty operation to all partitions.
applyBy(Object, Function<S, R>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Submits an empty operation to the owning partition for the given key.
applyBy(String, Function<S, R>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Submits an empty operation to the owning partition for the given key.
applyOn(PartitionId, Function<S, R>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Submits an empty operation to the given partition.
async() - Method in interface io.atomix.primitive.SyncPrimitive
Returns the underlying asynchronous primitive.
ASYNCHRONOUS - io.atomix.primitive.Replication
Asynchronous replication strategy.
AsyncPrimitive - Interface in io.atomix.primitive
Asynchronous primitive.

B

backup(BackupOutput) - Method in interface io.atomix.primitive.service.PrimitiveService
Backs up the service state to the given buffer.
BackupInput - Interface in io.atomix.primitive.service
Backup input.
BackupOutput - Interface in io.atomix.primitive.service
Backup output.
backups() - Method in interface io.atomix.primitive.partition.Partition
Returns the partition's backups.
backups(int) - Method in class io.atomix.primitive.partition.PrimaryTerm
Returns an ordered list of backup members.
build() - Method in class io.atomix.primitive.PrimitiveBuilder
Builds a new instance of the primitive.
buildAsync() - Method in class io.atomix.primitive.PrimitiveBuilder
Builds a new instance of the primitive asynchronously.
Builder() - Constructor for class io.atomix.primitive.log.LogSession.Builder
 
Builder() - Constructor for class io.atomix.primitive.session.SessionClient.Builder
 

C

candidates() - Method in class io.atomix.primitive.partition.PrimaryTerm
Returns the list of members.
canonical(EventType) - Static method in interface io.atomix.primitive.event.EventType
Simplifies the given event type.
canonicalize() - Method in interface io.atomix.primitive.event.EventType
Returns an identical event type in canonical form.
CHANGED - io.atomix.primitive.partition.PrimaryElectionEvent.Type
 
close() - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
close() - Method in interface io.atomix.primitive.AsyncPrimitive
Closes the primitive.
close() - Method in interface io.atomix.primitive.log.LogClient
Closes the log client.
close() - Method in interface io.atomix.primitive.log.LogSession
Closes the log session.
close() - Method in interface io.atomix.primitive.partition.ManagedPartitionGroup
Closes the partition group.
close() - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Closes the counter.
close() - Method in interface io.atomix.primitive.protocol.map.MapDelegate
Closes the map.
close() - Method in interface io.atomix.primitive.protocol.set.SetDelegate
Closes the set.
close() - Method in interface io.atomix.primitive.protocol.value.ValueDelegate
Closes the counter.
close() - Method in interface io.atomix.primitive.proxy.ProxyClient
Closes the proxy client.
close() - Method in interface io.atomix.primitive.proxy.ProxySession
Closes the proxy session.
close() - Method in interface io.atomix.primitive.service.PrimitiveService
Closes the state machine.
close() - Method in interface io.atomix.primitive.session.SessionClient
Closes the proxy.
close() - Method in class io.atomix.primitive.Synchronous
 
close() - Method in interface io.atomix.primitive.SyncPrimitive
Closes the primitive.
close(SessionId) - Method in class io.atomix.primitive.service.AbstractPrimitiveService
 
close(SessionId) - Method in interface io.atomix.primitive.service.PrimitiveService
Closes the session with the given identifier.
CLOSE - io.atomix.primitive.Recovery
Indicates that the session should be closed when lost.
CLOSED - io.atomix.primitive.PrimitiveState
Signifies a state wherein the primitive session has been closed and therefore cannot perform its functions.
CLOSED - io.atomix.primitive.session.Session.State
 
ClosedSession() - Constructor for exception io.atomix.primitive.PrimitiveException.ClosedSession
 
ClosedSession(String) - Constructor for exception io.atomix.primitive.PrimitiveException.ClosedSession
 
command(String) - Static method in interface io.atomix.primitive.operation.OperationId
Returns a new command operation identifier.
Command - Annotation Type in io.atomix.primitive.operation
Command annotation.
COMMAND - io.atomix.primitive.operation.OperationType
Command operation.
CommandFailure() - Constructor for exception io.atomix.primitive.PrimitiveException.CommandFailure
 
CommandFailure(String) - Constructor for exception io.atomix.primitive.PrimitiveException.CommandFailure
 
Commit<T> - Interface in io.atomix.primitive.service
Represents the committed state and metadata of a Raft state machine operation.
compareTo(PartitionId) - Method in class io.atomix.primitive.partition.PartitionId
 
compareTo(PrimitiveProtocol.Type<C>) - Method in interface io.atomix.primitive.protocol.PrimitiveProtocol.Type
 
ConcurrentModification() - Constructor for exception io.atomix.primitive.PrimitiveException.ConcurrentModification
 
config() - Method in class io.atomix.primitive.partition.PartitionGroupMembership
Returns the partition group configuration.
ConfigService - Interface in io.atomix.primitive.config
Configuration service.
connect() - Method in class io.atomix.primitive.AbstractAsyncPrimitive
Connects the primitive.
connect() - Method in interface io.atomix.primitive.log.LogClient
Connects the log client.
connect() - Method in interface io.atomix.primitive.log.LogSession
Connects the log session.
connect() - Method in interface io.atomix.primitive.proxy.ProxyClient
Connects the proxy client.
connect() - Method in interface io.atomix.primitive.proxy.ProxySession
Connects the proxy session.
connect() - Method in interface io.atomix.primitive.session.SessionClient
Connects the proxy.
connect(PartitionManagementService) - Method in interface io.atomix.primitive.partition.ManagedPartitionGroup
Connects to the partition group.
CONNECTED - io.atomix.primitive.PrimitiveState
Signifies a state wherein the primitive is operating correctly and is capable of meeting the advertised consistency and reliability guarantees.
Consistency - Enum in io.atomix.primitive
Primitive consistency model.
consume(long, Consumer<LogRecord>) - Method in interface io.atomix.primitive.log.LogConsumer
Adds a new consumer.
consume(Consumer<LogRecord>) - Method in interface io.atomix.primitive.log.LogConsumer
Adds a new consumer.
consumer() - Method in interface io.atomix.primitive.log.LogSession
Returns the log consumer.
context() - Method in interface io.atomix.primitive.log.LogSession
Returns the partition thread context.
context() - Method in interface io.atomix.primitive.proxy.ProxySession
Returns the session thread context.
context() - Method in interface io.atomix.primitive.session.SessionClient
Returns the partition thread context.
CounterCompatibleBuilder<B extends CounterCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.counter
Counter builder.
CounterDelegate - Interface in io.atomix.primitive.protocol.counter
Gossip-based counter service.
CounterProtocol - Interface in io.atomix.primitive.protocol.counter
Counter protocol.
createGroup(C) - Method in interface io.atomix.primitive.partition.PartitionGroupFactory
Creates a new partition group.
createPrimitive(String, PrimitiveType) - Method in interface io.atomix.primitive.PrimitiveRegistry
Creates a new distributed primitive.
currentIndex() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the current state machine index.
currentOperation() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the current operation type.
currentSession() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the current session.

D

decrementAndGet() - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Atomically decrement by one and return the updated value.
DEFAULT_OPERATION_TIMEOUT_MILLIS - Static variable in interface io.atomix.primitive.DistributedPrimitive
Default timeout for primitive operations.
delete() - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
delete() - Method in interface io.atomix.primitive.AsyncPrimitive
Purges state associated with this primitive.
delete() - Method in interface io.atomix.primitive.proxy.ProxyClient
Deletes the proxy client.
delete() - Method in interface io.atomix.primitive.proxy.ProxySession
Closes the proxy session and deletes the service.
delete() - Method in interface io.atomix.primitive.session.SessionClient
Closes the session and deletes the service.
delete() - Method in class io.atomix.primitive.Synchronous
 
delete() - Method in interface io.atomix.primitive.SyncPrimitive
Purges state associated with this primitive.
deletePrimitive(String) - Method in interface io.atomix.primitive.PrimitiveRegistry
Deletes the given distributed primitive.
DistributedPrimitive - Interface in io.atomix.primitive
Interface for all distributed primitives.

E

element() - Method in class io.atomix.primitive.protocol.set.SetDelegateEvent
Returns the set element.
enter(GroupMember) - Method in interface io.atomix.primitive.partition.PrimaryElection
Enters the primary election.
equals(Object) - Method in class io.atomix.primitive.event.PrimitiveEvent
 
equals(Object) - Method in class io.atomix.primitive.operation.PrimitiveOperation
 
equals(Object) - Method in class io.atomix.primitive.partition.GroupMember
 
equals(Object) - Method in class io.atomix.primitive.partition.PartitionId
 
equals(Object) - Method in class io.atomix.primitive.partition.PartitionMetadata
 
equals(Object) - Method in class io.atomix.primitive.partition.PrimaryTerm
 
equals(Object) - Method in class io.atomix.primitive.PrimitiveInfo
 
equals(Object) - Method in class io.atomix.primitive.session.SessionMetadata
 
event(EventType) - Static method in class io.atomix.primitive.event.PrimitiveEvent
Creates a new primitive event.
event(EventType, byte[]) - Static method in class io.atomix.primitive.event.PrimitiveEvent
Creates a new primitive event.
Event - Annotation Type in io.atomix.primitive.event
Annotates an event method.
Events - Class in io.atomix.primitive.event
Event utilities.
EventType - Interface in io.atomix.primitive.event
Raft event identifier.
EVENTUAL - io.atomix.primitive.Consistency
Eventual consistency model.
execute(PrimitiveOperation) - Method in interface io.atomix.primitive.session.SessionClient
Executes an operation to the cluster.
expire(SessionId) - Method in class io.atomix.primitive.service.AbstractPrimitiveService
 
expire(SessionId) - Method in interface io.atomix.primitive.service.PrimitiveService
Expires the session with the given identifier.
EXPIRED - io.atomix.primitive.PrimitiveState
Signifies a state wherein the primitive's session has been expired and therefore cannot perform its functions.
EXPIRED - io.atomix.primitive.session.Session.State
 

F

from(long) - Static method in class io.atomix.primitive.PrimitiveId
Creates a snapshot ID from the given number.
from(long) - Static method in class io.atomix.primitive.session.SessionId
Returns a new session ID from the given identifier.
from(String) - Static method in interface io.atomix.primitive.event.EventType
Creates a new Raft event identifier.
from(String) - Static method in class io.atomix.primitive.partition.MemberGroupId
Creates a new member group identifier.
from(String) - Static method in class io.atomix.primitive.PrimitiveId
Creates a snapshot ID from the given string.
from(String, int) - Static method in class io.atomix.primitive.partition.PartitionId
Creates a partition identifier from an integer.
from(String, OperationType) - Static method in interface io.atomix.primitive.operation.OperationId
Returns a new operation identifier.

G

get() - Method in class io.atomix.primitive.PrimitiveBuilder
Gets or builds a singleton instance of the primitive.
get() - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Returns the counter value.
get() - Method in interface io.atomix.primitive.protocol.value.ValueDelegate
Gets the current value.
getAndAdd(long) - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Atomically adds the given value to the current value.
getAndDecrement() - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Atomically decrement by one and return the previous value.
getAndIncrement() - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Atomically increment by one and return the previous value.
getAndSet(V) - Method in interface io.atomix.primitive.protocol.value.ValueDelegate
Atomically sets to the given value and returns the old value.
getAsync() - Method in class io.atomix.primitive.PrimitiveBuilder
Gets or builds a singleton instance of the primitive asynchronously.
getClient() - Method in interface io.atomix.primitive.partition.Partition
Returns the partition client.
getCommunicationService() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the cluster communication service.
getConfig(String, PrimitiveType) - Method in interface io.atomix.primitive.config.ConfigService
Returns the registered configuration for the given primitive.
getElectionFor(PartitionId) - Method in interface io.atomix.primitive.partition.PrimaryElectionService
Returns the primary election for the given partition identifier.
getElectionService() - Method in interface io.atomix.primitive.partition.PartitionManagementService
Returns the primary election service.
getEventMap(Class<?>) - Static method in class io.atomix.primitive.event.Events
Returns the collection of events provided by the given service interface.
getEventService() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the cluster event service.
getExecutorService() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the primitive thread pool.
getGroupType(String) - Method in interface io.atomix.primitive.partition.PartitionGroupTypeRegistry
Returns the partition group type with the given name.
getGroupTypes() - Method in interface io.atomix.primitive.partition.PartitionGroupTypeRegistry
Returns the collection of partition group type configurations.
getMemberGroup(Member) - Method in interface io.atomix.primitive.partition.MemberGroupService
Returns the group for the given node.
getMemberGroups() - Method in interface io.atomix.primitive.partition.MemberGroupService
Returns the collection of member groups.
getMemberGroups(Collection<Member>) - Method in interface io.atomix.primitive.partition.MemberGroupProvider
Creates member groups from the given list of nodes.
getMembership(String) - Method in interface io.atomix.primitive.partition.PartitionGroupMembershipService
Returns the members for the given group.
getMemberships() - Method in interface io.atomix.primitive.partition.PartitionGroupMembershipService
Returns the membership for all partition groups.
getMembershipService() - Method in interface io.atomix.primitive.partition.PartitionManagementService
Returns the cluster service.
getMembershipService() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the cluster service.
getMessagingService() - Method in interface io.atomix.primitive.partition.PartitionManagementService
Returns the cluster messaging service.
getMethodMap(Class<?>) - Static method in class io.atomix.primitive.event.Events
Returns the collection of events provided by the given service interface.
getMethodMap(Class<?>) - Static method in class io.atomix.primitive.operation.Operations
Returns the collection of operations provided by the given service interface.
getName() - Method in class io.atomix.primitive.config.PrimitiveConfig
 
getName() - Method in class io.atomix.primitive.partition.PartitionGroupConfig
 
getNamespaceConfig() - Method in class io.atomix.primitive.config.PrimitiveConfig
Returns the serializer configuration.
getOperationMap(Class<?>) - Static method in class io.atomix.primitive.operation.Operations
Returns the collection of operations provided by the given service interface.
getPartition(PartitionId) - Method in interface io.atomix.primitive.log.LogClient
Returns the partition with the given identifier.
getPartition(PartitionId) - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns a partition by ID.
getPartition(PartitionId) - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the proxy with the given identifier.
getPartition(Object) - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the partition proxy for the given key.
getPartition(String) - Method in interface io.atomix.primitive.log.LogClient
Returns the partition for the given key.
getPartition(String) - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns the partition for the given key.
getPartition(String) - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the partition proxy for the given key.
getPartitionGroup(PrimitiveProtocol.Type) - Method in interface io.atomix.primitive.partition.PartitionService
Returns the first partition group that matches the given primitive type.
getPartitionGroup(ProxyProtocol) - Method in interface io.atomix.primitive.partition.PartitionService
Returns the first partition group that matches the given primitive protocol.
getPartitionGroup(String) - Method in interface io.atomix.primitive.partition.PartitionService
Returns a partition group by name.
getPartitionGroups() - Method in interface io.atomix.primitive.partition.PartitionService
Returns a collection of all partition groups.
getPartitionGroupTypeRegistry() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the partition group type registry.
getPartitionId(Object) - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the partition ID for the given key.
getPartitionId(String) - Method in interface io.atomix.primitive.log.LogClient
Returns the partition ID for the given key.
getPartitionId(String) - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the partition ID for the given key.
getPartitionIds() - Method in interface io.atomix.primitive.log.LogClient
Returns the collection of all partition IDs.
getPartitionIds() - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns a sorted list of partition IDs.
getPartitionIds() - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the collection of all partition IDs.
getPartitions() - Method in interface io.atomix.primitive.log.LogClient
Returns the collection of all partitions.
getPartitions() - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns a collection of all partitions.
getPartitions() - Method in class io.atomix.primitive.partition.PartitionGroupConfig
Returns the number of partitions in the group.
getPartitions() - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the collection of all partition proxies.
getPartitionService() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the partition service.
getPrimitive(String) - Method in interface io.atomix.primitive.PrimitiveRegistry
Returns the info for a single primitive.
getPrimitive(String, PrimitiveType<?, ?, P>) - Method in interface io.atomix.primitive.PrimitiveFactory
Gets or creates a distributed primitive.
getPrimitive(String, PrimitiveType<?, C, P>, C) - Method in interface io.atomix.primitive.PrimitiveFactory
Gets or creates a distributed primitive.
getPrimitive(String, Supplier<CompletableFuture<P>>) - Method in interface io.atomix.primitive.PrimitiveCache
Gets or creates a locally cached multiton primitive instance.
getPrimitiveAsync(String, PrimitiveType<?, ?, P>) - Method in interface io.atomix.primitive.PrimitiveFactory
Gets or creates a distributed primitive asynchronously.
getPrimitiveAsync(String, PrimitiveType<?, C, P>, C) - Method in interface io.atomix.primitive.PrimitiveFactory
Gets or creates a distributed primitive asynchronously.
getPrimitiveCache() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the local primitive cache.
getPrimitiveRegistry() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the primitive registry.
getPrimitives() - Method in interface io.atomix.primitive.PrimitiveFactory
Returns a collection of open primitives.
getPrimitives() - Method in interface io.atomix.primitive.PrimitiveRegistry
Returns a collection of open primitives.
getPrimitives(PrimitiveType) - Method in interface io.atomix.primitive.PrimitiveFactory
Returns a collection of open primitives of the given type.
getPrimitives(PrimitiveType) - Method in interface io.atomix.primitive.PrimitiveRegistry
Returns a collection of open primitives of the given type.
getPrimitiveType(String) - Method in interface io.atomix.primitive.PrimitiveFactory
Returns a primitive type by name.
getPrimitiveType(String) - Method in interface io.atomix.primitive.PrimitiveTypeRegistry
Returns the primitive type for the given name.
getPrimitiveTypeRegistry() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the primitive type registry.
getPrimitiveTypes() - Method in interface io.atomix.primitive.partition.PartitionManagementService
Returns the primitive type registry.
getPrimitiveTypes() - Method in interface io.atomix.primitive.PrimitiveTypeRegistry
Returns the collection of registered primitive types.
getProtocolConfig() - Method in class io.atomix.primitive.config.PrimitiveConfig
Returns the protocol configuration.
getProtocolType(String) - Method in interface io.atomix.primitive.protocol.PrimitiveProtocolTypeRegistry
Returns the protocol type for the given configuration.
getProtocolTypeRegistry() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the primitive protocol type registry.
getProtocolTypes() - Method in interface io.atomix.primitive.protocol.PrimitiveProtocolTypeRegistry
Returns the collection of registered protocol types.
getSerializationService() - Method in interface io.atomix.primitive.PrimitiveManagementService
Returns the primitive serialization service.
getSession(long) - Method in interface io.atomix.primitive.session.Sessions
Returns a session by session ID.
getSessionIdService() - Method in interface io.atomix.primitive.partition.PartitionManagementService
Returns the session ID generator service.
getState() - Method in interface io.atomix.primitive.log.LogSession
Returns the current session state.
getState() - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the session state.
getState() - Method in interface io.atomix.primitive.proxy.ProxySession
Returns the session state.
getState() - Method in interface io.atomix.primitive.session.Session
Returns the session state.
getState() - Method in interface io.atomix.primitive.session.SessionClient
Returns the session state.
getSystemMembership() - Method in interface io.atomix.primitive.partition.PartitionGroupMembershipService
Returns the system group membership.
getSystemPartitionGroup() - Method in interface io.atomix.primitive.partition.PartitionService
Returns the system partition group.
getTerm() - Method in interface io.atomix.primitive.partition.PrimaryElection
Returns the current term.
GossipProtocol - Interface in io.atomix.primitive.protocol
Dissemination protocol.
group() - Method in class io.atomix.primitive.partition.PartitionGroupMembership
Returns the partition group name.
group() - Method in class io.atomix.primitive.partition.PartitionId
Returns the partition group name.
group() - Method in interface io.atomix.primitive.protocol.LogProtocol
Returns the protocol partition group name.
group() - Method in interface io.atomix.primitive.protocol.ProxyProtocol
Returns the protocol partition group name.
groupId() - Method in class io.atomix.primitive.partition.GroupMember
Returns the member group ID.
GroupMember - Class in io.atomix.primitive.partition
Primary election member.
GroupMember(MemberId, MemberGroupId) - Constructor for class io.atomix.primitive.partition.GroupMember
 
GROUPS_CHANGED - io.atomix.primitive.partition.MemberGroupEvent.Type
 

H

handle(OperationId, Function<Commit<byte[]>, byte[]>) - Method in interface io.atomix.primitive.service.ServiceExecutor
Registers a operation callback.
hashCode() - Method in class io.atomix.primitive.event.PrimitiveEvent
 
hashCode() - Method in class io.atomix.primitive.operation.PrimitiveOperation
 
hashCode() - Method in class io.atomix.primitive.partition.GroupMember
 
hashCode() - Method in class io.atomix.primitive.partition.PartitionId
 
hashCode() - Method in class io.atomix.primitive.partition.PartitionMetadata
 
hashCode() - Method in class io.atomix.primitive.partition.PrimaryTerm
 
hashCode() - Method in class io.atomix.primitive.PrimitiveInfo
 
hashCode() - Method in class io.atomix.primitive.session.SessionMetadata
 
HOST_AWARE - io.atomix.primitive.partition.MemberGroupStrategy
Host aware member group strategy.

I

id() - Method in class io.atomix.primitive.operation.PrimitiveOperation
Returns the operation identifier.
id() - Method in interface io.atomix.primitive.partition.MemberGroup
Returns the group identifier.
id() - Method in interface io.atomix.primitive.partition.Partition
Returns the partition identifier.
id() - Method in class io.atomix.primitive.partition.PartitionMetadata
Returns the partition identifier.
incrementAndGet() - Method in interface io.atomix.primitive.protocol.counter.CounterDelegate
Atomically increment by one and return the updated value.
index() - Method in class io.atomix.primitive.log.LogRecord
Returns the record index.
index() - Method in interface io.atomix.primitive.service.Commit
Returns the commit index.
init(ServiceContext) - Method in class io.atomix.primitive.service.AbstractPrimitiveService
 
init(ServiceContext) - Method in interface io.atomix.primitive.service.PrimitiveService
Initializes the state machine.
INSERT - io.atomix.primitive.protocol.map.MapDelegateEvent.Type
Entry added to map.
INSERTION - io.atomix.primitive.Ordering
Indicates that items should be ordered in insertion order.
Interrupted() - Constructor for exception io.atomix.primitive.PrimitiveException.Interrupted
 
io.atomix.primitive - package io.atomix.primitive
Provides classes and interfaces for defining and managing primitive types.
io.atomix.primitive.config - package io.atomix.primitive.config
Primitive instance configuration store.
io.atomix.primitive.event - package io.atomix.primitive.event
Provides interfaces for defining distributed primitive events.
io.atomix.primitive.log - package io.atomix.primitive.log
 
io.atomix.primitive.operation - package io.atomix.primitive.operation
Provides classes and interfaces for defining distributed primitive operations.
io.atomix.primitive.partition - package io.atomix.primitive.partition
Provides classes and interfaces for managing primitive partitions, partition groups, and member groups.
io.atomix.primitive.protocol - package io.atomix.primitive.protocol
Provides classes and interfaces for defining and managing primitive protocols.
io.atomix.primitive.protocol.counter - package io.atomix.primitive.protocol.counter
Interfaces for counter-compatible gossip protocols and delegates.
io.atomix.primitive.protocol.map - package io.atomix.primitive.protocol.map
Interfaces for map-compatible gossip protocols and delegates.
io.atomix.primitive.protocol.set - package io.atomix.primitive.protocol.set
Interfaces for set-compatible gossip protocols and delegates.
io.atomix.primitive.protocol.value - package io.atomix.primitive.protocol.value
Interfaces for value-compatible gossip protocols and delegates.
io.atomix.primitive.proxy - package io.atomix.primitive.proxy
Provides interfaces for operating on primitive services via Java proxies.
io.atomix.primitive.serialization - package io.atomix.primitive.serialization
 
io.atomix.primitive.service - package io.atomix.primitive.service
Provides classes and interfaces for defining distributed primitive state machines.
io.atomix.primitive.session - package io.atomix.primitive.session
Provides classes and interfaces for managing primitive sessions.
isMember(Member) - Method in interface io.atomix.primitive.partition.MemberGroup
Returns a boolean indicating whether the given node is a member of the group.
isReadOnly() - Method in class io.atomix.primitive.config.PrimitiveConfig
Returns whether the primitive is read-only.

J

join(PartitionManagementService) - Method in interface io.atomix.primitive.partition.ManagedPartitionGroup
Joins the partition group.

K

key() - Method in class io.atomix.primitive.protocol.map.MapDelegateEvent
Returns the map entry key.

L

LINEARIZABLE - io.atomix.primitive.Consistency
Linearizable consistency model.
localMemberId() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the local member ID
LogClient - Interface in io.atomix.primitive.log
Log client.
LogCompatibleBuilder<B extends LogCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol
Log compatible primitive.
LogConsumer - Interface in io.atomix.primitive.log
Log consumer.
logicalClock() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the state machine's logical clock.
logicalTime() - Method in interface io.atomix.primitive.service.Commit
Returns the logical time at which the operation was committed.
LogProducer - Interface in io.atomix.primitive.log
Log producer.
LogProtocol - Interface in io.atomix.primitive.protocol
Log replication based primitive protocol.
LogRecord - Class in io.atomix.primitive.log
Distributed log protocol record.
LogRecord(long, long, byte[]) - Constructor for class io.atomix.primitive.log.LogRecord
 
LogSession - Interface in io.atomix.primitive.log
Log session.
LogSession.Builder - Class in io.atomix.primitive.log
Log session builder.

M

ManagedMemberGroupService - Interface in io.atomix.primitive.partition
Manage member group service.
ManagedPartitionGroup - Interface in io.atomix.primitive.partition
Managed partition group.
ManagedPartitionGroupMembershipService - Interface in io.atomix.primitive.partition
Managed partition group membership service.
ManagedPartitionService - Interface in io.atomix.primitive.partition
Managed partition service.
ManagedPrimaryElection - Interface in io.atomix.primitive.partition
Managed primary election.
ManagedPrimaryElectionService - Interface in io.atomix.primitive.partition
Managed primary election service.
ManagedPrimitiveRegistry - Interface in io.atomix.primitive
Managed primitive registry.
ManagedSessionIdService - Interface in io.atomix.primitive.session
Managed session ID service.
map(Function<T, U>) - Method in interface io.atomix.primitive.service.Commit
Converts the commit from one type to another.
MapCompatibleBuilder<B extends MapCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.map
Map builder.
MapDelegate<K,​V> - Interface in io.atomix.primitive.protocol.map
Gossip-based map service.
MapDelegateEvent<K,​V> - Class in io.atomix.primitive.protocol.map
Map protocol event.
MapDelegateEvent(MapDelegateEvent.Type, K, V) - Constructor for class io.atomix.primitive.protocol.map.MapDelegateEvent
 
MapDelegateEvent(MapDelegateEvent.Type, K, V, long) - Constructor for class io.atomix.primitive.protocol.map.MapDelegateEvent
 
MapDelegateEvent.Type - Enum in io.atomix.primitive.protocol.map
Map protocol event type.
MapDelegateEventListener<K,​V> - Interface in io.atomix.primitive.protocol.map
Map protocol event listener.
MapProtocol - Interface in io.atomix.primitive.protocol.map
Map protocol.
mapToNull() - Method in interface io.atomix.primitive.service.Commit
Converts the commit to a null valued commit.
MemberGroup - Interface in io.atomix.primitive.partition
Partition member group.
MemberGroupEvent - Class in io.atomix.primitive.partition
Member group event.
MemberGroupEvent(MemberGroupEvent.Type, Collection<MemberGroup>) - Constructor for class io.atomix.primitive.partition.MemberGroupEvent
 
MemberGroupEvent(MemberGroupEvent.Type, Collection<MemberGroup>, long) - Constructor for class io.atomix.primitive.partition.MemberGroupEvent
 
MemberGroupEvent.Type - Enum in io.atomix.primitive.partition
Member group event type.
MemberGroupEventListener - Interface in io.atomix.primitive.partition
Member group event listener.
MemberGroupId - Class in io.atomix.primitive.partition
Member group identifier.
MemberGroupId(String) - Constructor for class io.atomix.primitive.partition.MemberGroupId
 
MemberGroupProvider - Interface in io.atomix.primitive.partition
Member group provider.
MemberGroupService - Interface in io.atomix.primitive.partition
Member group service.
MemberGroupStrategy - Enum in io.atomix.primitive.partition
Member group strategy.
memberId() - Method in class io.atomix.primitive.partition.GroupMember
Returns the member ID.
memberId() - Method in interface io.atomix.primitive.session.Session
Returns the member identifier to which the session belongs.
members() - Method in interface io.atomix.primitive.partition.Partition
Returns the collection of all members in the partition.
members() - Method in class io.atomix.primitive.partition.PartitionGroupMembership
Returns the partition group members.
members() - Method in class io.atomix.primitive.partition.PartitionMetadata
Returns the controller nodes that are members of this partition.
MEMBERS_CHANGED - io.atomix.primitive.partition.PartitionGroupMembershipEvent.Type
 
membership() - Method in class io.atomix.primitive.partition.PartitionGroupMembershipEvent
Returns the partition group membership.
MURMUR3 - Static variable in interface io.atomix.primitive.partition.Partitioner
Murmur 3 partitioner.
Murmur3Partitioner - Class in io.atomix.primitive.partition
Murmur 3 partitioner.
Murmur3Partitioner() - Constructor for class io.atomix.primitive.partition.Murmur3Partitioner
 

N

name() - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
name() - Method in interface io.atomix.primitive.DistributedPrimitive
Returns the name of this primitive.
name() - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns the partition group name.
name() - Method in class io.atomix.primitive.PrimitiveInfo
Returns the primitive name.
name() - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the primitive name.
name() - Method in interface io.atomix.primitive.proxy.ProxySession
Returns the primitive name.
name() - Method in interface io.atomix.primitive.session.SessionClient
Returns the primitive name.
name() - Method in class io.atomix.primitive.Synchronous
 
namespace() - Method in interface io.atomix.primitive.partition.PartitionGroup.Type
Returns the partition group namespace.
namespace() - Method in interface io.atomix.primitive.PrimitiveType
Returns the primitive type namespace.
NATURAL - io.atomix.primitive.Ordering
Indicates that items should be ordered in their natural order.
NavigableMapCompatibleBuilder<B extends NavigableMapCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.map
Map builder.
NavigableMapDelegate<K,​V> - Interface in io.atomix.primitive.protocol.map
Navigable map protocol.
NavigableMapProtocol - Interface in io.atomix.primitive.protocol.map
Navigable map protocol.
NavigableSetCompatibleBuilder<B extends NavigableSetCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.set
Set builder.
NavigableSetDelegate<E> - Interface in io.atomix.primitive.protocol.set
Navigable set protocol.
NavigableSetProtocol - Interface in io.atomix.primitive.protocol.set
Navigable set protocol.
newBuilder() - Method in interface io.atomix.primitive.serialization.SerializationService
Returns a new serializer builder.
newBuilder(String) - Method in interface io.atomix.primitive.serialization.SerializationService
Returns a new serializer builder.
newBuilder(String, C, PrimitiveManagementService) - Method in interface io.atomix.primitive.PrimitiveType
Returns a new primitive builder.
newClient(PartitionService) - Method in interface io.atomix.primitive.protocol.LogProtocol
Returns a new log client.
newConfig() - Method in interface io.atomix.primitive.PrimitiveType
Returns a new instance of the primitive configuration.
newCounterDelegate(String, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.counter.CounterProtocol
Returns a new counter delegate.
newMapDelegate(String, Serializer, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.map.MapProtocol
Returns a new map delegate.
newNavigableMapDelegate(String, Serializer, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.map.NavigableMapProtocol
Returns a new navigable map delegate.
newNavigableSetDelegate(String, Serializer, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.set.NavigableSetProtocol
Returns a new set delegate.
newPartitionGroup(C) - Method in interface io.atomix.primitive.partition.PartitionGroup.Type
Creates a new partition group instance.
newProtocol() - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns a new primitive protocol.
newProtocol(C) - Method in interface io.atomix.primitive.protocol.PrimitiveProtocol.Type
Creates a new protocol instance.
newProxy(String, PrimitiveType, Class<S>, ServiceConfig, PartitionService) - Method in interface io.atomix.primitive.protocol.ProxyProtocol
Returns a new primitive proxy for the given partition group.
newService(ServiceConfig) - Method in interface io.atomix.primitive.PrimitiveType
Creates a new service instance from the given configuration.
newSetDelegate(String, Serializer, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.set.SetProtocol
Returns a new set delegate.
newSortedMapDelegate(String, Serializer, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.map.SortedMapProtocol
Returns a new sorted map delegate.
newSortedSetDelegate(String, Serializer, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.set.SortedSetProtocol
Returns a new set delegate.
newValueDelegate(String, Serializer, PrimitiveManagementService) - Method in interface io.atomix.primitive.protocol.value.ValueProtocol
Returns a new value delegate.
nextSessionId() - Method in interface io.atomix.primitive.session.SessionIdService
Returns the next unique session identifier.
NODE_AWARE - io.atomix.primitive.partition.MemberGroupStrategy
Node aware member group strategy (the default).

O

onClose(Session) - Method in interface io.atomix.primitive.session.SessionListener
Called when a session was closed by the client.
onExpire(Session) - Method in interface io.atomix.primitive.session.SessionListener
Called when a session is expired by the system.
onOpen(Session) - Method in interface io.atomix.primitive.session.SessionListener
Called when a new session is registered.
OPEN - io.atomix.primitive.session.Session.State
 
operation() - Method in interface io.atomix.primitive.service.Commit
Returns the operation identifier.
operation(OperationId) - Static method in class io.atomix.primitive.operation.PrimitiveOperation
Creates a new primitive operation with a simplified identifier and a null value.
operation(OperationId, byte[]) - Static method in class io.atomix.primitive.operation.PrimitiveOperation
Creates a new primitive operation with a simplified identifier.
Operation - Annotation Type in io.atomix.primitive.operation
Operation annotation.
OperationId - Interface in io.atomix.primitive.operation
Raft operation identifier.
Operations - Class in io.atomix.primitive.operation
Operation utilities.
OperationType - Enum in io.atomix.primitive.operation
Raft operation type.
Ordering - Enum in io.atomix.primitive
Describes the order of a primitive data structure.

P

partition(String, List<PartitionId>) - Method in class io.atomix.primitive.partition.Murmur3Partitioner
 
partition(K, List<PartitionId>) - Method in interface io.atomix.primitive.partition.Partitioner
Returns the partition ID to which the specified object maps.
Partition - Interface in io.atomix.primitive.partition
Atomix partition.
PartitionClient - Interface in io.atomix.primitive.partition
Primitive client.
Partitioner<K> - Interface in io.atomix.primitive.partition
Interface for mapping from an object to partition ID.
PartitionGroup - Interface in io.atomix.primitive.partition
Primitive partition group.
PartitionGroup.Builder<C extends PartitionGroupConfig<C>> - Class in io.atomix.primitive.partition
Partition group builder.
PartitionGroup.Type<C extends PartitionGroupConfig<C>> - Interface in io.atomix.primitive.partition
Partition group type.
PartitionGroupConfig<C extends PartitionGroupConfig<C>> - Class in io.atomix.primitive.partition
Partition group configuration.
PartitionGroupConfig() - Constructor for class io.atomix.primitive.partition.PartitionGroupConfig
 
PartitionGroupFactory<C extends PartitionGroupConfig<C>,​P extends ManagedPartitionGroup> - Interface in io.atomix.primitive.partition
Partition group factory.
PartitionGroupMembership - Class in io.atomix.primitive.partition
Partition group membership information.
PartitionGroupMembership(String, PartitionGroupConfig, Set<MemberId>, boolean) - Constructor for class io.atomix.primitive.partition.PartitionGroupMembership
 
PartitionGroupMembershipEvent - Class in io.atomix.primitive.partition
Partition group membership event.
PartitionGroupMembershipEvent(PartitionGroupMembershipEvent.Type, PartitionGroupMembership) - Constructor for class io.atomix.primitive.partition.PartitionGroupMembershipEvent
 
PartitionGroupMembershipEvent(PartitionGroupMembershipEvent.Type, PartitionGroupMembership, long) - Constructor for class io.atomix.primitive.partition.PartitionGroupMembershipEvent
 
PartitionGroupMembershipEvent.Type - Enum in io.atomix.primitive.partition
Partition group membership event type.
PartitionGroupMembershipEventListener - Interface in io.atomix.primitive.partition
Partition group membership event listener.
PartitionGroupMembershipService - Interface in io.atomix.primitive.partition
Partition group membership service.
PartitionGroupTypeRegistry - Interface in io.atomix.primitive.partition
Partition group type registry.
partitionId() - Method in interface io.atomix.primitive.log.LogSession
Returns the session partition ID.
partitionId() - Method in class io.atomix.primitive.partition.PrimaryElectionEvent
Returns the partition ID.
partitionId() - Method in interface io.atomix.primitive.proxy.ProxySession
Returns the proxy partition ID.
partitionId() - Method in interface io.atomix.primitive.session.SessionClient
Returns the partition identifier.
PartitionId - Class in io.atomix.primitive.partition
PartitionMetadata identifier.
PartitionId(String, int) - Constructor for class io.atomix.primitive.partition.PartitionId
Creates a partition identifier from an integer.
PartitionManagementService - Interface in io.atomix.primitive.partition
Partition management service.
PartitionMetadata - Class in io.atomix.primitive.partition
A partition or shard is a group of controller nodes that are work together to maintain state.
PartitionMetadata(PartitionId, Collection<MemberId>) - Constructor for class io.atomix.primitive.partition.PartitionMetadata
 
PartitionService - Interface in io.atomix.primitive.partition
Partition service.
primary() - Method in interface io.atomix.primitive.partition.Partition
Returns the partition's current primary.
primary() - Method in class io.atomix.primitive.partition.PrimaryTerm
Returns the primary member.
PrimaryElection - Interface in io.atomix.primitive.partition
Partition primary election.
PrimaryElectionEvent - Class in io.atomix.primitive.partition
Primary election event.
PrimaryElectionEvent(PrimaryElectionEvent.Type, PartitionId, PrimaryTerm) - Constructor for class io.atomix.primitive.partition.PrimaryElectionEvent
 
PrimaryElectionEvent.Type - Enum in io.atomix.primitive.partition
Returns the election event type.
PrimaryElectionEventListener - Interface in io.atomix.primitive.partition
Primary election event listener.
PrimaryElectionService - Interface in io.atomix.primitive.partition
Partition primary election service.
PrimaryTerm - Class in io.atomix.primitive.partition
Partition primary term.
PrimaryTerm(long, GroupMember, List<GroupMember>) - Constructor for class io.atomix.primitive.partition.PrimaryTerm
 
primitiveBuilder(String, PrimitiveType<B, C, P>) - Method in interface io.atomix.primitive.PrimitiveFactory
Creates a new named primitive builder of the given primitiveType.
PrimitiveBuilder<B extends PrimitiveBuilder<B,​C,​P>,​C extends PrimitiveConfig,​P extends SyncPrimitive> - Class in io.atomix.primitive
Abstract builder for distributed primitives.
PrimitiveBuilder(PrimitiveType, String, C, PrimitiveManagementService) - Constructor for class io.atomix.primitive.PrimitiveBuilder
 
PrimitiveCache - Interface in io.atomix.primitive
Atomix primitive cache.
PrimitiveConfig<C extends PrimitiveConfig<C>> - Class in io.atomix.primitive.config
Primitive configuration.
PrimitiveConfig() - Constructor for class io.atomix.primitive.config.PrimitiveConfig
 
PrimitiveEvent - Class in io.atomix.primitive.event
Raft event.
PrimitiveEvent(EventType, byte[]) - Constructor for class io.atomix.primitive.event.PrimitiveEvent
 
PrimitiveException - Exception in io.atomix.primitive
Top level exception for Store failures.
PrimitiveException() - Constructor for exception io.atomix.primitive.PrimitiveException
 
PrimitiveException(String) - Constructor for exception io.atomix.primitive.PrimitiveException
 
PrimitiveException(Throwable) - Constructor for exception io.atomix.primitive.PrimitiveException
 
PrimitiveException.ClosedSession - Exception in io.atomix.primitive
Closed session exception.
PrimitiveException.CommandFailure - Exception in io.atomix.primitive
Command failure exception.
PrimitiveException.ConcurrentModification - Exception in io.atomix.primitive
Store update conflicts with an in flight transaction.
PrimitiveException.Interrupted - Exception in io.atomix.primitive
Store operation interrupted.
PrimitiveException.QueryFailure - Exception in io.atomix.primitive
Query failure exception.
PrimitiveException.ServiceException - Exception in io.atomix.primitive
Primitive service exception.
PrimitiveException.Timeout - Exception in io.atomix.primitive
Store operation timeout.
PrimitiveException.Unavailable - Exception in io.atomix.primitive
Store is temporarily unavailable.
PrimitiveException.UnknownClient - Exception in io.atomix.primitive
Unknown client exception.
PrimitiveException.UnknownService - Exception in io.atomix.primitive
Unknown service exception.
PrimitiveException.UnknownSession - Exception in io.atomix.primitive
Unknown session exception.
PrimitiveFactory - Interface in io.atomix.primitive
Manages the creation of distributed primitive instances.
PrimitiveId - Class in io.atomix.primitive
Snapshot identifier.
PrimitiveId(Long) - Constructor for class io.atomix.primitive.PrimitiveId
 
PrimitiveInfo - Class in io.atomix.primitive
Distributed primitive info.
PrimitiveInfo(String, PrimitiveType) - Constructor for class io.atomix.primitive.PrimitiveInfo
 
PrimitiveManagementService - Interface in io.atomix.primitive
Primitive management service.
primitiveName() - Method in interface io.atomix.primitive.session.Session
Returns the session's service name.
primitiveName() - Method in class io.atomix.primitive.session.SessionMetadata
Returns the session name.
PrimitiveOperation - Class in io.atomix.primitive.operation
Base type for Raft state operations.
PrimitiveOperation(OperationId, byte[]) - Constructor for class io.atomix.primitive.operation.PrimitiveOperation
 
PrimitiveProtocol - Interface in io.atomix.primitive.protocol
Primitive protocol.
PrimitiveProtocol.Type<C extends PrimitiveProtocolConfig<C>> - Interface in io.atomix.primitive.protocol
Distributed primitive protocol type.
PrimitiveProtocolBuilder<B extends PrimitiveProtocolBuilder<B,​C,​P>,​C extends PrimitiveProtocolConfig<C>,​P extends PrimitiveProtocol> - Class in io.atomix.primitive.protocol
Primitive protocol builder.
PrimitiveProtocolConfig<C extends PrimitiveProtocolConfig<C>> - Class in io.atomix.primitive.protocol
Primitive protocol configuration.
PrimitiveProtocolConfig() - Constructor for class io.atomix.primitive.protocol.PrimitiveProtocolConfig
 
PrimitiveProtocolTypeRegistry - Interface in io.atomix.primitive.protocol
Primitive protocol type registry.
PrimitiveRegistry - Interface in io.atomix.primitive
Primitive registry.
PrimitiveService - Interface in io.atomix.primitive.service
Base class for user-provided services.
PrimitiveState - Enum in io.atomix.primitive
State of distributed primitive.
primitiveType() - Method in interface io.atomix.primitive.session.Session
Returns the session's service type.
primitiveType() - Method in class io.atomix.primitive.session.SessionMetadata
Returns the session type.
PrimitiveType<B extends PrimitiveBuilder,​C extends PrimitiveConfig,​P extends SyncPrimitive> - Interface in io.atomix.primitive
Primitive type.
PrimitiveTypeRegistry - Interface in io.atomix.primitive
Primitive registry.
producer() - Method in interface io.atomix.primitive.log.LogSession
Returns the log producer.
protocol() - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
protocol() - Method in interface io.atomix.primitive.DistributedPrimitive
Returns the primitive protocol.
protocol() - Method in interface io.atomix.primitive.log.LogClient
Returns the client log protocol.
protocol() - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns the primitive protocol type supported by the partition group.
protocol() - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the client proxy protocol.
protocol() - Method in class io.atomix.primitive.Synchronous
 
ProxyClient<S> - Interface in io.atomix.primitive.proxy
Primitive proxy.
ProxyCompatibleBuilder<B extends ProxyCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol
State machine replication compatible primitive.
ProxyProtocol - Interface in io.atomix.primitive.protocol
State machine replication-based primitive protocol.
ProxySession<S> - Interface in io.atomix.primitive.proxy
Proxy session.
publish(EventType) - Method in interface io.atomix.primitive.session.Session
Publishes an empty event to the session.
publish(EventType, T) - Method in interface io.atomix.primitive.session.Session
Publishes an event to the session.
publish(PrimitiveEvent) - Method in interface io.atomix.primitive.session.Session
Publishes an event to the session.

Q

query(String) - Static method in interface io.atomix.primitive.operation.OperationId
Returns a new query operation identifier.
Query - Annotation Type in io.atomix.primitive.operation
Query annotation.
QUERY - io.atomix.primitive.operation.OperationType
Query operation.
QueryFailure() - Constructor for exception io.atomix.primitive.PrimitiveException.QueryFailure
 
QueryFailure(String) - Constructor for exception io.atomix.primitive.PrimitiveException.QueryFailure
 

R

RACK_AWARE - io.atomix.primitive.partition.MemberGroupStrategy
Rack aware member group strategy.
readObject() - Method in interface io.atomix.primitive.service.BackupInput
Deserializes an object from the input.
RECOVER - io.atomix.primitive.Recovery
Indicates that the session should be recovered when lost.
Recovery - Enum in io.atomix.primitive
Primitive session recovery strategy.
register(OperationId, Runnable) - Method in interface io.atomix.primitive.service.ServiceExecutor
Registers a operation callback.
register(OperationId, Consumer<Commit<T>>) - Method in interface io.atomix.primitive.service.ServiceExecutor
Registers a operation callback.
register(OperationId, Function<Commit<T>, R>) - Method in interface io.atomix.primitive.service.ServiceExecutor
Registers an operation callback.
register(OperationId, Supplier<R>) - Method in interface io.atomix.primitive.service.ServiceExecutor
Registers a no argument operation callback.
register(Session) - Method in class io.atomix.primitive.service.AbstractPrimitiveService
 
register(Session) - Method in interface io.atomix.primitive.service.PrimitiveService
Registers a primitive session.
register(Object) - Method in interface io.atomix.primitive.proxy.ProxyClient
Registers a client proxy.
register(Object) - Method in interface io.atomix.primitive.proxy.ProxySession
Registers a client listener.
REMOVE - io.atomix.primitive.protocol.map.MapDelegateEvent.Type
Entry removed from map.
REMOVE - io.atomix.primitive.protocol.set.SetDelegateEvent.Type
Element removed from the set.
removeEventListener(EventType, Consumer<PrimitiveEvent>) - Method in interface io.atomix.primitive.session.SessionClient
Removes an event listener.
removeListener(MapDelegateEventListener<K, V>) - Method in interface io.atomix.primitive.protocol.map.MapDelegate
Removes the specified listener from the map such that it will no longer receive change notifications.
removeListener(SetDelegateEventListener<E>) - Method in interface io.atomix.primitive.protocol.set.SetDelegate
Removes the specified listener from the set such that it will no longer receive change notifications.
removeListener(ValueDelegateEventListener<V>) - Method in interface io.atomix.primitive.protocol.value.ValueDelegate
Unregisters the specified listener such that it will no longer receive atomic value update notifications.
removeListener(SessionListener) - Method in interface io.atomix.primitive.session.Sessions
Removes a listener from the sessions.
removeStateChangeListener(Consumer<PrimitiveState>) - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
removeStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.DistributedPrimitive
Unregisters a previously registered listener to be called when the primitive's state changes.
removeStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.log.LogClient
Removes a state change listener.
removeStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.log.LogSession
Removes a state change listener.
removeStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.proxy.ProxyClient
Removes a state change listener.
removeStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.proxy.ProxySession
Removes a state change listener.
removeStateChangeListener(Consumer<PrimitiveState>) - Method in interface io.atomix.primitive.session.SessionClient
Removes a state change listener.
Replication - Enum in io.atomix.primitive
Replication strategy.
restore(BackupInput) - Method in interface io.atomix.primitive.service.PrimitiveService
Restores the service state from the given buffer.

S

SEQUENTIAL - io.atomix.primitive.Consistency
Sequential consistency model.
SerializationService - Interface in io.atomix.primitive.serialization
Primitive serialization service.
serializer() - Method in class io.atomix.primitive.service.AbstractPrimitiveService
 
serializer() - Method in interface io.atomix.primitive.service.PrimitiveService
Returns the primitive service serializer.
serviceConfig() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the service configuration.
ServiceConfig - Class in io.atomix.primitive.service
Service configuration class.
ServiceConfig() - Constructor for class io.atomix.primitive.service.ServiceConfig
 
ServiceContext - Interface in io.atomix.primitive.service
State machine context.
ServiceException() - Constructor for exception io.atomix.primitive.PrimitiveException.ServiceException
 
ServiceException(String) - Constructor for exception io.atomix.primitive.PrimitiveException.ServiceException
 
ServiceException(Throwable) - Constructor for exception io.atomix.primitive.PrimitiveException.ServiceException
 
ServiceExecutor - Interface in io.atomix.primitive.service
Facilitates registration and execution of state machine commands and provides deterministic scheduling.
serviceId() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the state machine identifier.
serviceName() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the state machine name.
serviceType() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the state machine type.
session() - Method in interface io.atomix.primitive.service.Commit
Returns the session that submitted the operation.
Session<C> - Interface in io.atomix.primitive.session
Provides an interface to communicating with a client via session events.
Session.State - Enum in io.atomix.primitive.session
Session state enums.
sessionBuilder(String, PrimitiveType, ServiceConfig) - Method in interface io.atomix.primitive.partition.PartitionClient
Returns a new session builder for the given primitive type.
SessionClient - Interface in io.atomix.primitive.session
Partition proxy.
SessionClient.Builder - Class in io.atomix.primitive.session
Partition proxy builder.
sessionId() - Method in interface io.atomix.primitive.log.LogSession
Returns the session identifier.
sessionId() - Method in interface io.atomix.primitive.session.Session
Returns the session identifier.
sessionId() - Method in interface io.atomix.primitive.session.SessionClient
Returns the proxy session identifier.
sessionId() - Method in class io.atomix.primitive.session.SessionMetadata
Returns the globally unique session identifier.
SessionId - Class in io.atomix.primitive.session
Session identifier.
SessionId(Long) - Constructor for class io.atomix.primitive.session.SessionId
 
SessionIdService - Interface in io.atomix.primitive.session
Globally unique session ID provider.
SessionListener - Interface in io.atomix.primitive.session
Support for listening for state changes in server sessions.
SessionMetadata - Class in io.atomix.primitive.session
Primitive session metadata.
SessionMetadata(long, String, String) - Constructor for class io.atomix.primitive.session.SessionMetadata
 
Sessions - Interface in io.atomix.primitive.session
Provides a set of active server sessions.
set(V) - Method in interface io.atomix.primitive.protocol.value.ValueDelegate
Sets to the given value.
SetCompatibleBuilder<B extends SetCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.set
Set builder.
SetDelegate<E> - Interface in io.atomix.primitive.protocol.set
Gossip-based set service.
SetDelegateEvent<E> - Class in io.atomix.primitive.protocol.set
Set protocol event.
SetDelegateEvent(SetDelegateEvent.Type, E) - Constructor for class io.atomix.primitive.protocol.set.SetDelegateEvent
 
SetDelegateEvent(SetDelegateEvent.Type, E, long) - Constructor for class io.atomix.primitive.protocol.set.SetDelegateEvent
 
SetDelegateEvent.Type - Enum in io.atomix.primitive.protocol.set
Set protocol event type.
SetDelegateEventListener<E> - Interface in io.atomix.primitive.protocol.set
Set protocol event listener.
setName(String) - Method in class io.atomix.primitive.config.PrimitiveConfig
 
setName(String) - Method in class io.atomix.primitive.partition.PartitionGroupConfig
 
setNamespaceConfig(NamespaceConfig) - Method in class io.atomix.primitive.config.PrimitiveConfig
Sets the serializer configuration.
setPartitions(int) - Method in class io.atomix.primitive.partition.PartitionGroupConfig
Sets the number of partitions in the group.
SetProtocol - Interface in io.atomix.primitive.protocol.set
Set protocol.
setProtocolConfig(PrimitiveProtocolConfig) - Method in class io.atomix.primitive.config.PrimitiveConfig
Sets the protocol configuration.
setReadOnly() - Method in class io.atomix.primitive.config.PrimitiveConfig
Sets the primitive to read-only.
setReadOnly(boolean) - Method in class io.atomix.primitive.config.PrimitiveConfig
Sets whether the primitive is read-only.
simplify(OperationId) - Static method in interface io.atomix.primitive.operation.OperationId
Simplifies the given operation identifier.
snapshot() - Method in interface io.atomix.primitive.partition.PartitionGroup
Takes snapshots of all partitions.
snapshot(PartitionId) - Method in interface io.atomix.primitive.partition.PartitionGroup
Takes a snapshot of the partition.
SortedMapCompatibleBuilder<B extends SortedMapCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.map
Map builder.
SortedMapDelegate<K,​V> - Interface in io.atomix.primitive.protocol.map
Sorted map protocol.
SortedMapProtocol - Interface in io.atomix.primitive.protocol.map
Sorted map protocol.
SortedSetCompatibleBuilder<B extends SortedSetCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.set
Set builder.
SortedSetDelegate<E> - Interface in io.atomix.primitive.protocol.set
Sorted set protocol.
SortedSetProtocol - Interface in io.atomix.primitive.protocol.set
Sorted set protocol.
state() - Method in interface io.atomix.primitive.log.LogClient
Returns the log client state.
SUSPENDED - io.atomix.primitive.PrimitiveState
Signifies a state wherein the primitive is temporarily incapable of providing the advertised consistency properties.
SUSPICIOUS - io.atomix.primitive.session.Session.State
 
sync() - Method in interface io.atomix.primitive.AsyncPrimitive
Returns a synchronous wrapper around the asynchronous primitive.
sync(Duration) - Method in interface io.atomix.primitive.AsyncPrimitive
Returns a synchronous wrapper around the asynchronous primitive.
Synchronous<T extends AsyncPrimitive> - Class in io.atomix.primitive
DistributedPrimitive that is a synchronous (blocking) version of another.
Synchronous(T) - Constructor for class io.atomix.primitive.Synchronous
 
SYNCHRONOUS - io.atomix.primitive.Replication
Synchronous replication strategy.
SyncPrimitive - Interface in io.atomix.primitive
Synchronous primitive.
system() - Method in class io.atomix.primitive.partition.PartitionGroupMembership
Returns whether this partition group is the system partition group.

T

term() - Method in interface io.atomix.primitive.partition.Partition
Returns the partition term.
term() - Method in class io.atomix.primitive.partition.PrimaryElectionEvent
Returns the election term.
term() - Method in class io.atomix.primitive.partition.PrimaryTerm
Returns the primary term number.
tick(WallClockTimestamp) - Method in class io.atomix.primitive.service.AbstractPrimitiveService
 
tick(WallClockTimestamp) - Method in interface io.atomix.primitive.service.PrimitiveService
Increments the Raft service time to the given timestamp.
tick(WallClockTimestamp) - Method in interface io.atomix.primitive.service.ServiceExecutor
Increments the service clock.
Timeout() - Constructor for exception io.atomix.primitive.PrimitiveException.Timeout
 
timestamp() - Method in class io.atomix.primitive.log.LogRecord
Returns the record timestamp.
toString() - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
toString() - Method in class io.atomix.primitive.event.PrimitiveEvent
 
toString() - Method in class io.atomix.primitive.log.LogRecord
 
toString() - Method in class io.atomix.primitive.operation.PrimitiveOperation
 
toString() - Method in class io.atomix.primitive.partition.GroupMember
 
toString() - Method in class io.atomix.primitive.partition.PartitionGroupMembership
 
toString() - Method in class io.atomix.primitive.partition.PartitionId
 
toString() - Method in class io.atomix.primitive.partition.PartitionMetadata
 
toString() - Method in class io.atomix.primitive.partition.PrimaryElectionEvent
 
toString() - Method in class io.atomix.primitive.partition.PrimaryTerm
 
toString() - Method in class io.atomix.primitive.PrimitiveInfo
 
toString() - Method in class io.atomix.primitive.session.SessionMetadata
 
type() - Method in class io.atomix.primitive.AbstractAsyncPrimitive
 
type() - Method in interface io.atomix.primitive.DistributedPrimitive
Returns the type of primitive.
type() - Method in class io.atomix.primitive.event.PrimitiveEvent
Returns the event type identifier.
type() - Method in annotation type io.atomix.primitive.operation.Operation
The operation type.
type() - Method in interface io.atomix.primitive.operation.OperationId
Returns the operation type.
type() - Method in interface io.atomix.primitive.partition.PartitionGroup
Returns the partition group type.
type() - Method in class io.atomix.primitive.PrimitiveInfo
Returns the primitive type.
type() - Method in interface io.atomix.primitive.protocol.PrimitiveProtocol
Returns the protocol type.
type() - Method in interface io.atomix.primitive.proxy.ProxyClient
Returns the client proxy type.
type() - Method in interface io.atomix.primitive.proxy.ProxySession
Returns the client proxy type.
type() - Method in interface io.atomix.primitive.session.SessionClient
Returns the client proxy type.
type() - Method in class io.atomix.primitive.Synchronous
 

U

Unavailable() - Constructor for exception io.atomix.primitive.PrimitiveException.Unavailable
 
Unavailable(String) - Constructor for exception io.atomix.primitive.PrimitiveException.Unavailable
 
UnknownClient() - Constructor for exception io.atomix.primitive.PrimitiveException.UnknownClient
 
UnknownClient(String) - Constructor for exception io.atomix.primitive.PrimitiveException.UnknownClient
 
UnknownService() - Constructor for exception io.atomix.primitive.PrimitiveException.UnknownService
 
UnknownService(String) - Constructor for exception io.atomix.primitive.PrimitiveException.UnknownService
 
UnknownSession() - Constructor for exception io.atomix.primitive.PrimitiveException.UnknownSession
 
UnknownSession(String) - Constructor for exception io.atomix.primitive.PrimitiveException.UnknownSession
 
UPDATE - io.atomix.primitive.protocol.map.MapDelegateEvent.Type
Existing entry updated.
UPDATE - io.atomix.primitive.protocol.value.ValueDelegateEvent.Type
Valuee updated event.

V

value() - Method in annotation type io.atomix.primitive.event.Event
The event type name.
value() - Method in class io.atomix.primitive.event.PrimitiveEvent
Returns the event value.
value() - Method in class io.atomix.primitive.log.LogRecord
Returns the record value.
value() - Method in annotation type io.atomix.primitive.operation.Command
The operation name.
value() - Method in annotation type io.atomix.primitive.operation.Operation
The operation name.
value() - Method in class io.atomix.primitive.operation.PrimitiveOperation
Returns the operation value.
value() - Method in annotation type io.atomix.primitive.operation.Query
The operation name.
value() - Method in class io.atomix.primitive.protocol.map.MapDelegateEvent
Returns the map entry value.
value() - Method in class io.atomix.primitive.protocol.value.ValueDelegateEvent
Returns the value.
value() - Method in interface io.atomix.primitive.service.Commit
Returns the operation submitted by the client.
ValueCompatibleBuilder<B extends ValueCompatibleBuilder<B>> - Interface in io.atomix.primitive.protocol.value
Value builder.
ValueDelegate<V> - Interface in io.atomix.primitive.protocol.value
Gossip-based value service.
ValueDelegateEvent<V> - Class in io.atomix.primitive.protocol.value
Value protocol event.
ValueDelegateEvent(ValueDelegateEvent.Type, V) - Constructor for class io.atomix.primitive.protocol.value.ValueDelegateEvent
 
ValueDelegateEvent(ValueDelegateEvent.Type, V, long) - Constructor for class io.atomix.primitive.protocol.value.ValueDelegateEvent
 
ValueDelegateEvent.Type - Enum in io.atomix.primitive.protocol.value
Value protocol event type.
ValueDelegateEventListener<E> - Interface in io.atomix.primitive.protocol.value
Value protocol event listener.
valueOf(String) - Static method in enum io.atomix.primitive.Consistency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.operation.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.Ordering
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.partition.MemberGroupEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.partition.MemberGroupStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.partition.PartitionGroupMembershipEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.partition.PrimaryElectionEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.PrimitiveState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.protocol.map.MapDelegateEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.protocol.set.SetDelegateEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.protocol.value.ValueDelegateEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.Recovery
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.Replication
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.atomix.primitive.session.Session.State
Returns the enum constant of this type with the specified name.
ValueProtocol - Interface in io.atomix.primitive.protocol.value
Value protocol.
values() - Static method in enum io.atomix.primitive.Consistency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.operation.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.Ordering
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.partition.MemberGroupEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.partition.MemberGroupStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.partition.PartitionGroupMembershipEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.partition.PrimaryElectionEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.PrimitiveState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.protocol.map.MapDelegateEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.protocol.set.SetDelegateEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.protocol.value.ValueDelegateEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.Recovery
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.Replication
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.atomix.primitive.session.Session.State
Returns an array containing the constants of this enum type, in the order they are declared.

W

wallClock() - Method in interface io.atomix.primitive.service.ServiceContext
Returns the state machine's wall clock.
wallClockTime() - Method in interface io.atomix.primitive.service.Commit
Returns the time at which the operation was committed.
withProtocol(CounterProtocol) - Method in interface io.atomix.primitive.protocol.counter.CounterCompatibleBuilder
Configures the builder with a counter compatible gossip protocol.
withProtocol(LogProtocol) - Method in interface io.atomix.primitive.protocol.LogCompatibleBuilder
Configures the builder with a log replication protocol.
withProtocol(MapProtocol) - Method in interface io.atomix.primitive.protocol.map.MapCompatibleBuilder
Configures the builder with a map compatible gossip protocol.
withProtocol(NavigableMapProtocol) - Method in interface io.atomix.primitive.protocol.map.NavigableMapCompatibleBuilder
Configures the builder with a map compatible gossip protocol.
withProtocol(SortedMapProtocol) - Method in interface io.atomix.primitive.protocol.map.SortedMapCompatibleBuilder
Configures the builder with a map compatible gossip protocol.
withProtocol(ProxyProtocol) - Method in interface io.atomix.primitive.protocol.ProxyCompatibleBuilder
Configures the builder with a state machine replication protocol.
withProtocol(NavigableSetProtocol) - Method in interface io.atomix.primitive.protocol.set.NavigableSetCompatibleBuilder
Configures the builder with a set compatible gossip protocol.
withProtocol(SetProtocol) - Method in interface io.atomix.primitive.protocol.set.SetCompatibleBuilder
Configures the builder with a set compatible gossip protocol.
withProtocol(SortedSetProtocol) - Method in interface io.atomix.primitive.protocol.set.SortedSetCompatibleBuilder
Configures the builder with a set compatible gossip protocol.
withProtocol(ValueProtocol) - Method in interface io.atomix.primitive.protocol.value.ValueCompatibleBuilder
Configures the builder with a value compatible gossip protocol.
withReadOnly() - Method in class io.atomix.primitive.PrimitiveBuilder
Sets the primitive to read-only.
withReadOnly(boolean) - Method in class io.atomix.primitive.PrimitiveBuilder
Sets whether the primitive is read-only.
withSerializer(Serializer) - Method in class io.atomix.primitive.PrimitiveBuilder
Sets the primitive serializer.
writeObject(U) - Method in interface io.atomix.primitive.service.BackupOutput
Serializes an object to the output.

Z

ZONE_AWARE - io.atomix.primitive.partition.MemberGroupStrategy
Zone aware member group strategy.
A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes All Packages