コード例 #1
0
		public void CanSendRequestVotesAndGetReply()
		{
			using (var node2Transport = new HttpTransport("node2"))
			{
				var node1 = new NodeConnectionInfo { Name = "node1", Uri = new Uri("http://localhost:9079") };
				node2Transport.Send(node1, new RequestVoteRequest
				{
					TrialOnly = true,
					From = "node2",
					ClusterTopologyId = new Guid("355a589b-cadc-463d-a515-5add2ea47205"),
					Term = 3,
					LastLogIndex = 2,
					LastLogTerm = 2,
				});

				MessageContext context;
				var gotIt = node2Transport.TryReceiveMessage(_timeout, CancellationToken.None, out context);

				Assert.True(gotIt);

				Assert.True(context.Message is RequestVoteResponse);
			}
		}
コード例 #2
0
ファイル: HttpTransportPingTest.cs プロジェクト: eqr/Rachis
        public void CanAskIfCanInstallSnapshot()
        {
            using (var node2Transport = new HttpTransport("node2"))
            {
                var node1 = new NodeConnectionInfo { Name = "node1", Uri = new Uri("http://localhost:9079") };

                node2Transport.Send(node1, new CanInstallSnapshotRequest
                {
                    From = "node2",
                    ClusterTopologyId = new Guid("355a589b-cadc-463d-a515-5add2ea47205"),
                    Term = 2,
                    Index = 3,
                });

                MessageContext context;
                var gotIt = node2Transport.TryReceiveMessage(_timeout, CancellationToken.None, out context);

                Assert.True(gotIt);
                var msg = (CanInstallSnapshotResponse)context.Message;
                Assert.True(msg.Success);
            }
        }
コード例 #3
0
ファイル: HttpTransportPingTest.cs プロジェクト: eqr/Rachis
        public void CanSendTimeoutNow()
        {
            using (var node2Transport = new HttpTransport("node2"))
            {
                var node1 = new NodeConnectionInfo { Name = "node1", Uri = new Uri("http://localhost:9079") };
                node2Transport.Send(node1, new AppendEntriesRequest
                {
                    From = "node2",
                    ClusterTopologyId = new Guid("355a589b-cadc-463d-a515-5add2ea47205"),
                    Term = 2,
                    PrevLogIndex = 0,
                    PrevLogTerm = 0,
                    LeaderCommit = 1,
                    Entries = new[]
                    {
                        new LogEntry
                        {
                            Term = 2,
                            Index = 1,
                            Data = new JsonCommandSerializer().Serialize(new DictionaryCommand.Set
                            {
                                Key = "a",
                                Value = 2
                            })
                        },
                    }
                });
                MessageContext context;
                var gotIt = node2Transport.TryReceiveMessage(_timeout, CancellationToken.None, out context);

                Assert.True(gotIt);
                Assert.True(((AppendEntriesResponse)context.Message).Success);

                var mres = new ManualResetEventSlim();
                _raftEngine.StateChanged += state =>
                {
                    if (state == RaftEngineState.CandidateByRequest)
                        mres.Set();
                };

                node2Transport.Send(node1, new TimeoutNowRequest
                {
                    Term = 4,
                    From = "node2",
                    ClusterTopologyId = new Guid("355a589b-cadc-463d-a515-5add2ea47205"),
                });

                gotIt = node2Transport.TryReceiveMessage(_timeout, CancellationToken.None, out context);

                Assert.True(gotIt);

                Assert.True(context.Message is NothingToDo);

                Assert.True(mres.Wait(_timeout));
            }
        }
コード例 #4
0
ファイル: HttpTransportPingTest.cs プロジェクト: eqr/Rachis
        public void CanSendEntries()
        {
            using (var node2Transport = new HttpTransport("node2"))
            {
                var node1 = new NodeConnectionInfo { Name = "node1", Uri = new Uri("http://localhost:9079") };

                node2Transport.Send(node1, new AppendEntriesRequest
                {
                    From = "node2",
                    ClusterTopologyId = new Guid("355a589b-cadc-463d-a515-5add2ea47205"),
                    Term = 2,
                    PrevLogIndex = 0,
                    PrevLogTerm = 0,
                    LeaderCommit = 1,
                    Entries = new LogEntry[]
                    {
                        new LogEntry
                        {
                            Term = 2,
                            Index = 1,
                            Data = new JsonCommandSerializer().Serialize(new DictionaryCommand.Set
                            {
                                Key = "a",
                                Value = 2
                            })
                        },
                    }
                });

                MessageContext context;
                var gotIt = node2Transport.TryReceiveMessage(_timeout, CancellationToken.None, out context);

                Assert.True(gotIt);

                var appendEntriesResponse = (AppendEntriesResponse)context.Message;
                Assert.True(appendEntriesResponse.Success);

                Assert.Equal(2, ((DictionaryStateMachine)_raftEngine.StateMachine).Data["a"]);
            }
        }
コード例 #5
0
ファイル: HttpTransportPingTest.cs プロジェクト: eqr/Rachis
        public void CanInstallSnapshot()
        {
            using (var node2Transport = new HttpTransport("node2"))
            {
                var node1 = new NodeConnectionInfo { Name = "node1", Uri = new Uri("http://localhost:9079") };

                node2Transport.Send(node1, new CanInstallSnapshotRequest
                {
                    From = "node2",
                    ClusterTopologyId = new Guid("355a589b-cadc-463d-a515-5add2ea47205"),
                    Term = 2,
                    Index = 3,
                });

                MessageContext context;
                var gotIt = node2Transport.TryReceiveMessage(_timeout, CancellationToken.None, out context);
                Assert.True(gotIt);
                Assert.True(context.Message is CanInstallSnapshotResponse);

                node2Transport.Stream(node1, new InstallSnapshotRequest
                {
                    From = "node2",
                    ClusterTopologyId = new Guid("355a589b-cadc-463d-a515-5add2ea47205"),
                    Term = 2,
                    Topology = new Topology(new Guid("355a589b-cadc-463d-a515-5add2ea47205")),
                    LastIncludedIndex = 2,
                    LastIncludedTerm = 2,
                }, stream =>
                {
                    var streamWriter = new StreamWriter(stream);
                    var data = new Dictionary<string, int> { { "a", 2 } };
                    new JsonSerializer().Serialize(streamWriter, data);
                    streamWriter.Flush();
                });

                gotIt = node2Transport.TryReceiveMessage(_timeout, CancellationToken.None, out context);

                Assert.True(gotIt);

                var appendEntriesResponse = (InstallSnapshotResponse)context.Message;
                Assert.True(appendEntriesResponse.Success);

                Assert.Equal(2, ((DictionaryStateMachine)_raftEngine.StateMachine).Data["a"]);
            }
        }