コード例 #1
0
//JAVA TO C# CONVERTER TODO TASK: Most Java annotations will not have direct .NET equivalent attributes:
//ORIGINAL LINE: @Test public void instanceFailingShouldHaveItsVotesInvalidated()
        public virtual void InstanceFailingShouldHaveItsVotesInvalidated()
        {
            // Given
            const string role1           = "coordinator1";
            const string role2           = "coordinator2";
            InstanceId   me              = new InstanceId(1);
            InstanceId   failingInstance = new InstanceId(2);
            InstanceId   otherInstance   = new InstanceId(3);

            Config config = mock(typeof(Config));

            when(config.Get(ClusterSettings.max_acceptors)).thenReturn(10);

            ClusterConfiguration clusterConfiguration = mock(typeof(ClusterConfiguration));
            IList <InstanceId>   clusterMemberIds     = new LinkedList <InstanceId>();

            clusterMemberIds.Add(failingInstance);
            clusterMemberIds.Add(otherInstance);
            clusterMemberIds.Add(me);
            when(clusterConfiguration.MemberIds).thenReturn(clusterMemberIds);

            MultiPaxosContext context = new MultiPaxosContext(me, Iterables.iterable(new ElectionRole(role1), new ElectionRole(role2)), clusterConfiguration, ThreadStart.run, NullLogProvider.Instance, mock(typeof(ObjectInputStreamFactory)), mock(typeof(ObjectOutputStreamFactory)), mock(typeof(AcceptorInstanceStore)), mock(typeof(Timeouts)), mock(typeof(ElectionCredentialsProvider)), config);

            HeartbeatContext heartbeatContext = context.HeartbeatContext;
            ElectionContext  electionContext  = context.ElectionContext;

            electionContext.StartElectionProcess(role1);
            electionContext.StartElectionProcess(role2);

            electionContext.Voted(role1, failingInstance, mock(typeof(ElectionCredentials)), 2);
            electionContext.Voted(role2, failingInstance, mock(typeof(ElectionCredentials)), 2);

            electionContext.Voted(role1, otherInstance, mock(typeof(ElectionCredentials)), 2);
            electionContext.Voted(role2, otherInstance, mock(typeof(ElectionCredentials)), 2);

            heartbeatContext.Suspect(failingInstance);

            assertEquals(1, electionContext.GetVoteCount(role1));
            assertEquals(1, electionContext.GetVoteCount(role2));
        }
コード例 #2
0
//JAVA TO C# CONVERTER TODO TASK: Most Java annotations will not have direct .NET equivalent attributes:
//ORIGINAL LINE: @Test public void shouldSendAtomicBroadcastOnJoiningAClusterWithAnEstablishedCoordinator() throws Throwable
//JAVA TO C# CONVERTER WARNING: Method 'throws' clauses are not available in C#:
        public virtual void ShouldSendAtomicBroadcastOnJoiningAClusterWithAnEstablishedCoordinator()
        {
            // Given
            string     winnerURI = "some://winner";
            InstanceId winner    = new InstanceId(2);

//JAVA TO C# CONVERTER WARNING: The original Java variable was marked 'final':
//ORIGINAL LINE: final java.util.List<org.neo4j.cluster.com.message.Message<?>> messages = new java.util.ArrayList<>(1);
//JAVA TO C# CONVERTER WARNING: Java wildcard generics have no direct equivalent in .NET:
            IList <Message <object> > messages = new List <Message <object> >(1);
            MessageHolder             holder   = messages.add;
            ElectionCredentials       voteCredentialComparable = mock(typeof(ElectionCredentials));

            ElectionContext electionContext = mock(typeof(ElectionContext));

            when(electionContext.Voted(eq(COORDINATOR), eq(new InstanceId(1)), eq(voteCredentialComparable), anyLong())).thenReturn(true);
            when(electionContext.GetVoteCount(COORDINATOR)).thenReturn(3);
            when(electionContext.NeededVoteCount).thenReturn(3);
            when(electionContext.GetElectionWinner(COORDINATOR)).thenReturn(winner);

            when(electionContext.GetLog(any(typeof(Type)))).thenReturn(NullLog.Instance);
            VersionedConfigurationStateChange stateChange = mock(typeof(VersionedConfigurationStateChange));

            when(electionContext.NewConfigurationStateChange()).thenReturn(stateChange);

            when(electionContext.GetUriForId(winner)).thenReturn(URI.create(winnerURI));

            // When
            Message <ElectionMessage> votedMessage = Message.to(ElectionMessage.Voted, URI.create("some://instance"), new ElectionMessage.VotedData(COORDINATOR, new InstanceId(1), voteCredentialComparable));

            votedMessage.SetHeader(Message.HEADER_FROM, "some://other");

            election.handle(electionContext, votedMessage, holder);

            // Then
            assertEquals(1, messages.Count);
//JAVA TO C# CONVERTER WARNING: Java wildcard generics have no direct equivalent in .NET:
//ORIGINAL LINE: org.neo4j.cluster.com.message.Message<?> message = messages.get(0);
            Message <object> message = messages[0];

            assertEquals(AtomicBroadcastMessage.broadcast, message.MessageType);
        }
