Giter Site home page Giter Site logo

helios's People

Contributors

aaronontheweb avatar gitter-badger avatar jeoffman avatar jordansjones avatar sean-gilliam avatar stefansedich avatar

Stargazers

 avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar

Watchers

 avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar  avatar

helios's Issues

Wrong tcp packet content ?

Hi,

I've discovered your work when I was looking for a framework to manage TCP transport on my application.

Using TimeService example I've created a small program which send data over tcp

Here the code of the startup:

            var host = IPAddress.Parse("192.168.0.72");
            var port = 7000;
            var bootstrapper = new ClientBootstrap().SetTransport(TransportType.Tcp).Build();

            client = bootstrapper.NewConnection(Node.Empty(), NodeBuilder.BuildNode().Host(host).WithPort(port));
            client.OnConnection += (address, connection) =>
            {
                Console.WriteLine("Confirmed connection with host.");
                connection.BeginReceive(ReceivedCallback);
            };
            client.OnDisconnection += (address, reason) => Console.WriteLine("Disconnected.");
            LoopConnect();
            Write();

and here concerning the Write method:

            var command = Encoding.ASCII.GetBytes("TEST");
            _client.Send(command, 0, command.Length, new EmptyNode());

My server receive the message. but with invalid characters at the beginning.
I've checked using wireshark the communication and the sent contains invalid chars at the beginning.

Here the Content in hex for my "TEST" message
04:00:00:00:54:45:53:54

How can I fix it ?

Thanks in advance !

After Connection Double Disconnection

I'm trying since 2 days figure out to use Helios.
But with poor examples and no documentation i'm really bored why isn't working properly.

I choosed Helios because the good reputation of this library, that is now annyoing me.

I'm using Server Reactor that listens TCP Connections in Port 3000, from the Game Client. (The client does the first Connection).
After the Connection is Handled the Server need wait the Client Send the Initial Packet (The HandShake).

But nothing appears on Console. (I created Logging Messages, for onreceive, send, onconnection and ondisconnection)

After some seconds, appears two times a Disconnection Message. Where the Reason is "Closed".

Why two messages if exists only one Connection?
Also if i try direct sending data to Client, also connection is immediatelly closed.

With my old Socket System using TCPListener (that was a crap) everything was working. Helios is really more pretty and easy to use.

But i can't understand what the hell is happening.

Helios never goes to BeginReceive? (The Callback shows message).

That really annoying me.
Observation: The Messages from Client to Server are encoded in RC4, that the OnReceive void calls my RC4 Library for Decrypting.

Why that doesn't work?

The github repository with the code is: https://github.com/sant0ro/Yupi/tree/nio
Branch: nio
Folder: Yupi/Net/Connection/

Thanks in advance.

The unhandled exception in akka.net framework from mono

I am using akka.net framework for building actor model. I caught next unhandled exception

System.NullReferenceException: Object reference not set to an instance of an object
at Helios.Concurrency.DedicatedThreadPool+ThreadPoolWorkQueue+d__9.MoveNext () [0x00000] in :0
at Helios.Concurrency.DedicatedThreadPool+PoolWorker.RunThread () [0x00000] in :0
at System.Threading.Thread.StartInternal () [0x00000] in :0

Linux version 4.2.0-42-generic (buildd@lgw01-55) (gcc version 4.8.4 (Ubuntu 4.8.4-2ubuntu114.04.3) ) #4914.04.1-Ubuntu SMP Wed Jun 29 20:22:11 UTC 2016

Mono version 4.0.5.1

TcpConnection.SendInternal throws NullReferenceException on Send if disconnected

If one sends a message from helios to a server and then the server disconnects (this triggers TcpConnection.Close() causing _client to become null), then helios tries to send another message with the same connection. The if statement in SendInternal will throw a NullReferenceException because the _client is null, this if statement should check that the client is null before checking if it is not connected.

