- 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
-
- 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
-
- 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
-
- 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
-
- MultiPaxosServerFactory(ClusterConfiguration, LogService, StateMachines.Monitor) - Constructor for class org.neo4j.cluster.MultiPaxosServerFactory
-
- myName() - Method in interface org.neo4j.cluster.protocol.cluster.ClusterContext
-
- 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
-