コード例 #3
0
//JAVA TO C# CONVERTER TODO TASK: Most Java annotations will not have direct .NET equivalent attributes:
//ORIGINAL LINE: @Test public void twoVotesFromSameInstanceForSameRoleShouldBeConsolidated()
        public virtual void TwoVotesFromSameInstanceForSameRoleShouldBeConsolidated()
        {
            // Given
            const string     coordinatorRole  = "coordinator";
            HeartbeatContext heartbeatContext = mock(typeof(HeartbeatContext));

            when(heartbeatContext.Failed).thenReturn(Collections.emptySet());

            IDictionary <InstanceId, URI> members = new Dictionary <InstanceId, URI>();

            members[new InstanceId(1)] = URI.create("server1");
            members[new InstanceId(2)] = URI.create("server2");
            members[new InstanceId(3)] = URI.create("server3");

            Config config = mock(typeof(Config));

            when(config.Get(ClusterSettings.max_acceptors)).thenReturn(10);

            ClusterConfiguration clusterConfiguration = mock(typeof(ClusterConfiguration));

            when(clusterConfiguration.Members).thenReturn(members);

            ClusterContext clusterContext = mock(typeof(ClusterContext));

            when(clusterContext.Configuration).thenReturn(clusterConfiguration);

            MultiPaxosContext context = new MultiPaxosContext(new InstanceId(1), Iterables.iterable(new ElectionRole(coordinatorRole)), clusterConfiguration, mock(typeof(Executor)), NullLogProvider.Instance, mock(typeof(ObjectInputStreamFactory)), mock(typeof(ObjectOutputStreamFactory)), mock(typeof(AcceptorInstanceStore)), mock(typeof(Timeouts)), mock(typeof(ElectionCredentialsProvider)), config);

            ElectionContext toTest = context.ElectionContext;

            // When
            toTest.StartElectionProcess(coordinatorRole);
            toTest.Voted(coordinatorRole, new InstanceId(1), new IntegerElectionCredentials(100), Org.Neo4j.cluster.protocol.cluster.ClusterContext_Fields.NO_ELECTOR_VERSION);
            toTest.Voted(coordinatorRole, new InstanceId(2), new IntegerElectionCredentials(100), Org.Neo4j.cluster.protocol.cluster.ClusterContext_Fields.NO_ELECTOR_VERSION);
            toTest.Voted(coordinatorRole, new InstanceId(2), new IntegerElectionCredentials(101), Org.Neo4j.cluster.protocol.cluster.ClusterContext_Fields.NO_ELECTOR_VERSION);

            // Then
            assertNull(toTest.GetElectionWinner(coordinatorRole));
            assertEquals(2, toTest.GetVoteCount(coordinatorRole));
        }
コード例 #4
0
//JAVA TO C# CONVERTER TODO TASK: Most Java annotations will not have direct .NET equivalent attributes:
//ORIGINAL LINE: @Test public void electionCompletingMakesItBeForgotten() throws Throwable
//JAVA TO C# CONVERTER WARNING: Method 'throws' clauses are not available in C#:
        public virtual void ElectionCompletingMakesItBeForgotten()
        {
            // Given
            string              coordinatorRole          = "coordinator";
            InstanceId          votingInstance           = new InstanceId(2);
            ElectionCredentials voteCredentialComparable = mock(typeof(ElectionCredentials));

            ElectionContext context = mock(typeof(ElectionContext));

            when(context.GetLog(Mockito.any())).thenReturn(NullLog.Instance);
            when(context.NeededVoteCount).thenReturn(3);
            when(context.GetVoteCount(coordinatorRole)).thenReturn(3);
            when(context.Voted(coordinatorRole, votingInstance, voteCredentialComparable, 4)).thenReturn(true);
            MessageHolder holder = mock(typeof(MessageHolder));

            Message <ElectionMessage> vote = Message.to(ElectionMessage.Voted, URI.create("cluster://elector"), new ElectionMessage.VersionedVotedData(coordinatorRole, votingInstance, voteCredentialComparable, 4));

            // When
            election.handle(context, vote, holder);

            // Then
            verify(context, times(1)).forgetElection(coordinatorRole);
        }