protected override void SendInternal(byte[] buffer, int index, int length, INode destination)
{
try
{
if (WasDisposed || !_client.Connected)
{
Close();
return;
}

Helios TCP data loss

We've been able to reproduce via Unit Test and CI server this issue many times now - there's a race condition where valid messages are discarded. In all likelihood by the LengthFrameDecoder or the receive / send buffer itself.

This is a critical bug and is the next major item on my to-do list now that Akka.NET's major changeset is wrapped for v1.0.

Rewrite socket primitives for clients and reactors

Related to #11

Once Akka.NET V1.0 ships (Thursday!) I'm going to begin publishing the specs for Helios 2.0.

One of the biggest areas where we will need community involvement is rewriting the socket primitives. There's a lot of unnecessary code repetition and leaky abstractions all over the place, but more importantly - we need to have a discussion on how to get the best performance offered via the CLR.

So I'll encourage everyone to read this http://stackoverflow.com/questions/3442344/c-sharp-high-performance-server and #11.

Everything's on the table for Helios 2.0.

Helios 2.0 manifesto

Now that I'm not under as much insane deadline pressure as I was during the first year of Helios, it's time to go back and do things right.

Goals

Helios 2.0 will have the following goals:

  1. Helios will be easy to understand and use.
  2. Helios will be singularly focused on doing one thing well: writing reactive, networked applications in .NET 3.5 / 4.0 / 4.5.
  3. Helios will more closely follow the Netty project's architecture and design goals. It won't ever match 1:1 with Netty, but we will borrow from their years of experience and astonishing success in equivalent JVM applications.
  4. Helios will include full documentation and tutorials.

Roadmap

We intend to accomplish these goals in the following steps:

  1. Remove everything from Helios that is currently not used or not relevant to this roadmap. House-cleaning.
  2. Provide clear specs for how new moving parts are supposed to work under Helios 2.0 - i.e. how do I add a step in the request processing pipeline? and so forth.
  3. Redesign and re-implement existing functionality in order to support specs.
  4. Provide integration and access points for enterprise concerns, such as monitoring and logging.

[Question] Status vs DotNetty

Hi, Aaron

I am a bit confused with the big bold text that recommends using DotNetty, but this project has more commits, is more active recently and has a real-world example of Akka.NET. The notice was added on Feb 28, so it is quite recent and it look like this project is still hot.

I am quite comfortable with internals of NetMq, but I need certain customization at low level and do not need all the functionality of 0MQ product family, so I am looking for a stable alternative. What should I use - helios or DotNetty for potential new development? Is DotNetty near stable with its v.0.3?

Thanks!

Can/Should Helios be used to create a UDP server ?

First, should Helios be used to do the above (I think so)? My intention is to understand if I have the right tool for my job before I begin exploring this.I do understand that the documentation will come soon esp. around Reactors.

got a System.OutOfMemoryException

i'm interest in helios. but i got a System.OutOfMemoryException when i ran TimeService example on single local machine. sorry i can't support the stacktrace info, but below is the method throw this exception (it's in helios-1.4.1\src\Helios\Concurrency\Impl\DedicatedThreadPoolFiber.cs):

public void Add(Action op)
{
     if (Running)
         _threadPool.QueueUserWorkItem(() => Executor.Execute(op));
}

os: window 7 ultimate 64 bit
memory: 16g

Prefer using XXXXAsync Socket Methods

Looking through the code base of Helios, I was wondering why did you prefer to use APM socket abstractions in order to perform tcp communication in Helios? The traditional Begin/End async methods on high performance network applications (like Akka) can cause increased garbage collection due to memory thrashing when servers have many connections or when they are receiving large amounts of data.

The most performant communication abstractions for TCP available in .NET nowadays is EAP - XXXAsync methods (ConnectAsync, ReceiveAsync, SendAsync etc) which, when used with buffer pooling, they reduce considerably GC work and therefore increase the overall performance of the application.

The System.Net.Sockets.Socket class has been enhanced in Version 3.5 for use by applications that use asynchronous network I/O to achieve the highest performance. A series of new classes have been added as part of a set of enhancements to the Socket class that provide an alternative asynchronous pattern that can be used by specialized high-performance socket applications. These enhancements were specifically designed for network server applications that require high performance. An application can use the enhanced asynchronous pattern exclusively, or only in targeted hot areas of their application (when receiving large amounts of data, for example).

https://msdn.microsoft.com/en-us/library/bb968780.aspx

NRE on starting TcpClient.BeginReceive

image

Hilarious race condition with this code...

 protected void StartClient()
        {
            if (!_server.IsOpen()) throw new HeliosException("Server is not started yet. Cannot start client yet.");
            _client = _clientConnectionFactory.NewConnection(_server.Local);
            _client.Receive += (data, channel) =>
            {
                if (!HighPerformance)
                {
                    ClientReceiveBuffer.Add(data);
                }
                ClientReceived.GetAndIncrement();
            };
            _client.OnConnection += (address, channel) => channel.BeginReceive();
            _client.OnError += (exception, connection) => _clientExecutor.Exceptions.Add(exception);
            _client.Open();
        }

While the _client.Open() call is still being executed, the _client.OnConnection event fires and channel.BeginReceive() fires before _client.Open() has a chance to finished.

All things considered, how about removing obsolete flag from legacy Helios 1.x APIs?

As we know, further development of Helios is discontinued in favor of DotNetty. With this in mind a strong recommendation is given that newcomers to Helios try DotNetty instead. However, it seems that the most common scenarios where Helios might still be used going forward, if this advice is followed, will involve legacy code bases that were originally developed for the 1.x APIs, or hacking on the sample code, which is largely based on the legacy APIs, or other simple cases where Helios 1.x Reactors may be well suited.

This leads to a strange situation where, in one of the most common situations where Helios is likely to be used, I get deprecation warnings at build time. If the newer 2.x APIs are used, in some ways it feels like a larger risk due to the shorter history and more limited documentation / samples and there would seem to be a stronger case for choosing DotNetty instead, but there is no warning about it.

Considering how this has transpired, what about removing the deprecation warnings, so that the 1.x APIs are no longer differentiated as obsolete and are once again on the same footing as the 2.x APIs? (Otherwise I could continue using Helios 1.4.2, but then will not benefit from more recent bug fixes.)

Unexpected bytes in ByteBuffer of a TCP connection

Hello,

I'm trying to utilize Helios in my application to get rid of performance limitations of the former native .Net TcpClient/UdpClient based implementation when connecting with a lot of remote devices. Setting up the TCP connection worked after some try and error.

I've wrote a custom MessageDecoder implementation to reflect our protocol. however, at some point i always get malformed/unexpected bytes in the stream.
Sometimes the data looks like the devices UDP discovery broadcast. Sometimes it could be DHCP discover broadcast messages. But how could they end up in the TCP stream?

I've seen in the LengthFieldFrameBasedDecoder there is a mechanism for discarding too long frames. Is tat intended to fix the behavior, I've discovered?

Edit:
I'm using Helios 1.4.0 from NuGet

Edit 2 relevant code:

public class MessageDecoder : MessageDecoderBase
{
    readonly int headerLength = Marshal.SizeOf(typeof(BaseMessage));
    public MessageDecoder()
    { }

    public override void Decode(Helios.Net.IConnection connection, Helios.Buffers.IByteBuf buffer, out List<Helios.Buffers.IByteBuf> decoded)
    {
        decoded = new List<Helios.Buffers.IByteBuf>();
        byte[] bytesHeader = new byte[headerLength];
        BaseMessage header = StructInitializer<BaseMessage>.ByteArrayToStruct(bytesHeader);

        if (buffer.ReadableBytes >= headerLength)
        {
            buffer.GetBytes(0, bytesHeader, 0, headerLength);
            header = StructInitializer<BaseMessage>.ByteArrayToStruct(bytesHeader);
        }
        else
        {
            return;
        }

        // header is valid?
        if (header.IsValid)
        {
            if (buffer.ReadableBytes >= (int)(headerLength + header.DataLength))
            {
                var message = buffer.ReadBytes((int)(headerLength + header.DataLength));
                decoded.Add(message);
            }
        else
        {
            // If this happens, the connections is essentially broken
            // It seems as no more data is passed to the decoder, however the connection is still alive and data gets transmitted
            buffer.SkipBytes(buffer.ReadableBytes);
        }
    }

    public override IMessageDecoder Clone()
    {
        return new MessageDecoder();
    }
}


public static class ConnectionManager
{
    static ClientBootstrap _heliosBootstrapper;
    static IConnectionFactory _tcpConnectionFactory;

    static ServerBootstrap _heliosBroadcastBootstrapper;
    static IConnectionFactory _udpConnectionFactory;

    static ConnectionManager()
    {       
        _heliosBootstrapper = new ClientBootstrap();
        _tcpConnectionFactory = _heliosBootstrapper
            .WorkerThreads(1)
            .SetOption("connectTimeout", TimeSpan.FromMilliseconds(ConnectTimeout))
            .SetTransport(TransportType.Tcp)
            .SetEncoder(new NoOpEncoder())
            .SetDecoder(new MessageDecoder())
            .Build();

        _heliosBroadcastBootstrapper = new ServerBootstrap();
        _udpConnectionFactory = _heliosBootstrapper
            .WorkerThreads(1)
            .SetTransport(TransportType.Udp)
            .SetEncoder(new NoOpEncoder())
            .SetDecoder(new NoOpDecoder())              
            .Build();
    }

    public static void EnableDeviceConnections()
    {
        // Enabling broadcast from devices. Unconnected devices will be connected afterwards by ConnectDevice() in the BroadcastRecieved event handler
        var node = NodeBuilder.BuildNode().WithPort(UdpBroadcastPort).Host(IPAddress.Any);
        var local = NodeBuilder.BuildNode().Host(IPAddress.Any).WithPort(UdpBroadcastPort);
        //NormalConnectionBuilder builder = new NormalConnectionBuilder();
        var broadreciever = _udpConnectionFactory.NewConnection(local, node);
        broadreciever.Receive += broadreciever_Receive;
        broadreciever.OnConnection += broadreciever_OnConnection;
        broadreciever.OnError += broadreciever_OnError;
        broadreciever.OnDisconnection += broadreciever_OnDisconnection;
        broadreciever.Open();
        broadreciever.BeginReceive();
    }

    static void broadreciever_OnDisconnection(Helios.Exceptions.HeliosConnectionException reason, IConnection closedChannel)
    {

    }

    static void broadreciever_OnError(Exception ex, IConnection connection)
    {

    }

    static void broadreciever_OnConnection(INode remoteAddress, IConnection responseChannel)
    {
    }

    static void broadreciever_Receive(NetworkData incomingData, IConnection responseChannel)
    {
        var broadcast = StructInitializer<BroadcastStruct>.ByteArrayToStruct(incomingData.Buffer);
        if(BroadcastRecieved != null)
            BroadcastRecieved(broadcast);
    }

    public static event EventHandler<BroadcastStruct> SiplugBroadcastRecieved;

    public void ConnectDevice(IPAddress device)
    {
        var node = Helios.Topology.NodeBuilder.BuildNode();
        node.Host = device;
        node.Port = TcpDataPort;
        var connection = _tcpConnectionFactory.NewConnection(node);
        connection.Receive += connection_Receive;
        connection.OnError += connection_OnError;
        connection.OnDisconnection += connection_OnDisconnection;
        connection.OnConnection += connection_OnConnection;
        var connected = await connection.OpenAsync();
    }
}

Akka remote no long behaves correctly with 1.4.2 version of helios

I got a client actor which sends to a server actor through remote. If I killed the server actor, client keeps trying to send message in 1.4.1. As soon as server actor came back online, server actor can successfully process the incoming message. However, in 1.4.2. version of Helios, it no longer works.

client actor:

class Program
{
    static void Main(string[] args)
    {
        var loggerBuilder =
            new LoggerConfiguration()
                .WriteTo.RollingFile(@"c:\Logs\AkkaRemote\Client-{Date}.log", LogEventLevel.Debug)
                .MinimumLevel.Debug();

        Log.Logger = loggerBuilder.CreateLogger();

        var clientActorSystem = ActorSystem.Create("client");
        var clientActor = clientActorSystem.ActorOf(Props.Create(() => new ClientActor()), "client-actor");

        clientActorSystem.Scheduler.ScheduleTellRepeatedly(TimeSpan.FromSeconds(5),
            TimeSpan.FromSeconds(1),
            clientActor,
            new ConnectTo("akka.tcp://[email protected]:14800"),
            ActorRefs.Nobody);

        Console.ReadLine();

        clientActorSystem.Terminate().Wait();
    }
}

public class ConnectTo
{
    public Guid Id { get; }

    public string Address { get; }

    public ConnectTo(string address)
    {
        Id = Guid.NewGuid();
        Address = address;
    }
}

public class ClientActor : ReceiveActor
{
    public ClientActor()
    {
        Receive<ConnectTo>(msg =>
        {
            var address = $"{msg.Address}/user/connect";

            var remote = Context.ActorSelection(address);

            remote.Tell($"Message {msg.Id} trying to connect to {msg.Address}");
        });
    }

    protected override void Unhandled(object message)
    {
        Context.GetLogger(new SerilogLogMessageFormatter()).Error("Unhandled message: {Message}", message);
    }
}

server actor:

class Program
{
    static void Main(string[] args)
    {
        var loggerBuilder =
            new LoggerConfiguration()
                .WriteTo.RollingFile(@"c:\Logs\AkkaRemote\server-{Date}.log", LogEventLevel.Debug)
                .MinimumLevel.Debug();

        Log.Logger = loggerBuilder.CreateLogger();

        var serverActorSystem = ActorSystem.Create("server");

        serverActorSystem.ActorOf(Props.Create(() => new ServerActor()), "connect");

        Console.ReadLine();

        serverActorSystem.Terminate().Wait();
    }
}

public class ServerActor : ReceiveActor
{
    public ServerActor()
    {
        Receive<string>(msg => Context.GetLogger(new SerilogLogMessageFormatter()).Info("Receive message: {Message}", msg));
    }
}

Start client, then server, and then shut down server (v.1.4.2):

client:

2016-02-09 09:37:16.703 +11:00 [Debug] "subscribing [akka://client/system/log1-SerilogLogger] to channel Akka.Event.Info"
2016-02-09 09:37:16.771 +11:00 [Debug] "subscribing [akka://client/system/log1-SerilogLogger] to channel Akka.Event.Warning"
2016-02-09 09:37:16.771 +11:00 [Debug] "subscribing [akka://client/system/log1-SerilogLogger] to channel Akka.Event.Error"
2016-02-09 09:37:16.771 +11:00 [Debug] "Logger log1-SerilogLogger [SerilogLogger] started"
2016-02-09 09:37:16.771 +11:00 [Debug] "subscribing [akka://client/system/UnhandledMessageForwarder] to channel Akka.Event.UnhandledMessage"
2016-02-09 09:37:16.771 +11:00 [Debug] "Started (Akka.Event.LoggingBus+UnhandledMessageForwarder)"
2016-02-09 09:37:16.771 +11:00 [Debug] "StandardOutLogger being removed"
2016-02-09 09:37:16.771 +11:00 [Debug] "now supervising akka://client/system/UnhandledMessageForwarder"
2016-02-09 09:37:16.771 +11:00 [Debug] "unsubscribing [akka://all-systems/] from all channels"
2016-02-09 09:37:16.772 +11:00 [Debug] "Default Loggers started"
2016-02-09 09:37:16.772 +11:00 [Debug] "now supervising akka://client/system/remoting-terminator"
2016-02-09 09:37:16.772 +11:00 [Debug] "now supervising akka://client/system/transports"
2016-02-09 09:37:16.772 +11:00 [Debug] "Started (Akka.Remote.TransportSupervisor)"
2016-02-09 09:37:16.772 +11:00 [Information] "Starting remoting"
2016-02-09 09:37:16.772 +11:00 [Debug] "now supervising akka://client/system/endpointManager"
2016-02-09 09:37:16.775 +11:00 [Debug] "Started (Akka.Remote.RemoteActorRefProvider+RemotingTerminator)"
2016-02-09 09:37:16.779 +11:00 [Debug] "Starting prune timer for endpoint manager..."
2016-02-09 09:37:16.779 +11:00 [Debug] "Started (Akka.Remote.EndpointManager)"
2016-02-09 09:37:16.790 +11:00 [Debug] "now watched by [akka://client/system]"
2016-02-09 09:37:16.889 +11:00 [Debug] "Started (Akka.Remote.Transport.AkkaProtocolManager)"
2016-02-09 09:37:16.892 +11:00 [Debug] "now supervising akka://client/system/transports/akkaprotocolmanager.tcp.0"
2016-02-09 09:37:16.904 +11:00 [Information] Remoting started; listening on addresses : ["akka.tcp://[email protected]:57846"]
2016-02-09 09:37:16.907 +11:00 [Information] "Remoting now listens on addresses: [akka.tcp://[email protected]:57846]"
2016-02-09 09:37:16.922 +11:00 [Debug] "Started (Akka.Remote.RemoteWatcher)"
2016-02-09 09:37:16.924 +11:00 [Warning] "{
  akka : {
    log-config-on-start : on
    stdout-loglevel : DEBUG
    loglevel : DEBUG
    loggers : [\"Akka.Logger.Serilog.SerilogLogger, Akka.Logger.Serilog\"]
    actor : {
      debug : {
        receive : on
        autoreceive : on
        lifecycle : on
        event-stream : on
        unhandled : on
      }
      provider : \"Akka.Remote.RemoteActorRefProvider, Akka.Remote\"
    }
    remote : {
      log-remote-lifecycle-events : DEBUG
      log-received-messages : on
      log-sent-messages : on
      helios : {
        tcp : {
          hostname : 127.0.0.1
          port : 0
        }
      }
    }
  }
}"
2016-02-09 09:37:16.924 +11:00 [Debug] "Started (Akka.Remote.RemoteDeploymentWatcher)"
2016-02-09 09:37:16.924 +11:00 [Debug] "now supervising akka://client/system/remote-watcher"
2016-02-09 09:37:16.924 +11:00 [Debug] "now supervising akka://client/system/remote-deployment-watcher"
2016-02-09 09:37:16.924 +11:00 [Debug] "now supervising akka://client/system/deadLetterListener"
2016-02-09 09:37:16.924 +11:00 [Debug] "now supervising akka://client/system/EventStreamUnsubscriber-1"
2016-02-09 09:37:16.924 +11:00 [Debug] "subscribing [akka://client/system/deadLetterListener] to channel Akka.Event.DeadLetter"
2016-02-09 09:37:16.924 +11:00 [Debug] "Started (Akka.Event.DeadLetterListener)"
2016-02-09 09:37:16.925 +11:00 [Debug] "registering unsubscriber with Akka.Event.EventStream"
2016-02-09 09:37:16.925 +11:00 [Debug] "Started (Akka.Event.EventStreamUnsubscriber)"
2016-02-09 09:37:16.928 +11:00 [Debug] "now supervising akka://client/user/client-actor"
2016-02-09 09:37:16.928 +11:00 [Debug] "Started (AkkaRemote.ClientActor)"
2016-02-09 09:37:21.994 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1"
2016-02-09 09:37:22.004 +11:00 [Debug] "Started (Akka.Remote.ReliableDeliverySupervisor)"
2016-02-09 09:37:22.004 +11:00 [Debug] "now watched by [akka://client/system/endpointManager]"
2016-02-09 09:37:22.005 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1/endpointWriter"
2016-02-09 09:37:22.006 +11:00 [Debug] "Started (Akka.Remote.EndpointWriter)"
2016-02-09 09:37:22.006 +11:00 [Debug] "now watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1]"
2016-02-09 09:37:22.012 +11:00 [Debug] "now supervising akka://client/system/transports/akkaprotocolmanager.tcp.0/akkaProtocol-tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1"
2016-02-09 09:37:23.053 +11:00 [Debug] "Started (Akka.Remote.Transport.ProtocolStateActor)"

server:

2016-02-09 09:37:38.164 +11:00 [Debug] "Logger log1-SerilogLogger [SerilogLogger] started"
2016-02-09 09:37:38.200 +11:00 [Debug] "StandardOutLogger being removed"
2016-02-09 09:37:38.200 +11:00 [Debug] "Default Loggers started"
2016-02-09 09:37:38.212 +11:00 [Information] "Starting remoting"
2016-02-09 09:37:38.227 +11:00 [Debug] "Starting prune timer for endpoint manager..."
2016-02-09 09:37:38.321 +11:00 [Information] Remoting started; listening on addresses : ["akka.tcp://[email protected]:14800"]
2016-02-09 09:37:38.325 +11:00 [Information] "Remoting now listens on addresses: [akka.tcp://[email protected]:14800]"
2016-02-09 09:37:38.334 +11:00 [Warning] "{
  akka : {
    log-config-on-start : on
    stdout-loglevel : DEBUG
    loglevel : DEBUG
    loggers : [\"Akka.Logger.Serilog.SerilogLogger, Akka.Logger.Serilog\"]
    actor : {
      provider : \"Akka.Remote.RemoteActorRefProvider, Akka.Remote\"
    }
    remote : {
      helios : {
        tcp : {
          hostname : 127.0.0.1
          port : 14800
        }
      }
    }
  }
}"

Start client then server, and then shut down server (v1.4.1):

client:

2016-02-09 09:32:16.304 +11:00 [Debug] "subscribing [akka://client/system/log1-SerilogLogger] to channel Akka.Event.Info"
2016-02-09 09:32:16.463 +11:00 [Debug] "subscribing [akka://client/system/log1-SerilogLogger] to channel Akka.Event.Warning"
2016-02-09 09:32:16.463 +11:00 [Debug] "subscribing [akka://client/system/log1-SerilogLogger] to channel Akka.Event.Error"
2016-02-09 09:32:16.463 +11:00 [Debug] "Logger log1-SerilogLogger [SerilogLogger] started"
2016-02-09 09:32:16.463 +11:00 [Debug] "subscribing [akka://client/system/UnhandledMessageForwarder] to channel Akka.Event.UnhandledMessage"
2016-02-09 09:32:16.463 +11:00 [Debug] "StandardOutLogger being removed"
2016-02-09 09:32:16.463 +11:00 [Debug] "unsubscribing [akka://all-systems/] from all channels"
2016-02-09 09:32:16.464 +11:00 [Debug] "now supervising akka://client/system/UnhandledMessageForwarder"
2016-02-09 09:32:16.464 +11:00 [Debug] "Started (Akka.Event.LoggingBus+UnhandledMessageForwarder)"
2016-02-09 09:32:16.464 +11:00 [Debug] "Default Loggers started"
2016-02-09 09:32:16.464 +11:00 [Debug] "now supervising akka://client/system/remoting-terminator"
2016-02-09 09:32:16.464 +11:00 [Debug] "now supervising akka://client/system/transports"
2016-02-09 09:32:16.466 +11:00 [Debug] "Started (Akka.Remote.TransportSupervisor)"
2016-02-09 09:32:16.484 +11:00 [Information] "Starting remoting"
2016-02-09 09:32:16.484 +11:00 [Debug] "now supervising akka://client/system/endpointManager"
2016-02-09 09:32:16.490 +11:00 [Debug] "Started (Akka.Remote.RemoteActorRefProvider+RemotingTerminator)"
2016-02-09 09:32:16.497 +11:00 [Debug] "now watched by [akka://client/system]"
2016-02-09 09:32:16.537 +11:00 [Debug] "Starting prune timer for endpoint manager..."
2016-02-09 09:32:16.537 +11:00 [Debug] "Started (Akka.Remote.EndpointManager)"
2016-02-09 09:32:16.612 +11:00 [Debug] "now supervising akka://client/system/transports/akkaprotocolmanager.tcp.0"
2016-02-09 09:32:16.614 +11:00 [Debug] "Started (Akka.Remote.Transport.AkkaProtocolManager)"
2016-02-09 09:32:16.623 +11:00 [Information] Remoting started; listening on addresses : ["akka.tcp://[email protected]:57445"]
2016-02-09 09:32:16.625 +11:00 [Information] "Remoting now listens on addresses: [akka.tcp://[email protected]:57445]"
2016-02-09 09:32:16.631 +11:00 [Debug] "Started (Akka.Remote.RemoteDeploymentWatcher)"
2016-02-09 09:32:16.631 +11:00 [Debug] "now supervising akka://client/system/remote-watcher"
2016-02-09 09:32:16.631 +11:00 [Debug] "now supervising akka://client/system/remote-deployment-watcher"
2016-02-09 09:32:16.634 +11:00 [Debug] "now supervising akka://client/system/deadLetterListener"
2016-02-09 09:32:16.634 +11:00 [Debug] "now supervising akka://client/system/EventStreamUnsubscriber-1"
2016-02-09 09:32:16.634 +11:00 [Debug] "subscribing [akka://client/system/deadLetterListener] to channel Akka.Event.DeadLetter"
2016-02-09 09:32:16.634 +11:00 [Debug] "Started (Akka.Event.DeadLetterListener)"
2016-02-09 09:32:16.634 +11:00 [Debug] "Started (Akka.Remote.RemoteWatcher)"
2016-02-09 09:32:16.634 +11:00 [Debug] "registering unsubscriber with Akka.Event.EventStream"
2016-02-09 09:32:16.634 +11:00 [Debug] "Started (Akka.Event.EventStreamUnsubscriber)"
2016-02-09 09:32:16.636 +11:00 [Warning] "{
  akka : {
    log-config-on-start : on
    stdout-loglevel : DEBUG
    loglevel : DEBUG
    loggers : [\"Akka.Logger.Serilog.SerilogLogger, Akka.Logger.Serilog\"]
    actor : {
      debug : {
        receive : on
        autoreceive : on
        lifecycle : on
        event-stream : on
        unhandled : on
      }
      provider : \"Akka.Remote.RemoteActorRefProvider, Akka.Remote\"
    }
    remote : {
      log-remote-lifecycle-events : DEBUG
      log-received-messages : on
      log-sent-messages : on
      helios : {
        tcp : {
          hostname : 127.0.0.1
          port : 0
        }
      }
    }
  }
}"
2016-02-09 09:32:16.637 +11:00 [Debug] "now supervising akka://client/user/client-actor"
2016-02-09 09:32:16.638 +11:00 [Debug] "Started (AkkaRemote.ClientActor)"
2016-02-09 09:32:21.715 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1"
2016-02-09 09:32:21.722 +11:00 [Debug] "Started (Akka.Remote.ReliableDeliverySupervisor)"
2016-02-09 09:32:21.722 +11:00 [Debug] "now watched by [akka://client/system/endpointManager]"
2016-02-09 09:32:21.722 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1/endpointWriter"
2016-02-09 09:32:21.725 +11:00 [Debug] "Started (Akka.Remote.EndpointWriter)"
2016-02-09 09:32:21.725 +11:00 [Debug] "now watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1]"
2016-02-09 09:32:21.730 +11:00 [Debug] "now supervising akka://client/system/transports/akkaprotocolmanager.tcp.0/akkaProtocol-tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1"
2016-02-09 09:32:22.756 +11:00 [Debug] "Started (Akka.Remote.Transport.ProtocolStateActor)"
2016-02-09 09:32:22.762 +11:00 [Warning] "AssociationError [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800: Error [Invalid address: akka.tcp://[email protected]:14800] []"
2016-02-09 09:32:22.774 +11:00 [Debug] "Stopped"
2016-02-09 09:32:22.783 +11:00 [Warning] Tried to associate with unreachable remote address ["akka.tcp://[email protected]:14800"]. Address is now gated for 5000 ms, all messages to this address will be delivered to dead letters. Reason: ["Invalid address: akka.tcp://[email protected]:14800"] "Caused by: [Akka.Remote.Transport.InvalidAssociationException: Association failure ---> Helios.Exceptions.HeliosConnectionException: No connection could be made because the target machine actively refused it 127.0.0.1:14800 ---> System.Net.Sockets.SocketException: No connection could be made because the target machine actively refused it 127.0.0.1:14800
   at System.Net.Sockets.Socket.EndConnect(IAsyncResult asyncResult)
   at Helios.Net.Connections.TcpConnection.Open()
   --- End of inner exception stack trace ---
   at Helios.Net.Connections.TcpConnection.Open()
   at Akka.Remote.Transport.Helios.CommonHandlers.Open()
   at Akka.Remote.Transport.Helios.HeliosTcpTransport.AssociateInternal(Address remoteAddress)
   at Akka.Remote.Transport.Helios.HeliosTransport.<Associate>d__27.MoveNext()
   --- End of inner exception stack trace ---]"
2016-02-09 09:32:22.784 +11:00 [Error] "Invalid address: akka.tcp://[email protected]:14800"
Akka.Remote.InvalidAssociation: Invalid address: akka.tcp://[email protected]:14800 ---> Akka.Remote.Transport.InvalidAssociationException: Association failure ---> Helios.Exceptions.HeliosConnectionException: No connection could be made because the target machine actively refused it 127.0.0.1:14800 ---> System.Net.Sockets.SocketException: No connection could be made because the target machine actively refused it 127.0.0.1:14800
   at System.Net.Sockets.Socket.EndConnect(IAsyncResult asyncResult)
   at Helios.Net.Connections.TcpConnection.Open()
   --- End of inner exception stack trace ---
   at Helios.Net.Connections.TcpConnection.Open()
   at Akka.Remote.Transport.Helios.CommonHandlers.Open()
   at Akka.Remote.Transport.Helios.HeliosTcpTransport.AssociateInternal(Address remoteAddress)
   at Akka.Remote.Transport.Helios.HeliosTransport.<Associate>d__27.MoveNext()
   --- End of inner exception stack trace ---
   --- End of inner exception stack trace ---
   at Akka.Remote.EndpointWriter.PublishAndThrow(Exception reason, LogLevel level)
   at Akka.Remote.EndpointWriter.<Initializing>b__23_1(Failure failure)
   at lambda_method(Closure , Object , Action`1 , Action`1 , Action`1 )
   at Akka.Tools.MatchHandler.PartialHandlerArgumentsCapture`4.Handle(T value)
   at Akka.Actor.ReceiveActor.ExecutePartialMessageHandler(Object message, PartialAction`1 partialAction)
   at Akka.Actor.ReceiveActor.OnReceive(Object message)
   at Akka.Actor.UntypedActor.Receive(Object message)
   at Akka.Actor.ActorBase.AroundReceive(Receive receive, Object message)
   at Akka.Actor.ActorCell.ReceiveMessage(Object message)
   at Akka.Actor.ActorCell.Invoke(Envelope envelope)
--- End of stack trace from previous location where exception was thrown ---
   at Akka.Actor.ActorCell.HandleFailed(Failed f)
   at Akka.Actor.ActorCell.SystemInvoke(Envelope envelope)
2016-02-09 09:32:22.789 +11:00 [Debug] "no longer watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1]"
2016-02-09 09:32:22.790 +11:00 [Debug] "Stopped"
2016-02-09 09:32:22.793 +11:00 [Debug] "Disassociated [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800"
2016-02-09 09:32:22.793 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 1 dead letters encountered."
2016-02-09 09:32:22.793 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 2 dead letters encountered."
2016-02-09 09:32:22.793 +11:00 [Information] "Message DeathWatchNotification from akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1 to akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1 was not delivered. 3 dead letters encountered."
2016-02-09 09:32:22.793 +11:00 [Debug] "received AutoReceiveMessage <Terminated>: [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1] - ExistenceConfirmed=True"
2016-02-09 09:32:22.793 +11:00 [Debug] "Stopped"
2016-02-09 09:32:23.656 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 4 dead letters encountered."
2016-02-09 09:32:24.664 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 5 dead letters encountered."
2016-02-09 09:32:25.671 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 6 dead letters encountered."
2016-02-09 09:32:26.676 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 7 dead letters encountered."
2016-02-09 09:32:27.677 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 8 dead letters encountered."
2016-02-09 09:32:28.688 +11:00 [Debug] "Started (Akka.Remote.ReliableDeliverySupervisor)"
2016-02-09 09:32:28.688 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-2/endpointWriter"
2016-02-09 09:32:28.688 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-2"
2016-02-09 09:32:28.688 +11:00 [Debug] "now watched by [akka://client/system/endpointManager]"
2016-02-09 09:32:28.688 +11:00 [Debug] "Started (Akka.Remote.EndpointWriter)"
2016-02-09 09:32:28.688 +11:00 [Debug] "now watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-2]"
2016-02-09 09:32:28.690 +11:00 [Debug] "now supervising akka://client/system/transports/akkaprotocolmanager.tcp.0/akkaProtocol-tcp%3a%2f%2fserver%40127.0.0.1%3a14800-2"
2016-02-09 09:32:29.713 +11:00 [Debug] "Started (Akka.Remote.Transport.ProtocolStateActor)"
2016-02-09 09:32:29.713 +11:00 [Debug] "Stopped"
2016-02-09 09:32:29.713 +11:00 [Warning] "AssociationError [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800: Error [Invalid address: akka.tcp://[email protected]:14800] []"
2016-02-09 09:32:29.713 +11:00 [Warning] Tried to associate with unreachable remote address ["akka.tcp://[email protected]:14800"]. Address is now gated for 5000 ms, all messages to this address will be delivered to dead letters. Reason: ["Invalid address: akka.tcp://[email protected]:14800"] "Caused by: [Akka.Remote.Transport.InvalidAssociationException: Association failure ---> Helios.Exceptions.HeliosConnectionException: No connection could be made because the target machine actively refused it 127.0.0.1:14800 ---> System.Net.Sockets.SocketException: No connection could be made because the target machine actively refused it 127.0.0.1:14800
   at System.Net.Sockets.Socket.EndConnect(IAsyncResult asyncResult)
   at Helios.Net.Connections.TcpConnection.Open()
   --- End of inner exception stack trace ---
   at Helios.Net.Connections.TcpConnection.Open()
   at Akka.Remote.Transport.Helios.CommonHandlers.Open()
   at Akka.Remote.Transport.Helios.HeliosTcpTransport.AssociateInternal(Address remoteAddress)
   at Akka.Remote.Transport.Helios.HeliosTransport.<Associate>d__27.MoveNext()
   --- End of inner exception stack trace ---]"
2016-02-09 09:32:29.713 +11:00 [Error] "Invalid address: akka.tcp://[email protected]:14800"
Akka.Remote.InvalidAssociation: Invalid address: akka.tcp://[email protected]:14800 ---> Akka.Remote.Transport.InvalidAssociationException: Association failure ---> Helios.Exceptions.HeliosConnectionException: No connection could be made because the target machine actively refused it 127.0.0.1:14800 ---> System.Net.Sockets.SocketException: No connection could be made because the target machine actively refused it 127.0.0.1:14800
   at System.Net.Sockets.Socket.EndConnect(IAsyncResult asyncResult)
   at Helios.Net.Connections.TcpConnection.Open()
   --- End of inner exception stack trace ---
   at Helios.Net.Connections.TcpConnection.Open()
   at Akka.Remote.Transport.Helios.CommonHandlers.Open()
   at Akka.Remote.Transport.Helios.HeliosTcpTransport.AssociateInternal(Address remoteAddress)
   at Akka.Remote.Transport.Helios.HeliosTransport.<Associate>d__27.MoveNext()
   --- End of inner exception stack trace ---
   --- End of inner exception stack trace ---
   at Akka.Remote.EndpointWriter.PublishAndThrow(Exception reason, LogLevel level)
   at Akka.Remote.EndpointWriter.<Initializing>b__23_1(Failure failure)
   at lambda_method(Closure , Object , Action`1 , Action`1 , Action`1 )
   at Akka.Tools.MatchHandler.PartialHandlerArgumentsCapture`4.Handle(T value)
   at Akka.Actor.ReceiveActor.ExecutePartialMessageHandler(Object message, PartialAction`1 partialAction)
   at Akka.Actor.ReceiveActor.OnReceive(Object message)
   at Akka.Actor.UntypedActor.Receive(Object message)
   at Akka.Actor.ActorBase.AroundReceive(Receive receive, Object message)
   at Akka.Actor.ActorCell.ReceiveMessage(Object message)
   at Akka.Actor.ActorCell.Invoke(Envelope envelope)
--- End of stack trace from previous location where exception was thrown ---
   at Akka.Actor.ActorCell.HandleFailed(Failed f)
   at Akka.Actor.ActorCell.SystemInvoke(Envelope envelope)
2016-02-09 09:32:29.713 +11:00 [Debug] "Stopped"
2016-02-09 09:32:29.713 +11:00 [Debug] "no longer watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-2]"
2016-02-09 09:32:29.713 +11:00 [Debug] "Disassociated [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800"
2016-02-09 09:32:29.713 +11:00 [Debug] "Stopped"
2016-02-09 09:32:29.713 +11:00 [Debug] "received AutoReceiveMessage <Terminated>: [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-2] - ExistenceConfirmed=True"
2016-02-09 09:32:29.713 +11:00 [Information] "Message String from akka://client/user/client-actor to akka://client/deadLetters was not delivered. 9 dead letters encountered."
2016-02-09 09:32:29.713 +11:00 [Debug] "unsubscribing [akka://client/system/deadLetterListener] from all channels"
2016-02-09 09:32:29.713 +11:00 [Debug] "Stopped"
2016-02-09 09:32:34.715 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-3"
2016-02-09 09:32:34.717 +11:00 [Debug] "Started (Akka.Remote.ReliableDeliverySupervisor)"
2016-02-09 09:32:34.717 +11:00 [Debug] "now watched by [akka://client/system/endpointManager]"
2016-02-09 09:32:34.717 +11:00 [Debug] "Started (Akka.Remote.EndpointWriter)"
2016-02-09 09:32:34.717 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-3/endpointWriter"
2016-02-09 09:32:34.717 +11:00 [Debug] "now watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-3]"
2016-02-09 09:32:34.719 +11:00 [Debug] "now supervising akka://client/system/transports/akkaprotocolmanager.tcp.0/akkaProtocol-tcp%3a%2f%2fserver%40127.0.0.1%3a14800-3"
2016-02-09 09:32:35.728 +11:00 [Debug] "Started (Akka.Remote.Transport.ProtocolStateActor)"
2016-02-09 09:32:35.729 +11:00 [Debug] "Stopped"
2016-02-09 09:32:35.729 +11:00 [Warning] "AssociationError [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800: Error [Invalid address: akka.tcp://[email protected]:14800] []"
2016-02-09 09:32:35.729 +11:00 [Warning] Tried to associate with unreachable remote address ["akka.tcp://[email protected]:14800"]. Address is now gated for 5000 ms, all messages to this address will be delivered to dead letters. Reason: ["Invalid address: akka.tcp://[email protected]:14800"] "Caused by: [Akka.Remote.Transport.InvalidAssociationException: Association failure ---> Helios.Exceptions.HeliosConnectionException: No connection could be made because the target machine actively refused it 127.0.0.1:14800 ---> System.Net.Sockets.SocketException: No connection could be made because the target machine actively refused it 127.0.0.1:14800
   at System.Net.Sockets.Socket.EndConnect(IAsyncResult asyncResult)
   at Helios.Net.Connections.TcpConnection.Open()
   --- End of inner exception stack trace ---
   at Helios.Net.Connections.TcpConnection.Open()
   at Akka.Remote.Transport.Helios.CommonHandlers.Open()
   at Akka.Remote.Transport.Helios.HeliosTcpTransport.AssociateInternal(Address remoteAddress)
   at Akka.Remote.Transport.Helios.HeliosTransport.<Associate>d__27.MoveNext()
   --- End of inner exception stack trace ---]"
2016-02-09 09:32:35.729 +11:00 [Error] "Invalid address: akka.tcp://[email protected]:14800"
Akka.Remote.InvalidAssociation: Invalid address: akka.tcp://[email protected]:14800 ---> Akka.Remote.Transport.InvalidAssociationException: Association failure ---> Helios.Exceptions.HeliosConnectionException: No connection could be made because the target machine actively refused it 127.0.0.1:14800 ---> System.Net.Sockets.SocketException: No connection could be made because the target machine actively refused it 127.0.0.1:14800
   at System.Net.Sockets.Socket.EndConnect(IAsyncResult asyncResult)
   at Helios.Net.Connections.TcpConnection.Open()
   --- End of inner exception stack trace ---
   at Helios.Net.Connections.TcpConnection.Open()
   at Akka.Remote.Transport.Helios.CommonHandlers.Open()
   at Akka.Remote.Transport.Helios.HeliosTcpTransport.AssociateInternal(Address remoteAddress)
   at Akka.Remote.Transport.Helios.HeliosTransport.<Associate>d__27.MoveNext()
   --- End of inner exception stack trace ---
   --- End of inner exception stack trace ---
   at Akka.Remote.EndpointWriter.PublishAndThrow(Exception reason, LogLevel level)
   at Akka.Remote.EndpointWriter.<Initializing>b__23_1(Failure failure)
   at lambda_method(Closure , Object , Action`1 , Action`1 , Action`1 )
   at Akka.Tools.MatchHandler.PartialHandlerArgumentsCapture`4.Handle(T value)
   at Akka.Actor.ReceiveActor.ExecutePartialMessageHandler(Object message, PartialAction`1 partialAction)
   at Akka.Actor.ReceiveActor.OnReceive(Object message)
   at Akka.Actor.UntypedActor.Receive(Object message)
   at Akka.Actor.ActorBase.AroundReceive(Receive receive, Object message)
   at Akka.Actor.ActorCell.ReceiveMessage(Object message)
   at Akka.Actor.ActorCell.Invoke(Envelope envelope)
--- End of stack trace from previous location where exception was thrown ---
   at Akka.Actor.ActorCell.HandleFailed(Failed f)
   at Akka.Actor.ActorCell.SystemInvoke(Envelope envelope)
2016-02-09 09:32:35.729 +11:00 [Debug] "Stopped"
2016-02-09 09:32:35.729 +11:00 [Debug] "received AutoReceiveMessage <Terminated>: [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-3] - ExistenceConfirmed=True"
2016-02-09 09:32:35.729 +11:00 [Debug] "no longer watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-3]"
2016-02-09 09:32:35.729 +11:00 [Debug] "Disassociated [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800"
2016-02-09 09:32:35.729 +11:00 [Debug] "Stopped"
2016-02-09 09:32:40.746 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4"
2016-02-09 09:32:40.749 +11:00 [Debug] "Started (Akka.Remote.ReliableDeliverySupervisor)"
2016-02-09 09:32:40.749 +11:00 [Debug] "now watched by [akka://client/system/endpointManager]"
2016-02-09 09:32:40.749 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4/endpointWriter"
2016-02-09 09:32:40.749 +11:00 [Debug] "Started (Akka.Remote.EndpointWriter)"
2016-02-09 09:32:40.749 +11:00 [Debug] "now watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4]"
2016-02-09 09:32:40.752 +11:00 [Debug] "now supervising akka://client/system/transports/akkaprotocolmanager.tcp.0/akkaProtocol-tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4"
2016-02-09 09:32:40.784 +11:00 [Debug] "Started (Akka.Remote.Transport.ProtocolStateActor)"
2016-02-09 09:32:41.633 +11:00 [Debug] "Associated [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800"
2016-02-09 09:32:41.633 +11:00 [Debug] "Started (Akka.Remote.EndpointReader)"
2016-02-09 09:32:41.633 +11:00 [Debug] "now watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4/endpointWriter]"
2016-02-09 09:32:41.635 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:41.784 +11:00 [Debug] Drained buffer with maxWriteCount: 50, fullBackoffCount: 1,smallBackoffCount: 0, noBackoffCount: 0,adaptiveBackoff: 1000
2016-02-09 09:32:41.789 +11:00 [Debug] "now supervising akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4/endpointWriter/endpointReader-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1"
2016-02-09 09:32:41.790 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:42.744 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:43.743 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:44.760 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:45.763 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:46.772 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:47.773 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:48.782 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:49.793 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:50.794 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:51.797 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:52.806 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:53.807 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:54.814 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:55.821 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:56.824 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:57.833 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:58.842 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:32:59.845 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:00.853 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:01.855 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:02.856 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:03.863 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:04.868 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:05.875 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:06.877 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:07.877 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:08.886 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:09.892 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:10.902 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:11.911 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:12.916 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:13.917 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:14.918 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:15.929 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:16.929 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:17.936 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:18.942 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:19.948 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:20.950 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:21.952 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:22.956 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:23.966 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:24.971 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:25.973 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:26.974 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:27.986 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:28.987 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:29.989 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:30.996 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:31.999 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:33.008 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:34.018 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:35.012 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:36.020 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:37.024 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:38.026 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:39.034 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:40.043 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:41.049 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:42.059 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:43.066 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:44.070 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:45.079 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:46.090 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:47.093 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:48.093 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:49.097 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:50.105 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:51.112 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:52.114 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:53.119 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:54.120 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:55.122 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:56.125 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:57.127 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:58.135 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:33:59.137 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:00.141 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:01.142 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:02.152 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:03.157 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:04.165 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:05.167 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:06.177 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:07.187 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:08.197 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:09.202 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:10.205 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:11.208 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:12.210 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:13.212 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:14.212 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:15.217 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:16.219 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:17.229 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:18.229 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:19.237 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:20.238 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:21.245 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:22.247 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:23.252 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:24.266 +11:00 [Debug] RemoteMessage: "ActorSelectionMessage - Message: Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800 - WildCartFanOut: False - Elements: user/connect" to ["[akka.tcp://[email protected]:14800/]"]<+["akka.tcp://[email protected]:14800/"] from ["[akka://client/user/client-actor]"]
2016-02-09 09:34:24.872 +11:00 [Debug] "Stopped"
2016-02-09 09:34:24.873 +11:00 [Debug] "Stopped"
2016-02-09 09:34:24.873 +11:00 [Debug] "received AutoReceiveMessage <Terminated>: [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4/endpointWriter/endpointReader-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-1] - ExistenceConfirmed=True"
2016-02-09 09:34:24.873 +11:00 [Debug] "Disassociated [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800"
2016-02-09 09:34:24.873 +11:00 [Warning] Association with remote system "akka.tcp://[email protected]:14800" has failed; address is now gated for 5000 ms. Reason is: ["Akka.Remote.EndpointDisassociatedException: Disassociated
   at Akka.Remote.EndpointWriter.PublishAndThrow(Exception reason, LogLevel level)
   at Akka.Remote.EndpointWriter.Unhandled(Object message)
   at Akka.Actor.ReceiveActor.ExecutePartialMessageHandler(Object message, PartialAction`1 partialAction)
   at Akka.Actor.ReceiveActor.<>c__DisplayClass11_0.<Become>b__0(Object m)
   at Akka.Actor.ActorCell.<>c__DisplayClass109_0.<Akka.Actor.IUntypedActorContext.Become>b__0(Object m)
   at Akka.Actor.ActorBase.AroundReceive(Receive receive, Object message)
   at Akka.Actor.ActorCell.ReceiveMessage(Object message)
   at Akka.Actor.ActorCell.ReceivedTerminated(Terminated t)
   at Akka.Actor.ActorCell.AutoReceiveMessage(Envelope envelope)
   at Akka.Actor.ActorCell.Invoke(Envelope envelope)
--- End of stack trace from previous location where exception was thrown ---
   at Akka.Actor.ActorCell.HandleFailed(Failed f)
   at Akka.Actor.ActorCell.SystemInvoke(Envelope envelope)"]
2016-02-09 09:34:24.873 +11:00 [Error] "Disassociated"
Akka.Remote.EndpointDisassociatedException: Disassociated
   at Akka.Remote.EndpointWriter.PublishAndThrow(Exception reason, LogLevel level)
   at Akka.Remote.EndpointWriter.Unhandled(Object message)
   at Akka.Actor.ReceiveActor.ExecutePartialMessageHandler(Object message, PartialAction`1 partialAction)
   at Akka.Actor.ReceiveActor.<>c__DisplayClass11_0.<Become>b__0(Object m)
   at Akka.Actor.ActorCell.<>c__DisplayClass109_0.<Akka.Actor.IUntypedActorContext.Become>b__0(Object m)
   at Akka.Actor.ActorBase.AroundReceive(Receive receive, Object message)
   at Akka.Actor.ActorCell.ReceiveMessage(Object message)
   at Akka.Actor.ActorCell.ReceivedTerminated(Terminated t)
   at Akka.Actor.ActorCell.AutoReceiveMessage(Envelope envelope)
   at Akka.Actor.ActorCell.Invoke(Envelope envelope)
--- End of stack trace from previous location where exception was thrown ---
   at Akka.Actor.ActorCell.HandleFailed(Failed f)
   at Akka.Actor.ActorCell.SystemInvoke(Envelope envelope)
2016-02-09 09:34:24.873 +11:00 [Debug] "Stopped"
2016-02-09 09:34:24.873 +11:00 [Debug] "no longer watched by [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4]"
2016-02-09 09:34:24.873 +11:00 [Debug] "Disassociated [akka.tcp://[email protected]:57445] -> akka.tcp://[email protected]:14800"
2016-02-09 09:34:24.873 +11:00 [Debug] "Stopped"
2016-02-09 09:34:24.874 +11:00 [Debug] "received AutoReceiveMessage <Terminated>: [akka://client/system/endpointManager/reliableEndpointWriter-akka.tcp%3a%2f%2fserver%40127.0.0.1%3a14800-4] - ExistenceConfirmed=True"

server:

2016-02-09 09:32:39.232 +11:00 [Debug] "Logger log1-SerilogLogger [SerilogLogger] started"
2016-02-09 09:32:39.268 +11:00 [Debug] "StandardOutLogger being removed"
2016-02-09 09:32:39.268 +11:00 [Debug] "Default Loggers started"
2016-02-09 09:32:39.270 +11:00 [Information] "Starting remoting"
2016-02-09 09:32:39.270 +11:00 [Debug] "Starting prune timer for endpoint manager..."
2016-02-09 09:32:39.359 +11:00 [Information] Remoting started; listening on addresses : ["akka.tcp://[email protected]:14800"]
2016-02-09 09:32:39.363 +11:00 [Information] "Remoting now listens on addresses: [akka.tcp://[email protected]:14800]"
2016-02-09 09:32:39.370 +11:00 [Warning] "{
  akka : {
    log-config-on-start : on
    stdout-loglevel : DEBUG
    loglevel : DEBUG
    loggers : [\"Akka.Logger.Serilog.SerilogLogger, Akka.Logger.Serilog\"]
    actor : {
      provider : \"Akka.Remote.RemoteActorRefProvider, Akka.Remote\"
    }
    remote : {
      helios : {
        tcp : {
          hostname : 127.0.0.1
          port : 14800
        }
      }
    }
  }
}"
2016-02-09 09:32:41.600 +11:00 [Debug] "Associated [akka.tcp://[email protected]:14800] <- akka.tcp://[email protected]:57445"
2016-02-09 09:32:41.879 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:41.879 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:42.745 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:43.750 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:44.760 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:45.763 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:46.772 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:47.773 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:48.782 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:49.794 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:50.809 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:51.797 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:52.807 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:53.809 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:54.815 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:55.821 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:56.849 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:57.834 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:58.843 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:32:59.847 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:00.854 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:01.855 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:02.858 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:03.865 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:04.868 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:05.876 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:06.877 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:07.878 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:08.887 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:09.894 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:10.904 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:11.911 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:12.916 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:13.918 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:14.919 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:15.930 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:16.930 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:17.937 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:18.942 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:19.949 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:20.950 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:21.952 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:22.958 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:23.967 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:24.971 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:25.975 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:26.974 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:27.987 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:28.989 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:29.990 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:30.997 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:32.000 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:33.008 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:34.020 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:35.013 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:36.024 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:37.026 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:38.026 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:39.034 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:40.044 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:41.051 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:42.062 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:43.066 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:44.070 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:45.080 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:46.095 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:47.094 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:48.093 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:49.096 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:50.107 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:51.113 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:52.114 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:53.118 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:54.121 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:55.122 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:56.126 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:57.130 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:58.135 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:33:59.138 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:00.142 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:01.143 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:02.152 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:03.161 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:04.165 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:05.168 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:06.178 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:07.188 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:08.198 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:09.201 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:10.205 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:11.209 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:12.210 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:13.212 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:14.213 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:15.217 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:16.221 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:17.230 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:18.229 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:19.237 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:20.240 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:21.246 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:22.248 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:23.253 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"
2016-02-09 09:34:24.269 +11:00 [Information] Receive message: "Message 274428a2-2ca8-4e87-8816-62d691614e95 trying to connect to akka.tcp://[email protected]:14800"

TLS / SSL options for Helios over TCP

Reviewing some options for bringing TLS / SSL support to TCP sockets for Helios 2.0.

The implementations thus far look like:

  1. SslStream upon accept / connect for inbound / outbound sockets. Could be implemented as a IChannelHandler that operates at the stage closest to the socket, or could be an implementation detail of the ITransport itself. Looks like SslStream will still work with asynchronous socket operations.
  2. Use Bouncy Castle's third party libraries for implementing TLS; there's not a lot of documentation for the libraries in C# (it's the Java ones by the same project that are most popular) but it looks like they depend on OpenSSL for some of the keystore work underneath the hood. The downside of this option is that, well, it's a third-party library we have to depend on it and we can't really say how well it works. Upside is that it supports DTLS, which would give us a security option for UDP.

2.0什么时间能完成?

作者你好,helios2.0什么时间能够推出来?我们非常期待。A developer from China!

Cluster sample

It would be nice to have a sample how to set up a cluster.

Need to decrease allocations inside Helios reactors

Some specs fresh off the build server for the dev branch:

Helios.Tests.Performance.Socket.TcpThroughputSpec+OneWayThroughputBenchmark

Tests a full request/response sequence for 1000 messages
4/13/2016 1:06:35 AM

System Info

NBench=NBench, Version=0.2.1.0, Culture=neutral, PublicKeyToken=null
OS=Microsoft Windows NT 6.2.9200.0
ProcessorCount=4
CLR=4.0.30319.42000,IsMono=False,MaxGcGeneration=2
WorkerThreads=32767, IOThreads=4

NBench Settings

RunMode=Iterations, TestMode=Measurement
NumberOfIterations=13, MaximumRunTime=00:00:01

Data


Totals

Metric Units Max Average Min StdDev
TotalBytesAllocated bytes 2,702,000.00 2,632,565.54 2,620,128.00 21,170.43
TotalCollections [Gen0] collections 0.00 0.00 0.00 0.00
TotalCollections [Gen1] collections 0.00 0.00 0.00 0.00
TotalCollections [Gen2] collections 0.00 0.00 0.00 0.00
[Counter] MessagesReceived operations 1,000.00 1,000.00 1,000.00 0.00

Per-second Totals

Metric Units / s Max / s Average / s Min / s StdDev / s
TotalBytesAllocated bytes 293,906,498.14 284,017,997.22 260,700,740.08 8,730,090.93
TotalCollections [Gen0] collections 0.00 0.00 0.00 0.00
TotalCollections [Gen1] collections 0.00 0.00 0.00 0.00
TotalCollections [Gen2] collections 0.00 0.00 0.00 0.00
[Counter] MessagesReceived operations 109,933.60 107,882.67 99,339.39 3,068.69

Raw Data

TotalBytesAllocated

Run # bytes bytes / s ns / bytes
1 2,624,928.00 288,396,580.90 3.47
2 2,632,736.00 288,686,689.26 3.46
3 2,632,368.00 288,178,663.31 3.47
4 2,628,328.00 287,161,087.32 3.48
5 2,625,344.00 283,508,347.55 3.53
6 2,624,344.00 260,700,740.08 3.84
7 2,626,480.00 277,303,489.42 3.61
8 2,626,336.00 284,287,801.87 3.52
9 2,624,952.00 288,329,525.48 3.47
10 2,702,000.00 293,906,498.14 3.40
11 2,624,152.00 288,482,476.58 3.47
12 2,631,256.00 289,053,718.55 3.46
13 2,620,128.00 274,238,345.44 3.65

TotalCollections [Gen0]

Run # collections collections / s ns / collections
1 0.00 0.00 9,101,800.00
2 0.00 0.00 9,119,700.00
3 0.00 0.00 9,134,500.00
4 0.00 0.00 9,152,800.00
5 0.00 0.00 9,260,200.00
6 0.00 0.00 10,066,500.00
7 0.00 0.00 9,471,500.00
8 0.00 0.00 9,238,300.00
9 0.00 0.00 9,104,000.00
10 0.00 0.00 9,193,400.00
11 0.00 0.00 9,096,400.00
12 0.00 0.00 9,103,000.00
13 0.00 0.00 9,554,200.00

TotalCollections [Gen1]

Run # collections collections / s ns / collections
1 0.00 0.00 9,101,800.00
2 0.00 0.00 9,119,700.00
3 0.00 0.00 9,134,500.00
4 0.00 0.00 9,152,800.00
5 0.00 0.00 9,260,200.00
6 0.00 0.00 10,066,500.00
7 0.00 0.00 9,471,500.00
8 0.00 0.00 9,238,300.00
9 0.00 0.00 9,104,000.00
10 0.00 0.00 9,193,400.00
11 0.00 0.00 9,096,400.00
12 0.00 0.00 9,103,000.00
13 0.00 0.00 9,554,200.00

TotalCollections [Gen2]

Run # collections collections / s ns / collections
1 0.00 0.00 9,101,800.00
2 0.00 0.00 9,119,700.00
3 0.00 0.00 9,134,500.00
4 0.00 0.00 9,152,800.00
5 0.00 0.00 9,260,200.00
6 0.00 0.00 10,066,500.00
7 0.00 0.00 9,471,500.00
8 0.00 0.00 9,238,300.00
9 0.00 0.00 9,104,000.00
10 0.00 0.00 9,193,400.00
11 0.00 0.00 9,096,400.00
12 0.00 0.00 9,103,000.00
13 0.00 0.00 9,554,200.00

[Counter] MessagesReceived

Run # operations operations / s ns / operations
1 1,000.00 109,868.38 9,101.80
2 1,000.00 109,652.73 9,119.70
3 1,000.00 109,475.07 9,134.50
4 1,000.00 109,256.18 9,152.80
5 1,000.00 107,989.03 9,260.20
6 1,000.00 99,339.39 10,066.50
7 1,000.00 105,579.90 9,471.50
8 1,000.00 108,245.02 9,238.30
9 1,000.00 109,841.83 9,104.00
10 1,000.00 108,773.69 9,193.40
11 1,000.00 109,933.60 9,096.40
12 1,000.00 109,853.89 9,103.00
13 1,000.00 104,666.01 9,554.20

System.Collections.Generic.KeyNotFoundException

Using version 1.4.2.
My process getting terminated with below exception on the event viewer

Log Name: Application
Source: .NET Runtime
Date: 10-02-2016 PM 03:48:21
Event ID: 1026
Task Category: None
Level: Error
Keywords: Classic
User: N/A
Computer: WIN2008SERVER
Description:
Application: ApiServices.exe
Framework Version: v4.0.30319
Description: The process was terminated due to an unhandled exception.
Exception Info: System.Collections.Generic.KeyNotFoundException
Stack:
at System.Collections.Generic.Dictionary`2[[System.__Canon, mscorlib, Version=4.0.0.0, Culture=neutral, PublicKeyToken=b77a5c561934e089],[System.__Canon, mscorlib, Version=4.0.0.0, Culture=neutral, PublicKeyToken=b77a5c561934e089]].get_Item(System._Canon)
at Helios.Reactor.Tcp.TcpProxyReactor.ReceiveCallback(System.IAsyncResult)
at System.Net.LazyAsyncResult.Complete(IntPtr)
at System.Threading.ExecutionContext.RunInternal(System.Threading.ExecutionContext, System.Threading.ContextCallback, System.Object, Boolean)
at System.Threading.ExecutionContext.Run(System.Threading.ExecutionContext, System.Threading.ContextCallback, System.Object, Boolean)
at System.Threading.ExecutionContext.Run(System.Threading.ExecutionContext, System.Threading.ContextCallback, System.Object)
at System.Net.ContextAwareResult.Complete(IntPtr)
at System.Net.LazyAsyncResult.ProtectedInvokeCallback(System.Object, IntPtr)
at System.Net.Sockets.BaseOverlappedAsyncResult.CompletionPortCallback(UInt32, UInt32, System.Threading.NativeOverlapped
)
at System.Threading.IOCompletionCallback.PerformIOCompletionCallback(UInt32, UInt32, System.Threading.NativeOverlapped)

Add Helios.TCPThroughput benchmark

Lets clock how quickly we can bounce 1 million messages back and forth between client and server - 2 million total round trips.

I think we can make some modifications to the MultiNodeTestKit to make this easy to do - need to make some of its logging capabilities optional.

More basic examples (eg. telnet echo server)

Hi,

I started to play with Helios and wanted to create basic echo Tcp server that works with any telnet client. In examples there is a TcpReactorServer, but it only works with RawSocket exmple. When using windows telnet, I can connect to the server, but typing any character in telnet client doesn't gets echoed. How can i achive this functionaly using Helios? It would be cool to have more basic examples, becouse documenation is very, very poor and examples are good starting point.

Not been updated。。。

Not been updated for a month, a little scared, because our bank project is to use your components. Please do not stop the update ah

Helios 2.0 IConnection Spec

IConnection - right now this term is used to mean two things:

  1. Literally the object that the app developer uses to interact with the Helios server (i.e. what gets created at the end of a ClientBootstrap or ServerBootstrap) and
  2. Also the response channel that gets passed to any of the Helios event handlers.

Essentially any handle to a socket no matter what was an IConnection in Helios 1.0.

Going forward, IConnection is going to mean only item 1 - this is literally the handle a developer is going to use to start / stop their Helios client or server going forward. All of the

IConnection Capabilities

An IConnection will be responsible for the following things, after it's been built:

  • start / stop the underlying transport - i.e. shutdown the socket or the socket listener.
  • provide read access to INode / address information - let the caller know what port / IP we're bound to.
  • allow the developer to change the writability of the transport - queue up writes until some magical thing has been done at the application level.
  • expose a WaitHandle for forcing the app to run continuously until shutdown - make it easy for people to wait while the socket is open.
  • __expose the IChannel object that Helios clients need in order to write messages onto the network. Available only for client connections.

Recommend Projects

  • React photo React

    A declarative, efficient, and flexible JavaScript library for building user interfaces.

  • Vue.js photo Vue.js

    🖖 Vue.js is a progressive, incrementally-adoptable JavaScript framework for building UI on the web.

  • Typescript photo Typescript

    TypeScript is a superset of JavaScript that compiles to clean JavaScript output.

  • TensorFlow photo TensorFlow

    An Open Source Machine Learning Framework for Everyone

  • Django photo Django

    The Web framework for perfectionists with deadlines.

  • D3 photo D3

    Bring data to life with SVG, Canvas and HTML. 📊📈🎉

Recommend Topics

  • javascript

    JavaScript (JS) is a lightweight interpreted programming language with first-class functions.

  • web

    Some thing interesting about web. New door for the world.

  • server

    A server is a program made to process requests and deliver data to clients.

  • Machine learning

    Machine learning is a way of modeling and interpreting data that allows a piece of software to respond intelligently.

  • Game

    Some thing interesting about game, make everyone happy.

Recommend Org

  • Facebook photo Facebook

    We are working to build community through open source technology. NB: members must have two-factor auth.

  • Microsoft photo Microsoft

    Open source projects and samples from Microsoft.

  • Google photo Google

    Google ❤️ Open Source for everyone.

  • D3 photo D3

    Data-Driven Documents codes.