use of org.neo4j.cluster.protocol.cluster.ClusterConfiguration in project neo4j by neo4j.
the class MultiPaxosServer method start.
public void start() throws IOException {
broadcastSerializer = new AtomicBroadcastSerializer(new ObjectStreamFactory(), new ObjectStreamFactory());
final LifeSupport life = new LifeSupport();
try {
MessageTimeoutStrategy timeoutStrategy = new MessageTimeoutStrategy(new FixedTimeoutStrategy(5000)).timeout(HeartbeatMessage.sendHeartbeat, 200);
Monitors monitors = new Monitors();
NetworkedServerFactory serverFactory = new NetworkedServerFactory(life, new MultiPaxosServerFactory(new ClusterConfiguration("default", NullLogProvider.getInstance()), NullLogProvider.getInstance(), monitors.newMonitor(StateMachines.Monitor.class)), timeoutStrategy, NullLogProvider.getInstance(), new ObjectStreamFactory(), new ObjectStreamFactory(), monitors.newMonitor(NetworkReceiver.Monitor.class), monitors.newMonitor(NetworkSender.Monitor.class), monitors.newMonitor(NamedThreadFactory.Monitor.class));
ServerIdElectionCredentialsProvider electionCredentialsProvider = new ServerIdElectionCredentialsProvider();
server = serverFactory.newNetworkedServer(Config.embeddedDefaults(), new InMemoryAcceptorInstanceStore(), electionCredentialsProvider);
server.addBindingListener(electionCredentialsProvider);
server.addBindingListener(new BindingListener() {
@Override
public void listeningAt(URI me) {
System.out.println("Listening at:" + me);
}
});
cluster = server.newClient(Cluster.class);
cluster.addClusterListener(new ClusterListener() {
@Override
public void enteredCluster(ClusterConfiguration clusterConfiguration) {
System.out.println("Entered cluster:" + clusterConfiguration);
}
@Override
public void joinedCluster(InstanceId instanceId, URI member) {
System.out.println("Joined cluster:" + instanceId + " (at URI " + member + ")");
}
@Override
public void leftCluster(InstanceId instanceId, URI member) {
System.out.println("Left cluster:" + instanceId);
}
@Override
public void leftCluster() {
System.out.println("Left cluster");
}
@Override
public void elected(String role, InstanceId instanceId, URI electedMember) {
System.out.println(instanceId + " at URI " + electedMember + " was elected as " + role);
}
@Override
public void unelected(String role, InstanceId instanceId, URI electedMember) {
System.out.println(instanceId + " at URI " + electedMember + " was removed from " + role);
}
});
Heartbeat heartbeat = server.newClient(Heartbeat.class);
heartbeat.addHeartbeatListener(new HeartbeatListener() {
@Override
public void failed(InstanceId server) {
System.out.println(server + " failed");
}
@Override
public void alive(InstanceId server) {
System.out.println(server + " alive");
}
});
broadcast = server.newClient(AtomicBroadcast.class);
broadcast.addAtomicBroadcastListener(new AtomicBroadcastListener() {
@Override
public void receive(Payload value) {
try {
System.out.println(broadcastSerializer.receive(value));
} catch (IOException e) {
e.printStackTrace();
} catch (ClassNotFoundException e) {
e.printStackTrace();
}
}
});
life.start();
String command;
BufferedReader reader = new BufferedReader(new InputStreamReader(System.in));
while (!(command = reader.readLine()).equals("quit")) {
String[] arguments = command.split(" ");
Method method = getCommandMethod(arguments[0]);
if (method != null) {
String[] realArgs = new String[arguments.length - 1];
System.arraycopy(arguments, 1, realArgs, 0, realArgs.length);
try {
method.invoke(this, (Object[]) realArgs);
} catch (IllegalAccessException e) {
e.printStackTrace();
} catch (IllegalArgumentException e) {
e.printStackTrace();
} catch (InvocationTargetException e) {
e.printStackTrace();
}
}
}
cluster.leave();
} finally {
life.shutdown();
System.out.println("Done");
}
}
use of org.neo4j.cluster.protocol.cluster.ClusterConfiguration in project neo4j by neo4j.
the class AtomicBroadcastContextImplTest method shouldHasNoQuorumWhenOneMachineAliveInAClusterWithThreeMachines.
@Test
public void shouldHasNoQuorumWhenOneMachineAliveInAClusterWithThreeMachines() {
//Given
HeartbeatContext heartbeatContext = mock(HeartbeatContext.class);
CommonContextState commonState = mock(CommonContextState.class);
ClusterConfiguration configuration = mock(ClusterConfiguration.class);
when(heartbeatContext.getAlive()).thenReturn(ids(1));
when(commonState.configuration()).thenReturn(configuration);
when(configuration.getMembers()).thenReturn(members(3));
AtomicBroadcastContextImpl context = new AtomicBroadcastContextImpl(null, commonState, null, null, null, // we do not care about other args
heartbeatContext);
//When
boolean hasQuorum = context.hasQuorum();
//Then
assertFalse(hasQuorum);
}
use of org.neo4j.cluster.protocol.cluster.ClusterConfiguration in project neo4j by neo4j.
the class HeartbeatStateTest method shouldIgnoreSuspicionsForOurselvesButKeepTheRest.
@Test
public void shouldIgnoreSuspicionsForOurselvesButKeepTheRest() throws Throwable {
// Given
InstanceId myId = new InstanceId(1);
InstanceId foreignId = new InstanceId(3);
HeartbeatState heartbeat = HeartbeatState.heartbeat;
ClusterConfiguration configuration = new ClusterConfiguration("whatever", NullLogProvider.getInstance(), "cluster://1", "cluster://2");
configuration.joined(myId, URI.create("cluster://1"));
configuration.joined(new InstanceId(2), URI.create("cluster://2"));
Config config = mock(Config.class);
when(config.get(ClusterSettings.max_acceptors)).thenReturn(10);
MultiPaxosContext context = new MultiPaxosContext(myId, iterable(new ElectionRole("coordinator")), configuration, Mockito.mock(Executor.class), NullLogProvider.getInstance(), Mockito.mock(ObjectInputStreamFactory.class), Mockito.mock(ObjectOutputStreamFactory.class), Mockito.mock(AcceptorInstanceStore.class), Mockito.mock(Timeouts.class), mock(ElectionCredentialsProvider.class), config);
HeartbeatContext heartbeatContext = context.getHeartbeatContext();
Message received = Message.internal(HeartbeatMessage.suspicions, new HeartbeatMessage.SuspicionsState(asSet(iterable(myId, foreignId))));
received.setHeader(Message.FROM, "cluster://2").setHeader(Message.INSTANCE_ID, "2");
// When
heartbeat.handle(heartbeatContext, received, mock(MessageHolder.class));
// Then
assertThat(heartbeatContext.getSuspicionsOf(myId).size(), equalTo(0));
assertThat(heartbeatContext.getSuspicionsOf(foreignId).size(), equalTo(1));
}
use of org.neo4j.cluster.protocol.cluster.ClusterConfiguration in project neo4j by neo4j.
the class SnapshotStateTest method baseNoSendTest.
public void baseNoSendTest(Map<InstanceId, URI> extraMembers) throws Throwable {
URI me = URI.create("cluster://me");
Map<InstanceId, URI> members = new HashMap<InstanceId, URI>();
final InstanceId myId = new InstanceId(1);
members.put(myId, me);
members.putAll(extraMembers);
ClusterConfiguration clusterConfiguration = mock(ClusterConfiguration.class);
when(clusterConfiguration.getMembers()).thenReturn(members);
when(clusterConfiguration.getElected(ClusterConfiguration.COORDINATOR)).thenReturn(myId);
when(clusterConfiguration.getUriForId(myId)).thenReturn(me);
ClusterContext clusterContext = mock(ClusterContext.class);
when(clusterContext.getConfiguration()).thenReturn(clusterConfiguration);
when(clusterContext.getMyId()).thenReturn(myId);
SnapshotContext context = mock(SnapshotContext.class);
when(context.getClusterContext()).thenReturn(clusterContext);
when(context.getSnapshotProvider()).thenReturn(mock(SnapshotProvider.class));
Message<SnapshotMessage> message = Message.to(SnapshotMessage.refreshSnapshot, me);
MessageHolder outgoing = mock(MessageHolder.class);
SnapshotState newState = (SnapshotState) SnapshotState.ready.handle(context, message, outgoing);
assertThat(newState, equalTo(SnapshotState.ready));
Mockito.verifyZeroInteractions(outgoing);
}
use of org.neo4j.cluster.protocol.cluster.ClusterConfiguration in project neo4j by neo4j.
the class ElectionContextTest method electorLeavingAndRejoiningWithNoElectionsInBetweenMustStillHaveElectionsGoThrough.
/*
* This assumes an instance leaves the cluster normally and then rejoins, without any elections in between. The
* expected result is that it will succeed in sending election results.
*/
@Test
public void electorLeavingAndRejoiningWithNoElectionsInBetweenMustStillHaveElectionsGoThrough() throws Exception {
// Given
final String role1 = "coordinator1";
InstanceId me = new InstanceId(1);
InstanceId leavingInstance = new InstanceId(2);
InstanceId forQuorum = new InstanceId(3);
Config config = mock(Config.class);
when(config.get(ClusterSettings.max_acceptors)).thenReturn(10);
ClusterConfiguration clusterConfiguration = mock(ClusterConfiguration.class);
List<InstanceId> clusterMemberIds = new LinkedList<InstanceId>();
clusterMemberIds.add(leavingInstance);
clusterMemberIds.add(me);
clusterMemberIds.add(forQuorum);
when(clusterConfiguration.getMemberIds()).thenReturn(clusterMemberIds);
MultiPaxosContext context = new MultiPaxosContext(me, Iterables.<ElectionRole, ElectionRole>iterable(new ElectionRole(role1)), clusterConfiguration, new Executor() {
@Override
public void execute(Runnable command) {
command.run();
}
}, NullLogProvider.getInstance(), mock(ObjectInputStreamFactory.class), mock(ObjectOutputStreamFactory.class), mock(AcceptorInstanceStore.class), mock(Timeouts.class), mock(ElectionCredentialsProvider.class), config);
HeartbeatContext heartbeatContext = context.getHeartbeatContext();
ClusterContext clusterContext = context.getClusterContext();
clusterContext.setLastElector(leavingInstance);
clusterContext.setLastElectorVersion(8);
// When the elector leaves the cluster
clusterContext.left(leavingInstance);
// Then the elector is reset to defaults
assertEquals(clusterContext.getLastElector(), InstanceId.NONE);
assertEquals(clusterContext.getLastElectorVersion(), ClusterContext.NO_ELECTOR_VERSION);
// When the elector comes back with an election result
// We don't need to join, election results do not check for elector membership
clusterContext.elected(role1, forQuorum, leavingInstance, 9);
// Then the result is actually respected
assertEquals(clusterContext.getLastElector(), leavingInstance);
assertEquals(clusterContext.getLastElectorVersion(), 9);
}
Aggregations