use of org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext in project neo4j by neo4j.
the class ClusterContextTest method testElectionVersionIsUpdatedOnElectionFromSelfAndProperlyIgnoredIfOld.
@Test
public void testElectionVersionIsUpdatedOnElectionFromSelfAndProperlyIgnoredIfOld() throws Exception {
final String coordinatorRole = "coordinator";
final InstanceId me = new InstanceId(1);
final InstanceId winner = new InstanceId(2);
HeartbeatContext heartbeatContext = mock(HeartbeatContext.class);
when(heartbeatContext.getFailed()).thenReturn(Collections.<InstanceId>emptySet());
Config config = mock(Config.class);
when(config.get(ClusterSettings.max_acceptors)).thenReturn(10);
MultiPaxosContext multiPaxosContext = new MultiPaxosContext(me, Iterables.<ElectionRole, ElectionRole>iterable(new ElectionRole(coordinatorRole)), mock(ClusterConfiguration.class), 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);
ClusterContext context = multiPaxosContext.getClusterContext();
ElectionContext electionContext = multiPaxosContext.getElectionContext();
ClusterListener listener = mock(ClusterListener.class);
context.addClusterListener(listener);
electionContext.forgetElection(coordinatorRole);
long expectedVersion = electionContext.newConfigurationStateChange().getVersion();
context.elected(coordinatorRole, winner, me, expectedVersion);
assertEquals(1, expectedVersion);
verify(listener, times(1)).elected(coordinatorRole, winner, null);
electionContext.forgetElection(coordinatorRole);
expectedVersion = electionContext.newConfigurationStateChange().getVersion();
context.elected(coordinatorRole, winner, me, expectedVersion);
assertEquals(2, expectedVersion);
verify(listener, times(2)).elected(coordinatorRole, winner, null);
context.elected(coordinatorRole, winner, me, expectedVersion - 1);
verifyNoMoreInteractions(listener);
}
use of org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext in project neo4j by neo4j.
the class ClusterContextTest method testElectionVersionIsUpdatedOnElectionFromOtherAndIgnoredIfOld.
@Test
public void testElectionVersionIsUpdatedOnElectionFromOtherAndIgnoredIfOld() throws Exception {
final String coordinatorRole = "coordinator";
final InstanceId me = new InstanceId(1);
final InstanceId winner = new InstanceId(2);
final InstanceId elector = new InstanceId(2);
HeartbeatContext heartbeatContext = mock(HeartbeatContext.class);
when(heartbeatContext.getFailed()).thenReturn(Collections.<InstanceId>emptySet());
Config config = mock(Config.class);
when(config.get(ClusterSettings.max_acceptors)).thenReturn(10);
MultiPaxosContext multiPaxosContext = new MultiPaxosContext(me, Iterables.<ElectionRole, ElectionRole>iterable(new ElectionRole(coordinatorRole)), mock(ClusterConfiguration.class), 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);
ClusterContext context = multiPaxosContext.getClusterContext();
ClusterListener listener = mock(ClusterListener.class);
context.addClusterListener(listener);
context.elected(coordinatorRole, winner, elector, 2);
verify(listener, times(1)).elected(coordinatorRole, winner, null);
context.elected(coordinatorRole, winner, elector, 3);
verify(listener, times(2)).elected(coordinatorRole, winner, null);
context.elected(coordinatorRole, winner, elector, 2);
verifyNoMoreInteractions(listener);
}
use of org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext in project neo4j by neo4j.
the class HeartbeatStateTest method shouldAddInstanceIdHeaderInCatchUpMessages.
@Test
public void shouldAddInstanceIdHeaderInCatchUpMessages() throws Throwable {
// Given
InstanceId instanceId = new InstanceId(1);
HeartbeatState heartbeat = HeartbeatState.heartbeat;
ClusterConfiguration configuration = new ClusterConfiguration("whatever", NullLogProvider.getInstance(), "cluster://1", "cluster://2");
configuration.joined(instanceId, URI.create("cluster://1"));
InstanceId otherInstance = new InstanceId(2);
configuration.joined(otherInstance, URI.create("cluster://2"));
Config config = mock(Config.class);
when(config.get(ClusterSettings.max_acceptors)).thenReturn(10);
MultiPaxosContext context = new MultiPaxosContext(instanceId, 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);
int lastDeliveredInstanceId = 100;
context.getLearnerContext().setLastDeliveredInstanceId(lastDeliveredInstanceId);
// This gap will trigger the catchUp message that we'll test against
lastDeliveredInstanceId += 20;
HeartbeatContext heartbeatContext = context.getHeartbeatContext();
Message received = Message.internal(HeartbeatMessage.i_am_alive, new HeartbeatMessage.IAmAliveState(otherInstance));
received.setHeader(Message.FROM, "cluster://2").setHeader(Message.INSTANCE_ID, "2").setHeader("last-learned", Integer.toString(lastDeliveredInstanceId));
// When
MessageHolder holder = mock(MessageHolder.class);
heartbeat.handle(heartbeatContext, received, holder);
// Then
verify(holder, times(1)).offer(Matchers.argThat(new MessageArgumentMatcher<LearnerMessage>().onMessageType(LearnerMessage.catchUp).withHeader(Message.INSTANCE_ID, "2")));
}
use of org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext in project neo4j by neo4j.
the class LearnerContextTest method shouldOnlyAllowHigherLastLearnedInstanceId.
@Test
public void shouldOnlyAllowHigherLastLearnedInstanceId() throws Exception {
// Given
Config config = mock(Config.class);
when(config.get(ClusterSettings.max_acceptors)).thenReturn(10);
MultiPaxosContext mpCtx = new MultiPaxosContext(null, Iterables.<ElectionRole>empty(), mock(ClusterConfiguration.class), null, NullLogProvider.getInstance(), null, null, null, null, null, config);
LearnerContext state = mpCtx.getLearnerContext();
// When
state.setLastKnownLearnedInstanceInCluster(1, new InstanceId(2));
state.setLastKnownLearnedInstanceInCluster(0, new InstanceId(3));
// Then
assertThat(state.getLastKnownLearnedInstanceInCluster(), equalTo(1L));
}
use of org.neo4j.cluster.protocol.atomicbroadcast.multipaxos.context.MultiPaxosContext in project neo4j by neo4j.
the class LearnerContextTest method settingLastLearnedInstanceToNegativeOneShouldAlwaysWin.
@Test
public void settingLastLearnedInstanceToNegativeOneShouldAlwaysWin() throws Exception {
// Given
Config config = mock(Config.class);
when(config.get(ClusterSettings.max_acceptors)).thenReturn(10);
MultiPaxosContext mpCtx = new MultiPaxosContext(null, Iterables.<ElectionRole>empty(), mock(ClusterConfiguration.class), null, NullLogProvider.getInstance(), null, null, null, null, null, config);
LearnerContext state = mpCtx.getLearnerContext();
// When
state.setLastKnownLearnedInstanceInCluster(1, new InstanceId(2));
state.setLastKnownLearnedInstanceInCluster(-1, null);
// Then
assertThat(state.getLastKnownLearnedInstanceInCluster(), equalTo(-1L));
assertThat(state.getLastKnownAliveUpToDateInstance(), equalTo(new org.neo4j.cluster.InstanceId(2)));
}
Aggregations