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

A

accept(AcceptorInstance, Object) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorContext
 
accept(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstance
 
accept(AcceptorInstance, Object) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstanceStore
 
accept(AcceptorInstance, Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
accepted(ProposerMessage.AcceptedState) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
AcceptorContext - Interface in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Context used by AcceptorState
AcceptorInstance - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Acceptor state for a Paxos instance
AcceptorInstance() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstance
 
acceptorInstanceStore - Variable in class org.neo4j.cluster.client.ClusterClientModule
 
AcceptorInstanceStore - Interface in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Store for Acceptor Paxos instances
AcceptorMessage - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Acceptor state machine messages
AcceptorMessage.AcceptState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
AcceptorMessage.AcceptState(long, Object) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.AcceptState
 
AcceptorMessage.PrepareState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
AcceptorMessage.PrepareState(long) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.PrepareState
 
AcceptorState - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
State machine for Paxos Acceptor
acquiredConfiguration(Map<InstanceId, URI>, Map<String, InstanceId>) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
addAtomicBroadcastListener(AtomicBroadcastListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
addAtomicBroadcastListener(AtomicBroadcastListener) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcast
 
addAtomicBroadcastListener(AtomicBroadcastListener) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastContext
 
addBindingListener(BindingListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
addBindingListener(BindingListener) - Method in interface org.neo4j.cluster.com.BindingNotifier
 
addBindingListener(BindingListener) - Method in class org.neo4j.cluster.ProtocolServer
 
addClusterListener(ClusterListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
addClusterListener(ClusterListener) - Method in interface org.neo4j.cluster.ClusterMonitor
 
addClusterListener(ClusterListener) - Method in interface org.neo4j.cluster.protocol.cluster.Cluster
 
addClusterListener(ClusterListener) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
addClusterMemberListener(ClusterMemberListener) - Method in interface org.neo4j.cluster.member.ClusterMemberEvents
 
addClusterMemberListener(ClusterMemberListener) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents
 
addHeartbeatListener(HeartbeatListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
addHeartbeatListener(HeartbeatListener) - Method in interface org.neo4j.cluster.protocol.heartbeat.Heartbeat
 
addHeartbeatListener(HeartbeatListener) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
addMappingFor(String, long) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.VersionMapper
 
addMessageProcessor(MessageProcessor) - Method in interface org.neo4j.cluster.com.message.MessageSource
 
addMessageProcessor(MessageProcessor) - Method in class org.neo4j.cluster.com.NetworkReceiver
 
addMessageProcessor(MessageProcessor) - Method in class org.neo4j.cluster.StateMachines
 
addMessageProcessor(MessageProcessor) - Method in class org.neo4j.cluster.timeout.Timeouts
 
addNetworkChannelsListener(NetworkReceiver.NetworkChannelsListener) - Method in class org.neo4j.cluster.com.NetworkReceiver
 
addNetworkChannelsListener(NetworkSender.NetworkChannelsListener) - Method in class org.neo4j.cluster.com.NetworkSender
 
addStateMachine(StateMachine) - Method in class org.neo4j.cluster.StateMachines
 
addStateTransitionListener(StateTransitionListener) - Method in class org.neo4j.cluster.ProtocolServer
 
addStateTransitionListener(StateTransitionListener) - Method in class org.neo4j.cluster.statemachine.StateMachine
 
addStateTransitionListener(StateTransitionListener) - Method in class org.neo4j.cluster.StateMachines
 
alive(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
alive(InstanceId) - Method in class org.neo4j.cluster.protocol.election.HeartbeatReelectionListener
 
alive(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
alive(InstanceId) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatListener.Adapter
 
alive(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatListener
 
allow_init_cluster - Static variable in class org.neo4j.cluster.ClusterSettings
 
apply(Iterable<MemberIsAvailable>, MemberIsAvailable) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.UniqueRoleFilter
 
apply(ClusterContext) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
apply(ClusterContext) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.VersionedConfigurationStateChange
 
AtomicBroadcast - Interface in org.neo4j.cluster.protocol.atomicbroadcast
Atomic broadcast API.
AtomicBroadcastContext - Interface in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Context for AtomicBroadcast statemachine.
AtomicBroadcastListener - Interface in org.neo4j.cluster.protocol.atomicbroadcast
Atomic broadcast listener.
AtomicBroadcastMessage - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Messages for the AtomicBroadcast client API.
AtomicBroadcastSerializer - Class in org.neo4j.cluster.protocol.atomicbroadcast
Serializes and deserializes value to/from Payloads.
AtomicBroadcastSerializer() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcastSerializer
 
AtomicBroadcastSerializer(ObjectInputStreamFactory, ObjectOutputStreamFactory) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcastSerializer
 
AtomicBroadcastState - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
State Machine for implementation of Atomic Broadcast client interface
availableMember(MemberIsAvailable) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.ClusterMembersSnapshot
 
awaitTermination(long, TimeUnit) - Method in class org.neo4j.cluster.DelayedDirectExecutor
 

B

beganProcessing(Message) - Method in interface org.neo4j.cluster.StateMachines.Monitor
 
BiasedWinnerStrategy - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
If a server is promoted or demoted, then use this WinnerStrategy during election so that that decision is adhered to, if possible.
BindingListener - Interface in org.neo4j.cluster
Listener for binding to a server address.
BindingNotifier - Interface in org.neo4j.cluster.com
Instances of this interface notify listeners when the cluster client has been bound to a particular network interface and port.
bookInstance(InstanceId, Message) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
boundAt() - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
boundAt() - Method in class org.neo4j.cluster.ProtocolServer
 
broadcast(Payload) - Method in class org.neo4j.cluster.client.ClusterClient
 
broadcast(Payload) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcast
 
broadcast(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcastSerializer
 
broadcast_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 

C

canBookInstance() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
cancelAllTimeouts() - Method in class org.neo4j.cluster.timeout.Timeouts
Cancel all current timeouts.
cancelTimeout(Object) - Method in interface org.neo4j.cluster.protocol.TimeoutsContext
 
cancelTimeout(Object) - Method in class org.neo4j.cluster.timeout.Timeouts
Cancel a timeout corresponding to a particular key.
channelClosed(URI) - Method in interface org.neo4j.cluster.com.NetworkReceiver.NetworkChannelsListener
 
channelClosed(URI) - Method in interface org.neo4j.cluster.com.NetworkSender.NetworkChannelsListener
 
channelOpened(URI) - Method in interface org.neo4j.cluster.com.NetworkReceiver.NetworkChannelsListener
 
channelOpened(URI) - Method in interface org.neo4j.cluster.com.NetworkSender.NetworkChannelsListener
 
ChannelOpenFailedException - Exception in org.neo4j.cluster.com
This is thrown when NetworkSender is unable to open a channel to another instance in the cluster.
ChannelOpenFailedException() - Constructor for exception org.neo4j.cluster.com.ChannelOpenFailedException
 
ChannelOpenFailedException(String) - Constructor for exception org.neo4j.cluster.com.ChannelOpenFailedException
 
ChannelOpenFailedException(String, Throwable) - Constructor for exception org.neo4j.cluster.com.ChannelOpenFailedException
 
ChannelOpenFailedException(Throwable) - Constructor for exception org.neo4j.cluster.com.ChannelOpenFailedException
 
checkTimeout(long) - Method in class org.neo4j.cluster.timeout.Timeouts.Timeout
 
clear() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstanceStore
 
clear() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
closed(Object, String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
Cluster - Interface in org.neo4j.cluster.protocol.cluster
Cluster membership management.
cluster_name - Static variable in class org.neo4j.cluster.ClusterSettings
 
CLUSTER_SCHEME - Static variable in class org.neo4j.cluster.com.NetworkReceiver
 
cluster_server - Static variable in class org.neo4j.cluster.ClusterSettings
 
ClusterClient - Class in org.neo4j.cluster.client
These are used as clients for a Neo4j cluster.
ClusterClient(LifeSupport, ProtocolServer) - Constructor for class org.neo4j.cluster.client.ClusterClient
 
clusterClient - Variable in class org.neo4j.cluster.client.ClusterClientModule
 
ClusterClientModule - Class in org.neo4j.cluster.client
This is a builder for ClusterClient instances.
ClusterClientModule(LifeSupport, Dependencies, Monitors, Config, LogService, ElectionCredentialsProvider) - Constructor for class org.neo4j.cluster.client.ClusterClientModule
 
ClusterConfiguration - Class in org.neo4j.cluster.protocol.cluster
Cluster configuration.
ClusterConfiguration(String, LogProvider, String...) - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
ClusterConfiguration(String, LogProvider, Collection<URI>) - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
ClusterConfiguration(ClusterConfiguration) - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
ClusterContext - Interface in org.neo4j.cluster.protocol.cluster
Represents the context necessary for cluster operations.
ClusterEntryDeniedException - Exception in org.neo4j.cluster.protocol.cluster
 
ClusterEntryDeniedException(InstanceId, ClusterMessage.ConfigurationResponseState) - Constructor for exception org.neo4j.cluster.protocol.cluster.ClusterEntryDeniedException
 
ClusterJoin - Class in org.neo4j.cluster.client
This service starts quite late, and is available for the instance to join as a member in the cluster.
ClusterJoin(ClusterJoin.Configuration, ProtocolServer, LogService) - Constructor for class org.neo4j.cluster.client.ClusterJoin
 
ClusterJoin.Configuration - Interface in org.neo4j.cluster.client
 
clusterJoinTimeout - Static variable in class org.neo4j.cluster.client.ClusterClientModule
 
ClusterLeaveReelectionListener - Class in org.neo4j.cluster.protocol.election
When an instance leaves a cluster, demote it from all its current roles.
ClusterLeaveReelectionListener(Election, LogProvider) - Constructor for class org.neo4j.cluster.protocol.election.ClusterLeaveReelectionListener
 
ClusterListener - Interface in org.neo4j.cluster.protocol.cluster
Listener interface for cluster configuration changes.
ClusterListener.Adapter - Class in org.neo4j.cluster.protocol.cluster
 
ClusterListener.Adapter() - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterListener.Adapter
 
ClusterMemberAvailability - Interface in org.neo4j.cluster.member
This can be used to signal that a cluster member can now actively participate with a given role, accompanied by a URI for accessing that role.
ClusterMemberEvents - Interface in org.neo4j.cluster.member
Register listeners here to get callbacks when important cluster events happen, such as elections, availability/unavailability of a member as a particular role, and member failure/recovery.
ClusterMemberListener - Interface in org.neo4j.cluster.member
A ClusterMemberListener is listening for events from elections and availability state.
ClusterMemberListener.Adapter - Class in org.neo4j.cluster.member
 
ClusterMemberListener.Adapter() - Constructor for class org.neo4j.cluster.member.ClusterMemberListener.Adapter
 
ClusterMessage - Enum in org.neo4j.cluster.protocol.cluster
Messages to implement the Cluster API state machine
ClusterMessage.ConfigurationChangeState - Class in org.neo4j.cluster.protocol.cluster
 
ClusterMessage.ConfigurationChangeState() - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
ClusterMessage.ConfigurationRequestState - Class in org.neo4j.cluster.protocol.cluster
 
ClusterMessage.ConfigurationRequestState(InstanceId, URI) - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationRequestState
 
ClusterMessage.ConfigurationResponseState - Class in org.neo4j.cluster.protocol.cluster
 
ClusterMessage.ConfigurationResponseState(Map<String, InstanceId>, Map<InstanceId, URI>, InstanceId, String) - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
ClusterMessage.ConfigurationTimeoutState - Class in org.neo4j.cluster.protocol.cluster
 
ClusterMessage.ConfigurationTimeoutState(int) - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationTimeoutState
 
ClusterMessage.VersionedConfigurationStateChange - Class in org.neo4j.cluster.protocol.cluster
 
ClusterMessage.VersionedConfigurationStateChange() - Constructor for class org.neo4j.cluster.protocol.cluster.ClusterMessage.VersionedConfigurationStateChange
 
ClusterMonitor - Interface in org.neo4j.cluster
Bundles up different ways of listening in on events going on in a cluster.
Clusters - Class in org.neo4j.cluster.client
Represents a clusters tag in the discovery XML file.
Clusters() - Constructor for class org.neo4j.cluster.client.Clusters
 
Clusters.Cluster - Class in org.neo4j.cluster.client
Represents the cluster tag in the discovery XML file.
Clusters.Cluster(String) - Constructor for class org.neo4j.cluster.client.Clusters.Cluster
 
Clusters.Member - Class in org.neo4j.cluster.client
Represents a member tag in the discovery XML file.
Clusters.Member(int, boolean) - Constructor for class org.neo4j.cluster.client.Clusters.Member
 
Clusters.Member(String) - Constructor for class org.neo4j.cluster.client.Clusters.Member
 
Clusters.Member(String, boolean) - Constructor for class org.neo4j.cluster.client.Clusters.Member
 
clusterServer() - Method in interface org.neo4j.cluster.com.NetworkReceiver.Configuration
 
ClusterSettings - Class in org.neo4j.cluster
Settings for cluster members
ClusterSettings() - Constructor for class org.neo4j.cluster.ClusterSettings
 
ClusterState - Enum in org.neo4j.cluster.protocol.cluster
State machine for the Cluster API
ClustersXMLSerializer - Class in org.neo4j.cluster.client
Serialize to and from the cluster discovery XML format.
ClustersXMLSerializer(DocumentBuilder) - Constructor for class org.neo4j.cluster.client.ClustersXMLSerializer
 
compareTo(InstanceId) - Method in class org.neo4j.cluster.InstanceId
 
compareTo(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
compareTo(Vote) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.Vote
 
compareTo(ClusterMessage.ConfigurationRequestState) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationRequestState
 
compareTo(Object) - Method in class org.neo4j.cluster.protocol.election.NotElectableElectionCredentials
 
compareTo(Object) - Method in class org.neo4j.cluster.protocol.election.ServerIdElectionCredentials
 
configuration_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
ConfigurationContext - Interface in org.neo4j.cluster.protocol
 
constructSupportingInfrastructureFor(InstanceId, MessageSource, MessageSender, DelayedDirectExecutor, Timeouts, Executor, MultiPaxosContext, StateMachine[]) - Method in class org.neo4j.cluster.MultiPaxosServerFactory
Sets up the supporting infrastructure and communication hooks for our state machines.
contains(URI) - Method in class org.neo4j.cluster.client.Clusters.Cluster
 
CONVERSATION_ID - Static variable in class org.neo4j.cluster.com.message.Message
 
COORDINATOR - Static variable in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
coordinatorIsElected(InstanceId) - Method in class org.neo4j.cluster.member.ClusterMemberListener.Adapter
 
coordinatorIsElected(InstanceId) - Method in interface org.neo4j.cluster.member.ClusterMemberListener
Called when new coordinator has been elected.
copyHeadersTo(Message<MESSAGETYPE>, String...) - Method in class org.neo4j.cluster.com.message.Message
 
create(String) - Method in class org.neo4j.cluster.client.ClusterClient
 
create(ByteArrayInputStream) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.ObjectInputStreamFactory
 
create(ByteArrayOutputStream) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.ObjectOutputStreamFactory
 
create(ByteArrayOutputStream) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.ObjectStreamFactory
 
create(ByteArrayInputStream) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.ObjectStreamFactory
 
create(String) - Method in interface org.neo4j.cluster.protocol.cluster.Cluster
 
created() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
created(String) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
created() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
CREATED_BY - Static variable in class org.neo4j.cluster.com.message.Message
 

D

default_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
defaultPort() - Method in interface org.neo4j.cluster.com.NetworkReceiver.Configuration
 
defaultPort() - Method in interface org.neo4j.cluster.com.NetworkSender.Configuration
 
DelayedDirectExecutor - Class in org.neo4j.cluster
Executor that executes the Runnables when drain() is called.
DelayedDirectExecutor(LogProvider) - Constructor for class org.neo4j.cluster.DelayedDirectExecutor
 
delivered() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
delivered(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
demote(InstanceId) - Method in class org.neo4j.cluster.client.ClusterClient
 
demote(InstanceId) - Method in interface org.neo4j.cluster.protocol.election.Election
 
demotion(ClusterContext, InstanceId) - Static method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.BiasedWinnerStrategy
 
discoveredLastReceivedInstanceId(long) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
drain() - Method in class org.neo4j.cluster.DelayedDirectExecutor
 
dumpDiagnostics(StringBuilder) - Method in class org.neo4j.cluster.client.ClusterClient
 

E

elected(String, InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
elected(String, InstanceId) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
Deprecated.
elected(String, InstanceId, InstanceId, long) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
elected(String, InstanceId, URI) - Method in class org.neo4j.cluster.protocol.cluster.ClusterListener.Adapter
 
elected(String, InstanceId, URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterListener
When a member (including potentially myself) has been elected to a particular role, this callback is invoked.
elected(String, InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
Election - Interface in org.neo4j.cluster.protocol.election
Election API.
election_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
ElectionContext - Interface in org.neo4j.cluster.protocol.election
Context used by ElectionState.
ElectionContext.VoteRequest - Class in org.neo4j.cluster.protocol.election
 
ElectionContext.VoteRequest(String, long) - Constructor for class org.neo4j.cluster.protocol.election.ElectionContext.VoteRequest
 
ElectionContextImpl - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context
 
ElectionCredentials - Interface in org.neo4j.cluster.protocol.election
 
ElectionCredentialsProvider - Interface in org.neo4j.cluster.protocol.election
Implementations of this provide the credential for the local node to be used in elections.
ElectionMessage - Enum in org.neo4j.cluster.protocol.election
Messages used to implement the ElectionState
ElectionMessage.VersionedVotedData - Class in org.neo4j.cluster.protocol.election
 
ElectionMessage.VersionedVotedData(String, InstanceId, Comparable<Object>, long) - Constructor for class org.neo4j.cluster.protocol.election.ElectionMessage.VersionedVotedData
 
ElectionMessage.VotedData - Class in org.neo4j.cluster.protocol.election
 
ElectionMessage.VotedData(String, InstanceId, Comparable<Object>) - Constructor for class org.neo4j.cluster.protocol.election.ElectionMessage.VotedData
 
electionOk() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
electionOk() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
ElectionRole - Class in org.neo4j.cluster.protocol.election
Role that an instance can have in a cluster.
ElectionRole(String) - Constructor for class org.neo4j.cluster.protocol.election.ElectionRole
 
ElectionState - Enum in org.neo4j.cluster.protocol.election
State machine that implements the Election API.
ElectionState.ElectionTimeoutData - Class in org.neo4j.cluster.protocol.election
 
ElectionState.ElectionTimeoutData(String, Message) - Constructor for class org.neo4j.cluster.protocol.election.ElectionState.ElectionTimeoutData
 
enteredCluster(ClusterConfiguration) - Method in class org.neo4j.cluster.protocol.cluster.ClusterListener.Adapter
 
enteredCluster(ClusterConfiguration) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterListener
When I enter the cluster as a member, this callback notifies me that this has been agreed upon by the entire cluster.
equals(Object) - Method in class org.neo4j.cluster.client.Clusters.Cluster
 
equals(Object) - Method in class org.neo4j.cluster.client.Clusters
 
equals(Object) - Method in class org.neo4j.cluster.client.Clusters.Member
 
equals(Object) - Method in class org.neo4j.cluster.com.message.Message
 
equals(Object) - Method in class org.neo4j.cluster.InstanceId
 
equals(Object) - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.AcceptState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.PrepareState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnFailedState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnRequestState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.AcceptedState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.PromiseState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectAcceptState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectPrepare
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.Vote
 
equals(Object) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.Payload
 
equals(Object) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
equals(Object) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationRequestState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationTimeoutState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.election.ElectionRole
 
equals(Object) - Method in class org.neo4j.cluster.protocol.election.NotElectableElectionCredentials
 
equals(Object) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.IAmAliveState
 
equals(Object) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.SuspicionsState
 
equals(Object) - Method in class org.neo4j.cluster.statemachine.StateTransition
 
execute(Runnable) - Method in class org.neo4j.cluster.DelayedDirectExecutor
 
execute(Runnable) - Method in class org.neo4j.cluster.ExecutorLifecycleAdapter
 
ExecutorLifecycleAdapter - Class in org.neo4j.cluster
 
ExecutorLifecycleAdapter(Factory<ExecutorService>) - Constructor for class org.neo4j.cluster.ExecutorLifecycleAdapter
 

F

failed(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
failed(InstanceId) - Method in class org.neo4j.cluster.protocol.election.HeartbeatReelectionListener
 
failed(InstanceId) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatListener.Adapter
 
failed(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatListener
 
finishedProcessing(Message) - Method in interface org.neo4j.cluster.StateMachines.Monitor
 
FixedTimeoutStrategy - Class in org.neo4j.cluster.timeout
A TimeoutStrategy that sets timeouts to a given fixed value.
FixedTimeoutStrategy(long) - Constructor for class org.neo4j.cluster.timeout.FixedTimeoutStrategy
 
forgetElection(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
forgetElection(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
FROM - Static variable in class org.neo4j.cluster.com.message.Message
 

G

getAcceptorContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
getAcceptorInstance(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorContext
 
getAcceptorInstance(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstanceStore
 
getAcceptorInstance(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
getAcceptors() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
getAcceptors() - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
getAlive() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getAlive() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
getAlive() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getAlive() - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
getAllowedFailures() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getAtomicBroadcastContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
getBallot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstance
 
getBallot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.AcceptState
 
getBallot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.PrepareState
 
getBallot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
getBallot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.PromiseState
 
getBallot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectPrepare
 
getBookedInstance(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
getBuf() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.Payload
 
getByUri(URI) - Method in class org.neo4j.cluster.client.Clusters.Cluster
 
getChannel(URI) - Method in class org.neo4j.cluster.com.NetworkSender
 
getCluster(String) - Method in class org.neo4j.cluster.client.Clusters
 
getClusterContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getClusterContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
getClusterContext() - Method in class org.neo4j.cluster.protocol.snapshot.SnapshotContext
 
getClusterJoinTimeout() - Method in interface org.neo4j.cluster.client.ClusterJoin.Configuration
 
getClusterName() - Method in interface org.neo4j.cluster.client.ClusterJoin.Configuration
 
getClusterName() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
getClusters() - Method in class org.neo4j.cluster.client.Clusters
 
getClusterServer() - Method in class org.neo4j.cluster.client.ClusterClient
 
getClusterUri() - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
getClusterUri() - Method in class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
getConfiguration() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getConfigurationResponseState() - Method in exception org.neo4j.cluster.protocol.cluster.ClusterEntryDeniedException
 
getContext() - Method in class org.neo4j.cluster.statemachine.StateMachine
 
getCoordinator() - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
getCredentials() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.Vote
 
getCredentials(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionCredentialsProvider
 
getCredentials(String) - Method in class org.neo4j.cluster.protocol.election.NotElectableElectionCredentialsProvider
 
getCredentials(String) - Method in class org.neo4j.cluster.protocol.election.ServerIdElectionCredentialsProvider
 
getCredentialsForRole(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getCredentialsForRole(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getCurrentAvailable(InstanceId) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.ClusterMembersSnapshot
 
getCurrentAvailableMembers() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.ClusterMembersSnapshot
 
getDiscoveredInstances() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getElected(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getElected(String) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getElected(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getElectionContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
getElectionWinner(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getElectionWinner(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getElector() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.VersionedConfigurationStateChange
 
getFailed() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getFailed() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getFailed() - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
getHeader(String) - Method in class org.neo4j.cluster.com.message.Message
 
getHeartbeatContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getHeartbeatContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
getHost() - Method in class org.neo4j.cluster.client.Clusters.Member
 
getId() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
getIdForUri(URI) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getIdForUri(URI) - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
getInitialHosts() - Method in interface org.neo4j.cluster.client.ClusterJoin.Configuration
 
getInstanceId() - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
getInstanceId() - Method in class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
getInstanceId() - Method in class org.neo4j.cluster.protocol.election.ElectionMessage.VotedData
 
getJoin() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
getJoinDeniedConfigurationResponseState() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getJoiningId() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationRequestState
 
getJoiningInstances() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getJoiningUri() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationRequestState
 
getJoinUri() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
getLastDeliveredInstanceId() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
getLastDeliveredInstanceId() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getLastDeliveredInstanceId() - Method in class org.neo4j.cluster.protocol.snapshot.SnapshotMessage.SnapshotState
 
getLastElector() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getLastElectorVersion() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getLastKnownAliveUpToDateInstance() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
getLastKnownLearnedInstanceInCluster() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
getLastKnownLearnedInstanceInCluster() - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
getLastLearnedInstanceId() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
getLastLearnedInstanceId() - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
getLatestReceivedInstanceId() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
getLearnerContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
getLearnerContext() - Method in class org.neo4j.cluster.protocol.snapshot.SnapshotContext
 
getLeave() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
getLen() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.Payload
 
getMemberIds() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getMembers() - Method in class org.neo4j.cluster.client.Clusters.Cluster
 
getMembers() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getMembers() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
getMembers() - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
getMemberURIs() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getMemberURIs() - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
getMessage() - Method in class org.neo4j.cluster.protocol.election.ElectionState.ElectionTimeoutData
 
getMessage() - Method in class org.neo4j.cluster.statemachine.StateTransition
 
getMessageType() - Method in class org.neo4j.cluster.com.message.Message
 
getMessageType() - Method in class org.neo4j.cluster.statemachine.StateMachine
 
getMinimumQuorumSize(List<URI>) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
getMyId() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getMyId() - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
getName() - Method in class org.neo4j.cluster.client.Clusters.Cluster
 
getName() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getName() - Method in class org.neo4j.cluster.protocol.election.ElectionRole
 
getNeededVoteCount() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getNeededVoteCount() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getNewState() - Method in class org.neo4j.cluster.statemachine.StateTransition
 
getNextConversationId() - Method in class org.neo4j.cluster.statemachine.StateMachineConversations
 
getObjectInputStreamFactory() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getObjectOutputStreamFactory() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getOldState() - Method in class org.neo4j.cluster.statemachine.StateTransition
 
getOtherInstances() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
getOtherInstances() - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
getOutgoing() - Method in class org.neo4j.cluster.StateMachines
 
getPaxosInstance(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
getPaxosInstance(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
getPaxosInstance(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
getPayload() - Method in class org.neo4j.cluster.com.message.Message
 
getPossibleRoles() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getPossibleRoles() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getProposerContext() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
getRemainingPings() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationTimeoutState
 
getRole() - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
getRole() - Method in class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
getRole() - Method in class org.neo4j.cluster.protocol.election.ElectionContext.VoteRequest
 
getRole() - Method in class org.neo4j.cluster.protocol.election.ElectionMessage.VotedData
 
getRole() - Method in class org.neo4j.cluster.protocol.election.ElectionState.ElectionTimeoutData
 
getRoles(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getRoles() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getRoles() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
getRoles(InstanceId) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getRolesOf(InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getRolesRequiringElection() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getRolesRequiringElection() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getRoleUri() - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
getServer() - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.IAmAliveState
 
getServerId() - Method in class org.neo4j.cluster.client.ClusterClient
 
getServerId() - Method in class org.neo4j.cluster.ProtocolServer
Ok to have this accessible like this?
getSnapshotProvider() - Method in class org.neo4j.cluster.protocol.snapshot.SnapshotContext
 
getState(ObjectOutputStream) - Method in interface org.neo4j.cluster.protocol.snapshot.SnapshotProvider
 
getState() - Method in class org.neo4j.cluster.statemachine.StateMachine
 
getStateMachine(Class<? extends MessageType>) - Method in class org.neo4j.cluster.StateMachines
 
getStateMachineProxyFactory() - Method in class org.neo4j.cluster.statemachine.StateMachineProxyHandler
 
getStateMachines() - Method in class org.neo4j.cluster.ProtocolServer
 
getStateMachines() - Method in class org.neo4j.cluster.StateMachines
 
getStoreId() - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
getSuggestedNode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.Vote
 
getSuspicions() - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.SuspicionsState
 
getSuspicionsFor(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
getSuspicionsOf(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
getTimeoutMessage(String) - Method in class org.neo4j.cluster.timeout.Timeouts
 
getTimeoutMessage() - Method in class org.neo4j.cluster.timeout.Timeouts.Timeout
 
getTimeouts() - Method in class org.neo4j.cluster.ProtocolServer
 
getTimeouts() - Method in class org.neo4j.cluster.StateMachines
 
getTimeouts() - Method in class org.neo4j.cluster.timeout.Timeouts
 
getTimestamp() - Method in class org.neo4j.cluster.client.Clusters
 
getUriForId(InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
getUriForId(InstanceId) - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
getValue() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstance
 
getValue() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.AcceptState
 
getValue() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnState
 
getValue() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.PromiseState
 
getVersion() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.VersionedConfigurationStateChange
 
getVersion() - Method in class org.neo4j.cluster.protocol.election.ElectionContext.VoteRequest
 
getVersion() - Method in class org.neo4j.cluster.protocol.election.ElectionMessage.VersionedVotedData
 
getVoteCount(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
getVoteCount(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
getVoteCredentials() - Method in class org.neo4j.cluster.protocol.election.ElectionMessage.VotedData
 

H

handle(CONTEXT, Message<MESSAGETYPE>, MessageHolder) - Method in interface org.neo4j.cluster.statemachine.State
Handle a message.
handle(Message<? extends MessageType>, MessageHolder) - Method in class org.neo4j.cluster.statemachine.StateMachine
 
hasCurrentlyElectedVoted(String, InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
hasCurrentlyElectedVoted(String, InstanceId) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
hasDeliveredAllKnownInstances() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
hashCode() - Method in class org.neo4j.cluster.client.Clusters.Cluster
 
hashCode() - Method in class org.neo4j.cluster.client.Clusters
 
hashCode() - Method in class org.neo4j.cluster.client.Clusters.Member
 
hashCode() - Method in class org.neo4j.cluster.com.message.Message
 
hashCode() - Method in class org.neo4j.cluster.InstanceId
 
hashCode() - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.AcceptState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.PrepareState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnFailedState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnRequestState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.AcceptedState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.PromiseState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectAcceptState
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectPrepare
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.Vote
 
hashCode() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.Payload
 
hashCode() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
hashCode() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
hashCode() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationRequestState
 
hashCode() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
hashCode() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationTimeoutState
 
hashCode() - Method in class org.neo4j.cluster.protocol.election.ElectionRole
 
hashCode() - Method in class org.neo4j.cluster.protocol.election.NotElectableElectionCredentials
 
hashCode() - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.IAmAliveState
 
hashCode() - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.SuspicionsState
 
hashCode() - Method in class org.neo4j.cluster.statemachine.StateTransition
 
hasHeader(String) - Method in class org.neo4j.cluster.com.message.Message
 
hasJoinBeenDenied() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
hasMappingFor(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.VersionMapper
 
hasPendingValues() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
hasQuorum() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastContext
 
Heartbeat - Interface in org.neo4j.cluster.protocol.heartbeat
Heartbeat API.
heartbeat_interval - Static variable in class org.neo4j.cluster.ClusterSettings
 
heartbeat_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
HeartbeatContext - Interface in org.neo4j.cluster.protocol.heartbeat
Context used by the HeartbeatState state machine.
HeartbeatIAmAliveProcessor - Class in org.neo4j.cluster.protocol.heartbeat
When a message is received, create an I Am Alive message as well, since we know that the sending instance is up
HeartbeatIAmAliveProcessor(MessageHolder, ClusterContext) - Constructor for class org.neo4j.cluster.protocol.heartbeat.HeartbeatIAmAliveProcessor
 
HeartbeatJoinListener - Class in org.neo4j.cluster.protocol.heartbeat
When an instance joins a cluster, setup a heartbeat for it
HeartbeatJoinListener(MessageHolder) - Constructor for class org.neo4j.cluster.protocol.heartbeat.HeartbeatJoinListener
 
HeartbeatLeftListener - Class in org.neo4j.cluster.protocol.heartbeat
 
HeartbeatLeftListener(HeartbeatContext, LogProvider) - Constructor for class org.neo4j.cluster.protocol.heartbeat.HeartbeatLeftListener
 
HeartbeatListener - Interface in org.neo4j.cluster.protocol.heartbeat
Listener interface for heart beat.
HeartbeatListener.Adapter - Class in org.neo4j.cluster.protocol.heartbeat
 
HeartbeatListener.Adapter() - Constructor for class org.neo4j.cluster.protocol.heartbeat.HeartbeatListener.Adapter
 
HeartbeatMessage - Enum in org.neo4j.cluster.protocol.heartbeat
Messages used by the HeartbeatState state machine.
HeartbeatMessage.IAmAliveState - Class in org.neo4j.cluster.protocol.heartbeat
 
HeartbeatMessage.IAmAliveState(InstanceId) - Constructor for class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.IAmAliveState
 
HeartbeatMessage.SuspicionsState - Class in org.neo4j.cluster.protocol.heartbeat
 
HeartbeatMessage.SuspicionsState(Set<InstanceId>) - Constructor for class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.SuspicionsState
 
HeartbeatReelectionListener - Class in org.neo4j.cluster.protocol.election
If an instance is considered failed, demote it from all its roles in the cluster.
HeartbeatReelectionListener(Election, LogProvider) - Constructor for class org.neo4j.cluster.protocol.election.HeartbeatReelectionListener
 
HeartbeatRefreshProcessor - Class in org.neo4j.cluster.protocol.heartbeat
When a message is sent out, reset the timeout for sending heartbeat to the TO host, since we only have to send i_am_alive if nothing else is going on.
HeartbeatRefreshProcessor(MessageHolder, ClusterContext) - Constructor for class org.neo4j.cluster.protocol.heartbeat.HeartbeatRefreshProcessor
 
HeartbeatState - Enum in org.neo4j.cluster.protocol.heartbeat
State machine that implements the Heartbeat API

I

INADDR_ANY - Static variable in class org.neo4j.cluster.com.NetworkReceiver
 
init() - Method in class org.neo4j.cluster.client.ClusterJoin
 
init() - Method in class org.neo4j.cluster.com.NetworkReceiver
 
init() - Method in class org.neo4j.cluster.com.NetworkSender
 
init() - Method in class org.neo4j.cluster.ExecutorLifecycleAdapter
 
init() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberAvailability
 
init() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents
 
initial_hosts - Static variable in class org.neo4j.cluster.ClusterSettings
 
InMemoryAcceptorInstanceStore - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
In memory version of an acceptor instance store.
InMemoryAcceptorInstanceStore() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
INSTANCE - Static variable in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
INSTANCE_ID - Static variable in class org.neo4j.cluster.ClusterSettings
 
INSTANCE_ID - Static variable in class org.neo4j.cluster.com.message.Message
 
instance_name - Static variable in class org.neo4j.cluster.ClusterSettings
 
InstanceId - Class in org.neo4j.cluster
Represents the concept of the cluster wide unique id of an instance.
InstanceId() - Constructor for class org.neo4j.cluster.InstanceId
 
InstanceId(int) - Constructor for class org.neo4j.cluster.InstanceId
 
InstanceId - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Id of a particular Paxos instance.
InstanceId(Message) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
InstanceId(String) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
InstanceId(long) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
instanceIsJoining(InstanceId, URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
instanceNameFromURI(URI) - Method in class org.neo4j.cluster.InstanceId
 
internal(MESSAGETYPE) - Static method in class org.neo4j.cluster.com.message.Message
 
internal(MESSAGETYPE, Object) - Static method in class org.neo4j.cluster.com.message.Message
 
invoke(Object, Method, Object[]) - Method in class org.neo4j.cluster.statemachine.StateMachineProxyHandler
 
isAccepted(int) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
isAllowedToCreateCluster() - Method in interface org.neo4j.cluster.client.ClusterJoin.Configuration
 
isCurrentlyAlive(InstanceId) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
isElectedAs(String) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
isElectionProcessInProgress(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
isElectionProcessInProgress(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
isElector() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
isElector() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
isFailed(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
isFailed(InstanceId) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
isFailed(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
isFullHaMember() - Method in class org.neo4j.cluster.client.Clusters.Member
 
isInCluster() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
isInCluster() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
isInCluster() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
isInstanceJoiningFromDifferentUri(InstanceId, URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
isInternal() - Method in class org.neo4j.cluster.com.message.Message
 
isLeaving(InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
isMe(InstanceId) - Method in interface org.neo4j.cluster.protocol.ConfigurationContext
 
isPromised(int) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
isQuorum(long, long) - Static method in class org.neo4j.cluster.util.Quorums
Determines if a number of available members qualify as a majority, given the total number of members.
isShutdown() - Method in class org.neo4j.cluster.DelayedDirectExecutor
 
isState(PaxosInstance.State) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
isTerminated() - Method in class org.neo4j.cluster.DelayedDirectExecutor
 

J

join(String, URI...) - Method in class org.neo4j.cluster.client.ClusterClient
 
join(String, URI...) - Method in interface org.neo4j.cluster.protocol.cluster.Cluster
 
join(InstanceId, URI) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
join_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
joinDenied(ClusterMessage.ConfigurationResponseState) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
joined(InstanceId, URI) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
joined() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
joined(InstanceId, URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
joinedCluster(InstanceId, URI) - Method in class org.neo4j.cluster.protocol.cluster.ClusterListener.Adapter
 
joinedCluster(InstanceId, URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterListener
When another instance joins as a member, this callback is invoked
joinedCluster(InstanceId, URI) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatJoinListener
 
joining(String, Iterable<URI>) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 

L

lastDelivered(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstanceStore
 
lastDelivered(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
learn_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
learnedInstanceId(long) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
LearnerContext - Interface in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Context for the Learner Paxos state machine.
LearnerMessage - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Learner state machine messages
LearnerMessage.LearnFailedState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
LearnerMessage.LearnFailedState() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnFailedState
 
LearnerMessage.LearnRequestState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
LearnerMessage.LearnRequestState() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnRequestState
 
LearnerMessage.LearnState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
LearnerMessage.LearnState(Object) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnState
 
LearnerState - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
State machine for Paxos Learner
leave() - Method in class org.neo4j.cluster.client.ClusterClient
 
leave() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorContext
 
leave() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
leave() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
leave() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
leave() - Method in interface org.neo4j.cluster.protocol.cluster.Cluster
 
leave(InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
leave_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
left(InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
left() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
left() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
left(InstanceId) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
leftCluster(InstanceId, URI) - Method in class org.neo4j.cluster.protocol.cluster.ClusterListener.Adapter
 
leftCluster() - Method in class org.neo4j.cluster.protocol.cluster.ClusterListener.Adapter
 
leftCluster() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterListener
When I leave the cluster, this callback notifies me that this has been agreed upon by the entire cluster.
leftCluster(InstanceId, URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterListener
When another instance leaves the cluster, this callback is invoked.
leftCluster(InstanceId, URI) - Method in class org.neo4j.cluster.protocol.election.ClusterLeaveReelectionListener
 
leftCluster(InstanceId, URI) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatLeftListener
 
LenientObjectInputStream - Class in org.neo4j.cluster.protocol.atomicbroadcast
 
LenientObjectInputStream(ByteArrayInputStream, VersionMapper) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.LenientObjectInputStream
 
LenientObjectOutputStream - Class in org.neo4j.cluster.protocol.atomicbroadcast
 
LenientObjectOutputStream(ByteArrayOutputStream, VersionMapper) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.LenientObjectOutputStream
 
life - Variable in class org.neo4j.cluster.client.ClusterClientModule
 
listeningAt(URI) - Method in interface org.neo4j.cluster.BindingListener
 
listeningAt(URI) - Method in class org.neo4j.cluster.com.NetworkReceiver
 
listeningAt(URI) - Method in interface org.neo4j.cluster.com.NetworkReceiver.NetworkChannelsListener
 
listeningAt(URI) - Method in class org.neo4j.cluster.protocol.election.ServerIdElectionCredentialsProvider
 
listeningAt(URI) - Method in class org.neo4j.cluster.ProtocolServer
 

M

mappingFor(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.VersionMapper
 
memberIsAlive(InstanceId) - Method in class org.neo4j.cluster.member.ClusterMemberListener.Adapter
 
memberIsAlive(InstanceId) - Method in interface org.neo4j.cluster.member.ClusterMemberListener
Called when a member is considered alive again, by quorum.
memberIsAvailable(String, URI, StoreId) - Method in interface org.neo4j.cluster.member.ClusterMemberAvailability
When a member has finished a transition to a particular role, i.e.
memberIsAvailable(String, InstanceId, URI, StoreId) - Method in class org.neo4j.cluster.member.ClusterMemberListener.Adapter
 
memberIsAvailable(String, InstanceId, URI, StoreId) - Method in interface org.neo4j.cluster.member.ClusterMemberListener
Called when a member announces that it is available to play a particular role, e.g.
MemberIsAvailable - Class in org.neo4j.cluster.member.paxos
This message is broadcast when a member of the cluster declares that it is ready to serve a particular role for the cluster.
MemberIsAvailable() - Constructor for class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
MemberIsAvailable(String, InstanceId, URI, URI, StoreId) - Constructor for class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
memberIsAvailable(String, URI, StoreId) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberAvailability
 
memberIsFailed(InstanceId) - Method in class org.neo4j.cluster.member.ClusterMemberListener.Adapter
 
memberIsFailed(InstanceId) - Method in interface org.neo4j.cluster.member.ClusterMemberListener
Called when a member is considered failed, by quorum.
memberIsUnavailable(String) - Method in interface org.neo4j.cluster.member.ClusterMemberAvailability
When a member is no longer available in a particular role it should call this to announce it to the other members of the cluster.
memberIsUnavailable(String, InstanceId) - Method in class org.neo4j.cluster.member.ClusterMemberListener.Adapter
 
memberIsUnavailable(String, InstanceId) - Method in interface org.neo4j.cluster.member.ClusterMemberListener
Called when a member is no longer available for fulfilling a particular role.
MemberIsUnavailable - Class in org.neo4j.cluster.member.paxos
This message is broadcast when a member of the cluster declares that it is not ready to serve a particular role for the cluster.
MemberIsUnavailable() - Constructor for class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
MemberIsUnavailable(String, InstanceId, URI) - Constructor for class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
memberIsUnavailable(String) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberAvailability
 
Message<MESSAGETYPE extends MessageType> - Class in org.neo4j.cluster.com.message
Message for state machines which can be sent out to instances in the cluster as well.
MessageHolder - Interface in org.neo4j.cluster.com.message
This is used to store messages generated from a StateMachine in response to an incoming message.
MessageProcessor - Interface in org.neo4j.cluster.com.message
This is used to process a single message to or from a StateMachine.
MessageSender - Interface in org.neo4j.cluster.com.message
Poorly conceived interface to allow a MessageProcessor to be a network sender which handles batches of messages.
MessageSource - Interface in org.neo4j.cluster.com.message
This represents a source of messages, such as NetworkReceiver.
MessageTimeoutStrategy - Class in org.neo4j.cluster.timeout
Timeout strategy that allows you to specify per message type what timeout to use
MessageTimeoutStrategy(TimeoutStrategy) - Constructor for class org.neo4j.cluster.timeout.MessageTimeoutStrategy
 
MessageType - Interface in org.neo4j.cluster.com.message
Message name.
MultiPaxosContext - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context
Context that implements all the context interfaces used by the Paxos state machines.
MultiPaxosContext(InstanceId, Iterable<ElectionRole>, ClusterConfiguration, Executor, LogService, ObjectInputStreamFactory, ObjectOutputStreamFactory, AcceptorInstanceStore, Timeouts, ElectionCredentialsProvider) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
 
MultiPaxosServerFactory - Class in org.neo4j.cluster
Factory for MultiPaxos ProtocolServers.
MultiPaxosServerFactory(ClusterConfiguration, LogService, StateMachines.Monitor) - Constructor for class org.neo4j.cluster.MultiPaxosServerFactory
 
myName() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 

N

name() - Method in interface org.neo4j.cluster.com.message.MessageType
 
name() - Method in interface org.neo4j.cluster.com.NetworkReceiver.Configuration
 
NettyLoggerFactory - Class in org.neo4j.cluster.logging
Adapter which send Netty logging messages to our internal log.
NettyLoggerFactory(LogProvider) - Constructor for class org.neo4j.cluster.logging.NettyLoggerFactory
 
NetworkedServerFactory - Class in org.neo4j.cluster
TODO
NetworkedServerFactory(LifeSupport, ProtocolServerFactory, TimeoutStrategy, LogProvider, ObjectInputStreamFactory, ObjectOutputStreamFactory, NetworkReceiver.Monitor, NetworkSender.Monitor, NamedThreadFactory.Monitor) - Constructor for class org.neo4j.cluster.NetworkedServerFactory
 
NetworkReceiver - Class in org.neo4j.cluster.com
TCP version of a Networked Instance.
NetworkReceiver(NetworkReceiver.Monitor, NetworkReceiver.Configuration, LogProvider) - Constructor for class org.neo4j.cluster.com.NetworkReceiver
 
NetworkReceiver.Configuration - Interface in org.neo4j.cluster.com
 
NetworkReceiver.Monitor - Interface in org.neo4j.cluster.com
 
NetworkReceiver.NetworkChannelsListener - Interface in org.neo4j.cluster.com
 
NetworkSender - Class in org.neo4j.cluster.com
TCP version of sending messages.
NetworkSender(NetworkSender.Monitor, NetworkSender.Configuration, NetworkReceiver, LogProvider) - Constructor for class org.neo4j.cluster.com.NetworkSender
 
NetworkSender.Configuration - Interface in org.neo4j.cluster.com
 
NetworkSender.Monitor - Interface in org.neo4j.cluster.com
 
NetworkSender.NetworkChannelsListener - Interface in org.neo4j.cluster.com
 
newClient(Class<T>) - Method in class org.neo4j.cluster.ProtocolServer
 
newConfigurationStateChange() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
newConfigurationStateChange() - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
newInstance(String) - Method in class org.neo4j.cluster.logging.NettyLoggerFactory
 
newInstanceId() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
newNetworkedServer(Config, AcceptorInstanceStore, ElectionCredentialsProvider) - Method in class org.neo4j.cluster.NetworkedServerFactory
 
newProtocolServer(InstanceId, TimeoutStrategy, MessageSource, MessageSender, AcceptorInstanceStore, ElectionCredentialsProvider, Executor, ObjectInputStreamFactory, ObjectOutputStreamFactory) - Method in class org.neo4j.cluster.MultiPaxosServerFactory
 
newProtocolServer(InstanceId, MessageSource, MessageSender, Executor, DelayedDirectExecutor, Timeouts, MultiPaxosContext, SnapshotContext) - Method in class org.neo4j.cluster.MultiPaxosServerFactory
 
newProtocolServer(InstanceId, TimeoutStrategy, MessageSource, MessageSender, AcceptorInstanceStore, ElectionCredentialsProvider, Executor, ObjectInputStreamFactory, ObjectOutputStreamFactory) - Method in interface org.neo4j.cluster.ProtocolServerFactory
 
newProxy(Class<CLIENT>) - Method in class org.neo4j.cluster.statemachine.StateMachineProxyFactory
 
newSerializer() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
NO_ELECTOR_VERSION - Static variable in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
nodeFailed(InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
nodeFailed(InstanceId) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
NONE - Static variable in class org.neo4j.cluster.InstanceId
 
NotElectableElectionCredentials - Class in org.neo4j.cluster.protocol.election
Election credentials stating that this instance cannot be elected.
NotElectableElectionCredentials() - Constructor for class org.neo4j.cluster.protocol.election.NotElectableElectionCredentials
 
NotElectableElectionCredentialsProvider - Class in org.neo4j.cluster.protocol.election
For clients who should never be elected as coordinators or masters, use this election credentials provider.
NotElectableElectionCredentialsProvider() - Constructor for class org.neo4j.cluster.protocol.election.NotElectableElectionCredentialsProvider
 
notifyLearnMiss(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
nrOfBookedInstances() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 

O

ObjectInputStreamFactory - Interface in org.neo4j.cluster.protocol.atomicbroadcast
 
ObjectOutputStreamFactory - Interface in org.neo4j.cluster.protocol.atomicbroadcast
 
ObjectStreamFactory - Class in org.neo4j.cluster.protocol.atomicbroadcast
Stream factory for serializing/deserializing messages.
ObjectStreamFactory() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.ObjectStreamFactory
 
offer(Message<? extends MessageType>) - Method in interface org.neo4j.cluster.com.message.MessageHolder
 
org.neo4j.cluster - package org.neo4j.cluster
 
org.neo4j.cluster.client - package org.neo4j.cluster.client
 
org.neo4j.cluster.com - package org.neo4j.cluster.com
 
org.neo4j.cluster.com.message - package org.neo4j.cluster.com.message
 
org.neo4j.cluster.logging - package org.neo4j.cluster.logging
 
org.neo4j.cluster.member - package org.neo4j.cluster.member
 
org.neo4j.cluster.member.paxos - package org.neo4j.cluster.member.paxos
 
org.neo4j.cluster.protocol - package org.neo4j.cluster.protocol
 
org.neo4j.cluster.protocol.atomicbroadcast - package org.neo4j.cluster.protocol.atomicbroadcast
 
org.neo4j.cluster.protocol.atomicbroadcast.multipaxos - package org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context - package org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context
 
org.neo4j.cluster.protocol.cluster - package org.neo4j.cluster.protocol.cluster
 
org.neo4j.cluster.protocol.election - package org.neo4j.cluster.protocol.election
 
org.neo4j.cluster.protocol.heartbeat - package org.neo4j.cluster.protocol.heartbeat
 
org.neo4j.cluster.protocol.snapshot - package org.neo4j.cluster.protocol.snapshot
 
org.neo4j.cluster.statemachine - package org.neo4j.cluster.statemachine
 
org.neo4j.cluster.timeout - package org.neo4j.cluster.timeout
 
org.neo4j.cluster.util - package org.neo4j.cluster.util
 

P

patchBookedInstances(ClusterMessage.ConfigurationChangeState) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
paxos_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
PaxosClusterMemberAvailability - Class in org.neo4j.cluster.member.paxos
Paxos based implementation of ClusterMemberAvailability
PaxosClusterMemberAvailability(InstanceId, BindingNotifier, AtomicBroadcast, LogProvider, ObjectInputStreamFactory, ObjectOutputStreamFactory) - Constructor for class org.neo4j.cluster.member.paxos.PaxosClusterMemberAvailability
 
PaxosClusterMemberEvents - Class in org.neo4j.cluster.member.paxos
Paxos based implementation of ClusterMemberEvents
PaxosClusterMemberEvents(Snapshot, Cluster, Heartbeat, AtomicBroadcast, LogProvider, Predicate<PaxosClusterMemberEvents.ClusterMembersSnapshot>, Function2<Iterable<MemberIsAvailable>, MemberIsAvailable, Iterable<MemberIsAvailable>>, ObjectInputStreamFactory, ObjectOutputStreamFactory, NamedThreadFactory.Monitor) - Constructor for class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents
 
PaxosClusterMemberEvents.ClusterMembersSnapshot - Class in org.neo4j.cluster.member.paxos
 
PaxosClusterMemberEvents.ClusterMembersSnapshot(Function2<Iterable<MemberIsAvailable>, MemberIsAvailable, Iterable<MemberIsAvailable>>) - Constructor for class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.ClusterMembersSnapshot
 
PaxosClusterMemberEvents.UniqueRoleFilter - Class in org.neo4j.cluster.member.paxos
 
PaxosClusterMemberEvents.UniqueRoleFilter() - Constructor for class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.UniqueRoleFilter
 
PaxosInstance - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Record of an individual Paxos instance, from a proposer perspective
PaxosInstance(PaxosInstanceStore, InstanceId) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
PaxosInstanceStore - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Store of Paxos instances, from a proposer perspective
PaxosInstanceStore() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
PaxosInstanceStore(int) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
Payload - Class in org.neo4j.cluster.protocol.atomicbroadcast
AtomicBroadcast payload.
Payload() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.Payload
Externalizable constructor
Payload(byte[], int) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.Payload
 
pending() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
pendingValue(Message) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
performRoleElections() - Method in class org.neo4j.cluster.client.ClusterClient
 
performRoleElections() - Method in interface org.neo4j.cluster.protocol.election.Election
Asks an election to be performed for all currently known roles, regardless of someone holding that role currently.
phase1_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
phase1Timeout(long) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
phase2_timeout - Static variable in class org.neo4j.cluster.ClusterSettings
 
phase2Timeout(long) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
pickWinner(Collection<Vote>) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.BiasedWinnerStrategy
 
pickWinner(Collection<Vote>) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.WinnerStrategy
 
popPendingValue() - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
port() - Method in interface org.neo4j.cluster.com.NetworkSender.Configuration
 
process(Message<? extends MessageType>) - Method in interface org.neo4j.cluster.com.message.MessageProcessor
 
process(List<Message<? extends MessageType>>) - Method in interface org.neo4j.cluster.com.message.MessageSender
 
process(List<Message<? extends MessageType>>) - Method in class org.neo4j.cluster.com.NetworkSender
 
process(Message<? extends MessageType>) - Method in class org.neo4j.cluster.com.NetworkSender
 
process(Message<? extends MessageType>) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatIAmAliveProcessor
 
process(Message<? extends MessageType>) - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatRefreshProcessor
 
process(Message) - Method in class org.neo4j.cluster.statemachine.StateMachineProxyFactory
 
process(Message<? extends MessageType>) - Method in class org.neo4j.cluster.StateMachines
 
processedMessage(Message) - Method in interface org.neo4j.cluster.com.NetworkReceiver.Monitor
 
promise(AcceptorInstance, long) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorContext
 
promise(long) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstance
 
promise(AcceptorInstance, long) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorInstanceStore
 
promise(AcceptorInstance, long) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
promise(ProposerMessage.PromiseState) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
promote(InstanceId, String) - Method in class org.neo4j.cluster.client.ClusterClient
 
promote(InstanceId, String) - Method in interface org.neo4j.cluster.protocol.election.Election
 
promotion(ClusterContext, InstanceId) - Static method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.BiasedWinnerStrategy
 
propose(long, List<URI>) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
ProposerContext - Interface in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Context used by ProposerState state machine.
ProposerMessage - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Coordinator state machine messages
ProposerMessage.AcceptedState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
ProposerMessage.AcceptedState() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.AcceptedState
 
ProposerMessage.PromiseState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
ProposerMessage.PromiseState(long, Object) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.PromiseState
 
ProposerMessage.RejectAcceptState - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
ProposerMessage.RejectAcceptState() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectAcceptState
 
ProposerMessage.RejectPrepare - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
 
ProposerMessage.RejectPrepare(long) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectPrepare
 
ProposerState - Enum in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
State machine for Paxos Proposer
ProtocolServer - Class in org.neo4j.cluster
A ProtocolServer ties together the underlying StateMachines with an understanding of ones own server address (me), and provides a proxy factory for creating clients to invoke the CSM.
ProtocolServer(InstanceId, StateMachines, LogProvider) - Constructor for class org.neo4j.cluster.ProtocolServer
 
ProtocolServerFactory - Interface in org.neo4j.cluster
Factory for instantiating ProtocolServers.

Q

queuedMessage(Message) - Method in interface org.neo4j.cluster.com.NetworkSender.Monitor
 
Quorums - Class in org.neo4j.cluster.util
 
Quorums() - Constructor for class org.neo4j.cluster.util.Quorums
 

R

read(Document) - Method in class org.neo4j.cluster.client.ClustersXMLSerializer
 
readExternal(ObjectInput) - Method in class org.neo4j.cluster.InstanceId
 
readExternal(ObjectInput) - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
readExternal(ObjectInput) - Method in class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
readExternal(ObjectInput) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.Payload
 
readExternal(ObjectInput) - Method in class org.neo4j.cluster.protocol.election.NotElectableElectionCredentials
 
ready(Object, boolean) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
receive(Message) - Method in class org.neo4j.cluster.com.NetworkReceiver
 
receive(Payload) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcastListener
 
receive(Payload) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcastSerializer
 
receive(Payload) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastContext
 
receivedMessage(Message) - Method in interface org.neo4j.cluster.com.NetworkReceiver.Monitor
 
receiver - Variable in class org.neo4j.cluster.client.ClusterClientModule
 
refreshSnapshot() - Method in class org.neo4j.cluster.client.ClusterClient
 
refreshSnapshot() - Method in interface org.neo4j.cluster.protocol.snapshot.Snapshot
 
rejected(ProposerMessage.RejectAcceptState) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
relativeTimeout(MessageType, MessageType, long) - Method in class org.neo4j.cluster.timeout.MessageTimeoutStrategy
 
removeAtomicBroadcastListener(AtomicBroadcastListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
removeAtomicBroadcastListener(AtomicBroadcastListener) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.AtomicBroadcast
 
removeAtomicBroadcastListener(AtomicBroadcastListener) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastContext
 
removeBindingListener(BindingListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
removeBindingListener(BindingListener) - Method in interface org.neo4j.cluster.com.BindingNotifier
 
removeBindingListener(BindingListener) - Method in class org.neo4j.cluster.ProtocolServer
 
removeBlankVotes(Collection<Vote>) - Static method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
removeClusterListener(ClusterListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
removeClusterListener(ClusterListener) - Method in interface org.neo4j.cluster.ClusterMonitor
 
removeClusterListener(ClusterListener) - Method in interface org.neo4j.cluster.protocol.cluster.Cluster
 
removeClusterListener(ClusterListener) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
removeClusterMemberListener(ClusterMemberListener) - Method in interface org.neo4j.cluster.member.ClusterMemberEvents
 
removeClusterMemberListener(ClusterMemberListener) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents
 
removeElected(String) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
removeHeartbeatListener(HeartbeatListener) - Method in class org.neo4j.cluster.client.ClusterClient
 
removeHeartbeatListener(HeartbeatListener) - Method in interface org.neo4j.cluster.protocol.heartbeat.Heartbeat
 
removeHeartbeatListener(HeartbeatListener) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
removeStateMachine(StateMachine) - Method in class org.neo4j.cluster.StateMachines
 
removeStateTransitionListener(StateTransitionListener) - Method in class org.neo4j.cluster.statemachine.StateMachine
 
removeStateTransitionListener(StateTransitionListener) - Method in class org.neo4j.cluster.StateMachines
 
respond(MESSAGETYPE, Message<?>, Object) - Static method in class org.neo4j.cluster.com.message.Message
 
rule(State<?, ?>, MessageType, State<?, ?>, Message<?>...) - Method in class org.neo4j.cluster.statemachine.StateMachineRules
 

S

sentMessage(Message) - Method in interface org.neo4j.cluster.com.NetworkSender.Monitor
 
server - Variable in class org.neo4j.cluster.client.ClusterClientModule
 
server_id - Static variable in class org.neo4j.cluster.ClusterSettings
 
ServerIdElectionCredentials - Class in org.neo4j.cluster.protocol.election
 
ServerIdElectionCredentials(URI) - Constructor for class org.neo4j.cluster.protocol.election.ServerIdElectionCredentials
 
ServerIdElectionCredentialsProvider - Class in org.neo4j.cluster.protocol.election
ElectionCredentialsProvider that provides the server URI as credentials for elections.
ServerIdElectionCredentialsProvider() - Constructor for class org.neo4j.cluster.protocol.election.ServerIdElectionCredentialsProvider
 
serverLeftCluster(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
setBoundAt(URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
setElector(InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.VersionedConfigurationStateChange
 
setHeader(String, String) - Method in class org.neo4j.cluster.com.message.Message
 
setLastDeliveredInstanceId(long) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
setLastElector(InstanceId) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
setLastElectorVersion(long) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
setLastKnownLearnedInstanceInCluster(long, InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
setMembers(Map<InstanceId, URI>) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
setNextInstanceId(long) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerContext
 
setPaused(boolean) - Method in class org.neo4j.cluster.com.NetworkReceiver
 
setPaused(boolean) - Method in class org.neo4j.cluster.com.NetworkSender
 
setRoles(Map<String, InstanceId>) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
setSnapshotProvider(SnapshotProvider) - Method in class org.neo4j.cluster.client.ClusterClient
 
setSnapshotProvider(SnapshotProvider) - Method in interface org.neo4j.cluster.protocol.snapshot.Snapshot
 
setSnapshotProvider(SnapshotProvider) - Method in class org.neo4j.cluster.protocol.snapshot.SnapshotContext
 
setState(SnapshotProvider, ObjectInputStreamFactory) - Method in class org.neo4j.cluster.protocol.snapshot.SnapshotMessage.SnapshotState
 
setState(ObjectInputStream) - Method in interface org.neo4j.cluster.protocol.snapshot.SnapshotProvider
 
setTimeout(Object, Message<? extends MessageType>) - Method in interface org.neo4j.cluster.protocol.TimeoutsContext
 
setTimeout(Object, Message<? extends MessageType>) - Method in class org.neo4j.cluster.timeout.Timeouts
Add a new timeout to the list If this is not cancelled it will trigger a message on the message processor
setTimestamp(long) - Method in class org.neo4j.cluster.client.Clusters
 
setVersion(long) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.VersionedConfigurationStateChange
 
shutdown() - Method in class org.neo4j.cluster.com.NetworkReceiver
 
shutdown() - Method in class org.neo4j.cluster.com.NetworkSender
 
shutdown() - Method in class org.neo4j.cluster.DelayedDirectExecutor
 
shutdown() - Method in class org.neo4j.cluster.ExecutorLifecycleAdapter
 
shutdown() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberAvailability
 
shutdown() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents
 
shutdown() - Method in class org.neo4j.cluster.ProtocolServer
 
shutdownNow() - Method in class org.neo4j.cluster.DelayedDirectExecutor
 
snapshot(CommonContextState, LogService, Timeouts, ClusterContextImpl, HeartbeatContextImpl, ElectionCredentialsProvider) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
snapshot(LogService, Timeouts, Executor, AcceptorInstanceStore, ObjectInputStreamFactory, ObjectOutputStreamFactory, ElectionCredentialsProvider) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext
Create a state snapshot.
snapshot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InMemoryAcceptorInstanceStore
 
snapshot(PaxosInstanceStore) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
snapshot() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstanceStore
 
snapshot(Log) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
snapshot() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
Snapshot - Interface in org.neo4j.cluster.protocol.snapshot
API for getting a snapshot of current state from an instance in a cluster.
SnapshotContext - Class in org.neo4j.cluster.protocol.snapshot
TODO
SnapshotContext(ClusterContext, LearnerContext) - Constructor for class org.neo4j.cluster.protocol.snapshot.SnapshotContext
 
SnapshotMessage - Enum in org.neo4j.cluster.protocol.snapshot
TODO
SnapshotMessage.SnapshotState - Class in org.neo4j.cluster.protocol.snapshot
 
SnapshotMessage.SnapshotState(long, SnapshotProvider, ObjectOutputStreamFactory) - Constructor for class org.neo4j.cluster.protocol.snapshot.SnapshotMessage.SnapshotState
 
SnapshotProvider - Interface in org.neo4j.cluster.protocol.snapshot
Handle snapshot data for cluster state.
SnapshotState - Enum in org.neo4j.cluster.protocol.snapshot
State machine for the snapshot API
start() - Method in class org.neo4j.cluster.client.ClusterJoin
 
start() - Method in class org.neo4j.cluster.com.NetworkReceiver
 
start() - Method in class org.neo4j.cluster.com.NetworkSender
 
start() - Method in class org.neo4j.cluster.ExecutorLifecycleAdapter
 
start() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberAvailability
 
start() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents
 
startDemotionProcess(String, InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
startDemotionProcess(String, InstanceId) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
started() - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
startElectionProcess(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
startElectionProcess(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
startPromotionProcess(String, InstanceId) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
startPromotionProcess(String, InstanceId) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
State<CONTEXT,MESSAGETYPE extends MessageType> - Interface in org.neo4j.cluster.statemachine
Implemented by states in a state machine.
StateMachine - Class in org.neo4j.cluster.statemachine
State machine that wraps a context and a state, which can change when a Message comes in.
StateMachine(Object, Class<? extends MessageType>, State<?, ?>, LogProvider) - Constructor for class org.neo4j.cluster.statemachine.StateMachine
 
StateMachineConversations - Class in org.neo4j.cluster.statemachine
Generate id's for state machine conversations.
StateMachineConversations(InstanceId) - Constructor for class org.neo4j.cluster.statemachine.StateMachineConversations
 
StateMachineProxyFactory - Class in org.neo4j.cluster.statemachine
Used to generate dynamic proxies whose methods are backed by a StateMachine.
StateMachineProxyFactory(StateMachines, StateMachineConversations, InstanceId) - Constructor for class org.neo4j.cluster.statemachine.StateMachineProxyFactory
 
StateMachineProxyHandler - Class in org.neo4j.cluster.statemachine
Handle for dynamic proxies that are backed by a StateMachine.
StateMachineProxyHandler(StateMachineProxyFactory, StateMachine) - Constructor for class org.neo4j.cluster.statemachine.StateMachineProxyHandler
 
StateMachineRules - Class in org.neo4j.cluster.statemachine
Trigger messages when given state transitions occur
StateMachineRules(MessageHolder) - Constructor for class org.neo4j.cluster.statemachine.StateMachineRules
 
StateMachines - Class in org.neo4j.cluster
Combines a set of state machines into one.
StateMachines(LogProvider, StateMachines.Monitor, MessageSource, MessageSender, Timeouts, DelayedDirectExecutor, Executor, InstanceId) - Constructor for class org.neo4j.cluster.StateMachines
 
StateMachines.Monitor - Interface in org.neo4j.cluster
 
stateTransition(StateTransition) - Method in class org.neo4j.cluster.statemachine.StateMachineRules
 
StateTransition - Class in org.neo4j.cluster.statemachine
A single state transition that occurred in a state machine as a consequence of handling a message.
StateTransition(State<?, ?>, Message<? extends MessageType>, State<?, ?>) - Constructor for class org.neo4j.cluster.statemachine.StateTransition
 
stateTransition(StateTransition) - Method in interface org.neo4j.cluster.statemachine.StateTransitionListener
 
stateTransition(StateTransition) - Method in class org.neo4j.cluster.statemachine.StateTransitionLogger
 
StateTransitionListener - Interface in org.neo4j.cluster.statemachine
Listener API for StateMachine transitions.
StateTransitionLogger - Class in org.neo4j.cluster.statemachine
Logs state transitions in StateMachines.
StateTransitionLogger(LogProvider, AtomicBroadcastSerializer) - Constructor for class org.neo4j.cluster.statemachine.StateTransitionLogger
 
stop() - Method in class org.neo4j.cluster.client.ClusterClient
 
stop() - Method in class org.neo4j.cluster.client.ClusterJoin
 
stop() - Method in class org.neo4j.cluster.com.NetworkReceiver
 
stop() - Method in class org.neo4j.cluster.com.NetworkSender
 
stop() - Method in class org.neo4j.cluster.ExecutorLifecycleAdapter
 
stop() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberAvailability
 
stop() - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents
 
suspect(InstanceId) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 
suspicions(InstanceId, Set<InstanceId>) - Method in interface org.neo4j.cluster.protocol.heartbeat.HeartbeatContext
 

T

tick(long) - Method in class org.neo4j.cluster.timeout.FixedTimeoutStrategy
 
tick(long) - Method in class org.neo4j.cluster.timeout.MessageTimeoutStrategy
 
tick(long) - Method in class org.neo4j.cluster.timeout.Timeouts
 
tick(long) - Method in interface org.neo4j.cluster.timeout.TimeoutStrategy
 
timeout(MESSAGETYPE, Message<?>) - Static method in class org.neo4j.cluster.com.message.Message
 
timeout(MESSAGETYPE, Message<?>, Object) - Static method in class org.neo4j.cluster.com.message.Message
 
timeout(MessageType, long) - Method in class org.neo4j.cluster.timeout.MessageTimeoutStrategy
 
timeoutCancelled(Message) - Method in class org.neo4j.cluster.timeout.FixedTimeoutStrategy
 
timeoutCancelled(Message) - Method in class org.neo4j.cluster.timeout.MessageTimeoutStrategy
 
timeoutCancelled(Message) - Method in interface org.neo4j.cluster.timeout.TimeoutStrategy
 
timeoutFor(Message) - Method in class org.neo4j.cluster.timeout.FixedTimeoutStrategy
 
timeoutFor(Message) - Method in class org.neo4j.cluster.timeout.MessageTimeoutStrategy
 
timeoutFor(Message) - Method in interface org.neo4j.cluster.timeout.TimeoutStrategy
 
Timeouts - Class in org.neo4j.cluster.timeout
Timeout management for state machines.
Timeouts(TimeoutStrategy) - Constructor for class org.neo4j.cluster.timeout.Timeouts
 
Timeouts.Timeout - Class in org.neo4j.cluster.timeout
 
Timeouts.Timeout(long, Message<? extends MessageType>) - Constructor for class org.neo4j.cluster.timeout.Timeouts.Timeout
 
TimeoutsContext - Interface in org.neo4j.cluster.protocol
 
timeoutStrategy - Variable in class org.neo4j.cluster.client.ClusterClientModule
 
TimeoutStrategy - Interface in org.neo4j.cluster.timeout
Strategy for determining what timeout to use for messages.
timeoutTriggered(Message) - Method in class org.neo4j.cluster.timeout.FixedTimeoutStrategy
 
timeoutTriggered(Message) - Method in class org.neo4j.cluster.timeout.MessageTimeoutStrategy
 
timeoutTriggered(Message) - Method in interface org.neo4j.cluster.timeout.TimeoutStrategy
 
TO - Static variable in class org.neo4j.cluster.com.message.Message
 
to(MESSAGETYPE, URI) - Static method in class org.neo4j.cluster.com.message.Message
 
to(MESSAGETYPE, URI, Object) - Static method in class org.neo4j.cluster.com.message.Message
 
toIntegerIndex() - Method in class org.neo4j.cluster.InstanceId
 
toString() - Method in class org.neo4j.cluster.com.message.Message
 
toString() - Method in class org.neo4j.cluster.InstanceId
 
toString() - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
toString() - Method in class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.AcceptState
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage.PrepareState
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.InstanceId
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnFailedState
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnRequestState
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage.LearnState
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.PaxosInstance
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.PromiseState
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage.RejectPrepare
 
toString() - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.Vote
 
toString() - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
toString() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 
toString() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationRequestState
 
toString() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationResponseState
 
toString() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationTimeoutState
 
toString() - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.VersionedConfigurationStateChange
 
toString() - Method in class org.neo4j.cluster.protocol.election.ElectionContext.VoteRequest
 
toString() - Method in class org.neo4j.cluster.protocol.election.ElectionMessage.VotedData
 
toString() - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.IAmAliveState
 
toString() - Method in class org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage.SuspicionsState
 
toString() - Method in class org.neo4j.cluster.ProtocolServer
 
toString() - Method in class org.neo4j.cluster.statemachine.StateMachine
 
toString() - Method in class org.neo4j.cluster.statemachine.StateTransition
 
toString() - Method in class org.neo4j.cluster.StateMachines
 
toString() - Method in class org.neo4j.cluster.timeout.Timeouts.Timeout
 
trigger(MessageProcessor) - Method in class org.neo4j.cluster.timeout.Timeouts.Timeout
 

U

unavailableMember(InstanceId) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.ClusterMembersSnapshot
 
unavailableMember(URI, InstanceId, String) - Method in class org.neo4j.cluster.member.paxos.PaxosClusterMemberEvents.ClusterMembersSnapshot
 
unbookInstance(InstanceId) - Method in interface org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerContext
 
unelect(String) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
unelect(String) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
unelected(String) - Method in class org.neo4j.cluster.protocol.cluster.ClusterConfiguration
 
unelected(String, InstanceId) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
Deprecated.
unelected(String, InstanceId, InstanceId, long) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
 
unelected(String, InstanceId, URI) - Method in class org.neo4j.cluster.protocol.cluster.ClusterListener.Adapter
 
unelected(String, InstanceId, URI) - Method in interface org.neo4j.cluster.protocol.cluster.ClusterListener
 
unelected(String, InstanceId) - Method in class org.neo4j.cluster.protocol.cluster.ClusterMessage.ConfigurationChangeState
 

V

valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.cluster.ClusterMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.cluster.ClusterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.election.ElectionMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.election.ElectionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.heartbeat.HeartbeatState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.snapshot.SnapshotMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.cluster.protocol.snapshot.SnapshotState
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AcceptorState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.AtomicBroadcastState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.LearnerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.ProposerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.cluster.ClusterMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.cluster.ClusterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.election.ElectionMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.election.ElectionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.heartbeat.HeartbeatMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.heartbeat.HeartbeatState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.snapshot.SnapshotMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.cluster.protocol.snapshot.SnapshotState
Returns an array containing the constants of this enum type, in the order they are declared.
VersionMapper - Class in org.neo4j.cluster.protocol.atomicbroadcast
 
VersionMapper() - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.VersionMapper
 
Vote - Class in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
A cluster coordinator election vote.
Vote(InstanceId, Comparable<Object>) - Constructor for class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.Vote
 
voted(String, InstanceId, Comparable<Object>, long) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
voted(String, InstanceId, Comparable<Object>, long) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 
voteRequestForRole(ElectionRole) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.ElectionContextImpl
 
voteRequestForRole(ElectionRole) - Method in interface org.neo4j.cluster.protocol.election.ElectionContext
 

W

WinnerStrategy - Interface in org.neo4j.cluster.protocol.atomicbroadcast.multipaxos
Strategy to be used to select a winner in a cluster coordinator election.
write(Clusters) - Method in class org.neo4j.cluster.client.ClustersXMLSerializer
 
writeExternal(ObjectOutput) - Method in class org.neo4j.cluster.InstanceId
 
writeExternal(ObjectOutput) - Method in class org.neo4j.cluster.member.paxos.MemberIsAvailable
 
writeExternal(ObjectOutput) - Method in class org.neo4j.cluster.member.paxos.MemberIsUnavailable
 
writeExternal(ObjectOutput) - Method in class org.neo4j.cluster.protocol.atomicbroadcast.Payload
 
writeExternal(ObjectOutput) - Method in class org.neo4j.cluster.protocol.election.NotElectableElectionCredentials
 
A B C D E F G H I J L M N O P Q R S T U V W 

Copyright © 2002–2015 The Neo4j Graph Database Project. All rights reserved.