Merge commit 'origin/silc.1.1.branch'
[silc.git] / lib / silcclient / client.c
index 44659ada59e5366baddab1912a6270fa5ddd8ea6..449fc375ce152b33bca4e0c3bbd06ce53870766d 100644 (file)
 
   client.c
 
-  Author: Pekka Riikonen <priikone@poseidon.pspt.fi>
+  Author: Pekka Riikonen <priikone@silcnet.org>
 
-  Copyright (C) 1997 - 2000 Pekka Riikonen
+  Copyright (C) 1997 - 2008 Pekka Riikonen
 
   This program is free software; you can redistribute it and/or modify
   it under the terms of the GNU General Public License as published by
-  the Free Software Foundation; either version 2 of the License, or
-  (at your option) any later version.
-  
+  the Free Software Foundation; version 2 of the License.
+
   This program is distributed in the hope that it will be useful,
   but WITHOUT ANY WARRANTY; without even the implied warranty of
   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the
   GNU General Public License for more details.
 
 */
-/* $Id$ */
-
-#include "clientlibincludes.h"
-
-/* Static task callback prototypes */
-SILC_TASK_CALLBACK(silc_client_connect_to_server_start);
-SILC_TASK_CALLBACK(silc_client_connect_to_server_second);
-SILC_TASK_CALLBACK(silc_client_connect_to_server_final);
-SILC_TASK_CALLBACK(silc_client_packet_process);
-SILC_TASK_CALLBACK(silc_client_packet_parse_real);
-
-static void silc_client_packet_parse(SilcPacketParserContext *parser_context);
-static void silc_client_packet_parse_type(SilcClient client, 
-                                         SilcSocketConnection sock,
-                                         SilcPacketContext *packet);
-
-/* Allocates new client object. This has to be done before client may
-   work. After calling this one must call silc_client_init to initialize
-   the client. The `application' is application specific user data pointer
-   and caller must free it. */
-
-SilcClient silc_client_alloc(SilcClientOperations *ops, void *application)
-{
-  SilcClient new_client;
-
-  new_client = silc_calloc(1, sizeof(*new_client));
-  new_client->application = application;
-  new_client->ops = ops;
 
-  return new_client;
-}
+#include "silc.h"
+#include "silcclient.h"
+#include "client_internal.h"
 
-/* Free's client object */
-
-void silc_client_free(SilcClient client)
-{
-  if (client) {
-    silc_free(client);
-  }
-}
+/************************ Static utility functions **************************/
 
-/* Initializes the client. This makes all the necessary steps to make
-   the client ready to be run. One must call silc_client_run to run the
-   client. */
+/* Connection machine FSM destructor.  This will finish the thread where
+   the machine was running and deletes the connection context. */
 
-int silc_client_init(SilcClient client)
+static void silc_client_connection_destructor(SilcFSM fsm,
+                                             void *fsm_context,
+                                             void *destructor_context)
 {
-  SILC_LOG_DEBUG(("Initializing client"));
+  SilcClientConnection conn = fsm_context;
+  SilcFSMThread thread = destructor_context;
 
-  /* Initialize hash functions for client to use */
-  silc_hash_alloc("md5", &client->md5hash);
-  silc_hash_alloc("sha1", &client->sha1hash);
+  SILC_LOG_DEBUG(("Connection %p finished", conn));
 
-  /* Initialize none cipher */
-  silc_cipher_alloc("none", &client->none_cipher);
+  /* Delete connection */
+  silc_client_del_connection(conn->client, conn);
 
-  /* Initialize random number generator */
-  client->rng = silc_rng_alloc();
-  silc_rng_init(client->rng);
-  silc_math_primegen_init(); /* XXX */
-
-  /* Register protocols */
-  silc_client_protocols_register();
-
-  /* Initialize the scheduler */
-  silc_schedule_init(&client->io_queue, &client->timeout_queue, 
-                    &client->generic_queue, 5000);
-
-  return TRUE;
+  /* Finish the thread were this machine was running.  Its destructor is the
+     silc_client_connection_finished. */
+  silc_fsm_finish(thread);
 }
 
-/* Stops the client. This is called to stop the client and thus to stop
-   the program. */
+/* Connection thread FSM destructor.  This was the thread where the connection
+   machine was running (may be real thread).  From here we notify client
+   that the connection thread has finished. */
 
-void silc_client_stop(SilcClient client)
+static void silc_client_connection_finished(SilcFSMThread fsm,
+                                           void *fsm_context,
+                                           void *destructor_context)
 {
-  SILC_LOG_DEBUG(("Stopping client"));
+  SilcClient client = silc_fsm_get_state_context(fsm);
 
-  /* Stop the scheduler, although it might be already stopped. This
-     doesn't hurt anyone. This removes all the tasks and task queues,
-     as well. */
-  silc_schedule_stop();
-  silc_schedule_uninit();
+  /* Signal client that we have finished */
+  silc_atomic_sub_int32(&client->internal->conns, 1);
+  client->internal->connection_closed = TRUE;
+  SILC_FSM_EVENT_SIGNAL(&client->internal->wait_event);
 
-  silc_client_protocols_unregister();
-
-  SILC_LOG_DEBUG(("Client stopped"));
+  silc_fsm_free(fsm);
 }
 
-/* Runs the client. */
+/* Packet FSM thread destructor */
 
-void silc_client_run(SilcClient client)
+static void silc_client_packet_destructor(SilcFSMThread thread,
+                                         void *thread_context,
+                                         void *destructor_context)
 {
-  SILC_LOG_DEBUG(("Running client"));
+  SilcClientConnection conn = thread_context;
 
-  /* Start the scheduler, the heart of the SILC client. When this returns
-     the program will be terminated. */
-  silc_schedule();
+  /* Add thread back to thread pool */
+  silc_list_add(conn->internal->thread_pool, thread);
+  if (silc_list_count(conn->internal->thread_pool) == 1)
+    silc_list_start(conn->internal->thread_pool);
 }
 
-/* Allocates and adds new connection to the client. This adds the allocated
-   connection to the connection table and returns a pointer to it. A client
-   can have multiple connections to multiple servers. Every connection must
-   be added to the client using this function. User data `context' may
-   be sent as argument. */
+/* Packet engine callback to receive a packet */
 
-SilcClientConnection silc_client_add_connection(SilcClient client,
-                                               char *hostname,
-                                               int port,
-                                               void *context)
+static SilcBool silc_client_packet_receive(SilcPacketEngine engine,
+                                          SilcPacketStream stream,
+                                          SilcPacket packet,
+                                          void *callback_context,
+                                          void *stream_context)
 {
-  SilcClientConnection conn;
-  int i;
+  SilcClientConnection conn = stream_context;
+  SilcFSMThread thread;
 
-  conn = silc_calloc(1, sizeof(*conn));
+  /* Packets we do not handle */
+  switch (packet->type) {
+  case SILC_PACKET_HEARTBEAT:
+  case SILC_PACKET_SUCCESS:
+  case SILC_PACKET_FAILURE:
+  case SILC_PACKET_REJECT:
+  case SILC_PACKET_KEY_EXCHANGE:
+  case SILC_PACKET_KEY_EXCHANGE_1:
+  case SILC_PACKET_KEY_EXCHANGE_2:
+  case SILC_PACKET_REKEY_DONE:
+  case SILC_PACKET_CONNECTION_AUTH:
+    return FALSE;
+    break;
+  }
 
-  /* Initialize ID caches */
-  conn->client_cache = silc_idcache_alloc(0);
-  conn->channel_cache = silc_idcache_alloc(0);
-  conn->server_cache = silc_idcache_alloc(0);
-  conn->client = client;
-  conn->remote_host = strdup(hostname);
-  conn->remote_port = port;
-  conn->context = context;
-
-  /* Add the connection to connections table */
-  for (i = 0; i < client->conns_count; i++)
-    if (client->conns && !client->conns[i]) {
-      client->conns[i] = conn;
-      return conn;
-    }
+  /* Get packet processing thread */
+  thread = silc_list_get(conn->internal->thread_pool);
+  if (!thread) {
+    thread = silc_fsm_thread_alloc(&conn->internal->fsm, conn,
+                                  silc_client_packet_destructor, NULL, FALSE);
+    if (!thread)
+      return FALSE;
+  } else {
+    silc_list_del(conn->internal->thread_pool, thread);
+    silc_fsm_thread_init(thread, &conn->internal->fsm, conn,
+                        silc_client_packet_destructor, NULL, FALSE);
+  }
 
-  client->conns = silc_realloc(client->conns, sizeof(*client->conns)
-                              * (client->conns_count + 1));
-  client->conns[client->conns_count] = conn;
-  client->conns_count++;
+  /* Process packet in thread */
+  silc_fsm_set_state_context(thread, packet);
+  silc_fsm_start_sync(thread, silc_client_connection_st_packet);
 
-  return conn;
+  return TRUE;
 }
 
-/* Removes connection from client. */
+/* Packet engine callback to indicate end of stream */
 
-void silc_client_del_connection(SilcClient client, SilcClientConnection conn)
+static void silc_client_packet_eos(SilcPacketEngine engine,
+                                  SilcPacketStream stream,
+                                  void *callback_context,
+                                  void *stream_context)
 {
-  int i;
+  SilcClientConnection conn = stream_context;
 
-  for (i = 0; i < client->conns_count; i++)
-    if (client->conns[i] == conn) {
-      silc_free(conn);
-      client->conns[i] = NULL;
-    }
-}
+  SILC_LOG_DEBUG(("Remote disconnected connection"));
 
-/* Internal context for connection process. This is needed as we
-   doing asynchronous connecting. */
-typedef struct {
-  SilcClient client;
-  SilcClientConnection conn;
-  SilcTask task;
-  int sock;
-  char *host;
-  int port;
-  int tries;
-} SilcClientInternalConnectContext;
-
-static int 
-silc_client_connect_to_server_internal(SilcClientInternalConnectContext *ctx)
-{
-  int sock;
-
-  /* XXX In the future we should give up this non-blocking connect all
-     together and use threads instead. */
-  /* Create connection to server asynchronously */
-  sock = silc_net_create_connection_async(ctx->port, ctx->host);
-  if (sock < 0)
-    return -1;
-
-  /* Register task that will receive the async connect and will
-     read the result. */
-  ctx->task = silc_task_register(ctx->client->io_queue, sock, 
-                                silc_client_connect_to_server_start,
-                                (void *)ctx, 0, 0, 
-                                SILC_TASK_FD,
-                                SILC_TASK_PRI_NORMAL);
-  silc_task_reset_iotype(ctx->task, SILC_TASK_WRITE);
-  silc_schedule_set_listen_fd(sock, ctx->task->iomask);
-
-  ctx->sock = sock;
-
-  return sock;
+  /* Signal to close connection */
+  conn->internal->status = SILC_CLIENT_CONN_DISCONNECTED;
+  if (!conn->internal->disconnected) {
+    conn->internal->disconnected = TRUE;
+    SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
+  }
 }
 
-/* Connects to remote server. This is the main routine used to connect
-   to SILC server. Returns -1 on error and the created socket otherwise. 
-   The `context' is user context that is saved into the SilcClientConnection
-   that is created after the connection is created. */
+/* Packet engine callback to indicate error */
 
-int silc_client_connect_to_server(SilcClient client, int port,
-                                 char *host, void *context)
+static void silc_client_packet_error(SilcPacketEngine engine,
+                                    SilcPacketStream stream,
+                                    SilcPacketError error,
+                                    void *callback_context,
+                                    void *stream_context)
 {
-  SilcClientInternalConnectContext *ctx;
-  SilcClientConnection conn;
-  int sock;
-
-  SILC_LOG_DEBUG(("Connecting to port %d of server %s",
-                 port, host));
-
-  conn = silc_client_add_connection(client, host, port, context);
-
-  client->ops->say(client, conn, 
-                  "Connecting to port %d of server %s", port, host);
+  SilcClient client = callback_context;
+  SilcClientConnection conn = stream_context;
 
-  /* Allocate internal context for connection process. This is
-     needed as we are doing async connecting. */
-  ctx = silc_calloc(1, sizeof(*ctx));
-  ctx->client = client;
-  ctx->conn = conn;
-  ctx->host = strdup(host);
-  ctx->port = port;
-  ctx->tries = 0;
+  /* Read and write errors are silent */
+  if (error == SILC_PACKET_ERR_READ || error == SILC_PACKET_ERR_WRITE)
+    return;
 
-  /* Do the actual connecting process */
-  sock = silc_client_connect_to_server_internal(ctx);
-  if (sock == -1)
-    silc_client_del_connection(client, conn);
-  return sock;
+  client->internal->ops->say(client, conn, SILC_CLIENT_MESSAGE_ERROR,
+                            (char *)silc_packet_error_string(error));
 }
 
-/* Start SILC Key Exchange (SKE) protocol to negotiate shared secret
-   key material between client and server.  This function can be called
-   directly if application is performing its own connecting and does not
-   use the connecting provided by this library. */
-
-int silc_client_start_key_exchange(SilcClient client,
-                                  SilcClientConnection conn,
-                                   int fd)
+/* Packet stream callbacks */
+static SilcPacketCallbacks silc_client_stream_cbs =
 {
-  SilcProtocol protocol;
-  SilcClientKEInternalContext *proto_ctx;
-  void *context;
-
-  /* Allocate new socket connection object */
-  silc_socket_alloc(fd, SILC_SOCKET_TYPE_SERVER, (void *)conn, &conn->sock);
-  if (conn->sock == NULL) {
-    client->ops->say(client, conn, 
-                    "Error: Could not allocate connection socket");
-    return FALSE;
-  }
+  silc_client_packet_receive,
+  silc_client_packet_eos,
+  silc_client_packet_error
+};
 
-  conn->nickname = strdup(client->username);
-  conn->sock->hostname = conn->remote_host;
-  conn->sock->port = conn->remote_port;
-
-  /* Allocate internal Key Exchange context. This is sent to the
-     protocol as context. */
-  proto_ctx = silc_calloc(1, sizeof(*proto_ctx));
-  proto_ctx->client = (void *)client;
-  proto_ctx->sock = conn->sock;
-  proto_ctx->rng = client->rng;
-  proto_ctx->responder = FALSE;
-
-  /* Perform key exchange protocol. silc_client_connect_to_server_final
-     will be called after the protocol is finished. */
-  silc_protocol_alloc(SILC_PROTOCOL_CLIENT_KEY_EXCHANGE, 
-                     &protocol, (void *)proto_ctx,
-                     silc_client_connect_to_server_second);
-  if (!protocol) {
-    client->ops->say(client, conn, 
-                    "Error: Could not start authentication protocol");
-    return FALSE;
-  }
-  conn->sock->protocol = protocol;
-
-  /* Register the connection for network input and output. This sets
-     that scheduler will listen for incoming packets for this connection 
-     and sets that outgoing packets may be sent to this connection as well.
-     However, this doesn't set the scheduler for outgoing traffic, it will 
-     be set separately by calling SILC_CLIENT_SET_CONNECTION_FOR_OUTPUT,
-     later when outgoing data is available. */
-  context = (void *)client;
-  SILC_CLIENT_REGISTER_CONNECTION_FOR_IO(fd);
-
-  /* Execute the protocol */
-  protocol->execute(client->timeout_queue, 0, protocol, fd, 0, 0);
-  return TRUE;
-}
+/* FSM destructor */
 
-/* Start of the connection to the remote server. This is called after
-   succesful TCP/IP connection has been established to the remote host. */
-
-SILC_TASK_CALLBACK(silc_client_connect_to_server_start)
+void silc_client_fsm_destructor(SilcFSM fsm, void *fsm_context,
+                               void *destructor_context)
 {
-  SilcClientInternalConnectContext *ctx =
-    (SilcClientInternalConnectContext *)context;
-  SilcClient client = ctx->client;
-  SilcClientConnection conn = ctx->conn;
-  int opt, opt_len = sizeof(opt);
-
-  SILC_LOG_DEBUG(("Start"));
-
-  /* Check the socket status as it might be in error */
-  getsockopt(fd, SOL_SOCKET, SO_ERROR, &opt, &opt_len);
-  if (opt != 0) {
-    if (ctx->tries < 2) {
-      /* Connection failed but lets try again */
-      client->ops->say(client, conn, "Could not connect to server %s: %s",
-                      ctx->host, strerror(opt));
-      client->ops->say(client, conn, 
-                      "Connecting to port %d of server %s resumed", 
-                      ctx->port, ctx->host);
-
-      /* Unregister old connection try */
-      silc_schedule_unset_listen_fd(fd);
-      silc_net_close_connection(fd);
-      silc_task_unregister(client->io_queue, ctx->task);
-
-      /* Try again */
-      silc_client_connect_to_server_internal(ctx);
-      ctx->tries++;
-    } else {
-      /* Connection failed and we won't try anymore */
-      client->ops->say(client, conn, "Could not connect to server %s: %s",
-                      ctx->host, strerror(opt));
-      silc_schedule_unset_listen_fd(fd);
-      silc_net_close_connection(fd);
-      silc_task_unregister(client->io_queue, ctx->task);
-      silc_free(ctx);
-
-      /* Notify application of failure */
-      client->ops->connect(client, conn, FALSE);
-      silc_client_del_connection(client, conn);
-    }
-    return;
-  }
-
-  silc_schedule_unset_listen_fd(fd);
-  silc_task_unregister(client->io_queue, ctx->task);
-  silc_free(ctx);
-
-  if (!silc_client_start_key_exchange(client, conn, fd)) {
-    silc_net_close_connection(fd);
-    client->ops->connect(client, conn, FALSE);
-  }
+  silc_fsm_free(fsm);
 }
 
-/* Second part of the connecting to the server. This executed 
-   authentication protocol. */
+/* Connect abort operation */
 
-SILC_TASK_CALLBACK(silc_client_connect_to_server_second)
+static void silc_client_connect_abort(SilcAsyncOperation op, void *context)
 {
-  SilcProtocol protocol = (SilcProtocol)context;
-  SilcClientKEInternalContext *ctx = 
-    (SilcClientKEInternalContext *)protocol->context;
-  SilcClient client = (SilcClient)ctx->client;
-  SilcSocketConnection sock = NULL;
-  SilcClientConnAuthInternalContext *proto_ctx;
-
-  SILC_LOG_DEBUG(("Start"));
-
-  if (protocol->state == SILC_PROTOCOL_STATE_ERROR) {
-    /* Error occured during protocol */
-    SILC_LOG_DEBUG(("Error during KE protocol"));
-    silc_protocol_free(protocol);
-    if (ctx->ske)
-      silc_ske_free(ctx->ske);
-    if (ctx->dest_id)
-      silc_free(ctx->dest_id);
-    ctx->sock->protocol = NULL;
-
-    /* Notify application of failure */
-    client->ops->connect(client, ctx->sock->user_data, FALSE);
-    silc_free(ctx);
-    return;
-  }
+  SilcClientConnection conn = context;
 
-  /* Allocate internal context for the authentication protocol. This
-     is sent as context for the protocol. */
-  proto_ctx = silc_calloc(1, sizeof(*proto_ctx));
-  proto_ctx->client = (void *)client;
-  proto_ctx->sock = sock = ctx->sock;
-  proto_ctx->ske = ctx->ske;   /* Save SKE object from previous protocol */
-  proto_ctx->dest_id_type = ctx->dest_id_type;
-  proto_ctx->dest_id = ctx->dest_id;
-
-  /* Resolve the authentication method to be used in this connection */
-  if (!client->ops->get_auth_method(client, sock->user_data, sock->hostname,
-                                   sock->port, &proto_ctx->auth_meth,
-                                   &proto_ctx->auth_data, 
-                                   &proto_ctx->auth_data_len))
-    {
-      /* XXX do AUTH_REQUEST resolcing with server */
-      proto_ctx->auth_meth = SILC_PROTOCOL_CONN_AUTH_NONE;
-    }
+  SILC_LOG_DEBUG(("Connection %p aborted by application", conn));
 
-  /* Free old protocol as it is finished now */
-  silc_protocol_free(protocol);
-  if (ctx->packet)
-    silc_buffer_free(ctx->packet);
-  silc_free(ctx);
-  /* silc_free(ctx->keymat....); */
-  sock->protocol = NULL;
-
-  /* Allocate the authentication protocol. This is allocated here
-     but we won't start it yet. We will be receiving party of this
-     protocol thus we will wait that connecting party will make
-     their first move. */
-  silc_protocol_alloc(SILC_PROTOCOL_CLIENT_CONNECTION_AUTH, 
-                     &sock->protocol, (void *)proto_ctx, 
-                     silc_client_connect_to_server_final);
-
-  /* Execute the protocol */
-  sock->protocol->execute(client->timeout_queue, 0, sock->protocol, fd, 0, 0);
-}
+  /* Connection callback will not be called after user aborted connecting */
+  conn->callback = NULL;
+  conn->internal->cop = NULL;
 
-/* Finalizes the connection to the remote SILC server. This is called
-   after authentication protocol has been completed. This send our
-   user information to the server to receive our client ID from
-   server. */
+  /* Signal to close connection */
+  if (!conn->internal->disconnected) {
+    conn->internal->disconnected = TRUE;
 
-SILC_TASK_CALLBACK(silc_client_connect_to_server_final)
-{
-  SilcProtocol protocol = (SilcProtocol)context;
-  SilcClientConnAuthInternalContext *ctx = 
-    (SilcClientConnAuthInternalContext *)protocol->context;
-  SilcClient client = (SilcClient)ctx->client;
-  SilcClientConnection conn = (SilcClientConnection)ctx->sock->user_data;
-  SilcBuffer packet;
-
-  SILC_LOG_DEBUG(("Start"));
-
-  if (protocol->state == SILC_PROTOCOL_STATE_ERROR) {
-    /* Error occured during protocol */
-    SILC_LOG_DEBUG(("Error during authentication protocol"));
-    silc_protocol_free(protocol);
-    if (ctx->auth_data)
-      silc_free(ctx->auth_data);
-    if (ctx->ske)
-      silc_ske_free(ctx->ske);
-    if (ctx->dest_id)
-      silc_free(ctx->dest_id);
-    conn->sock->protocol = NULL;
-
-    /* Notify application of failure */
-    client->ops->connect(client, ctx->sock->user_data, FALSE);
-    silc_free(ctx);
-    return;
+    /* If user aborts before connection machine is even up yet, then don't
+       send signal yet.  It will process this event when it comes up. */
+    if (silc_fsm_is_started(&conn->internal->fsm))
+      SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
   }
-
-  /* Send NEW_CLIENT packet to the server. We will become registered
-     to the SILC network after sending this packet and we will receive
-     client ID from the server. */
-  packet = silc_buffer_alloc(2 + 2 + strlen(client->username) + 
-                            strlen(client->realname));
-  silc_buffer_pull_tail(packet, SILC_BUFFER_END(packet));
-  silc_buffer_format(packet,
-                    SILC_STR_UI_SHORT(strlen(client->username)),
-                    SILC_STR_UI_XNSTRING(client->username,
-                                         strlen(client->username)),
-                    SILC_STR_UI_SHORT(strlen(client->realname)),
-                    SILC_STR_UI_XNSTRING(client->realname,
-                                         strlen(client->realname)),
-                    SILC_STR_END);
-
-  /* Send the packet */
-  silc_client_packet_send(client, ctx->sock, SILC_PACKET_NEW_CLIENT,
-                         NULL, 0, NULL, NULL, 
-                         packet->data, packet->len, TRUE);
-  silc_buffer_free(packet);
-
-  /* Save remote ID. */
-  conn->remote_id = ctx->dest_id;
-  conn->remote_id_data = silc_id_id2str(ctx->dest_id, SILC_ID_SERVER);
-  conn->remote_id_data_len = SILC_ID_SERVER_LEN;
-
-  /* Notify application of successful connection */
-  client->ops->connect(client, conn, TRUE);
-
-  silc_protocol_free(protocol);
-  if (ctx->auth_data)
-    silc_free(ctx->auth_data);
-  if (ctx->ske)
-    silc_ske_free(ctx->ske);
-  if (ctx->dest_id)
-    silc_free(ctx->dest_id);
-  silc_free(ctx);
-  conn->sock->protocol = NULL;
 }
 
-/* Internal routine that sends packet or marks packet to be sent. This
-   is used directly only in special cases. Normal cases should use
-   silc_server_packet_send. Returns < 0 on error. */
-
-static int silc_client_packet_send_real(SilcClient client,
-                                       SilcSocketConnection sock,
-                                       int force_send)
-{
-  int ret;
-
-  /* Send the packet */
-  ret = silc_packet_send(sock, force_send);
-  if (ret != -2)
-    return ret;
+/************************** Connection's machine ****************************/
 
-  /* Mark that there is some outgoing data available for this connection. 
-     This call sets the connection both for input and output (the input
-     is set always and this call keeps the input setting, actually). 
-     Actual data sending is performed by silc_client_packet_process. */
-  SILC_CLIENT_SET_CONNECTION_FOR_OUTPUT(sock->sock);
+/* Start the connection's state machine.  If threads are in use the machine
+   is always executed in a real thread. */
 
-  /* Mark to socket that data is pending in outgoing buffer. This flag
-     is needed if new data is added to the buffer before the earlier
-     put data is sent to the network. */
-  SILC_SET_OUTBUF_PENDING(sock);
-
-  return 0;
+SILC_FSM_STATE(silc_client_connection_st_start)
+{
+  SilcClientConnection conn = fsm_context;
+  SilcFSM connfsm;
+
+  /* Take scheduler for connection */
+  conn->internal->schedule = silc_fsm_get_schedule(fsm);
+
+  /*** Run connection machine */
+  connfsm = &conn->internal->fsm;
+  silc_fsm_init(connfsm, conn, silc_client_connection_destructor,
+               fsm, conn->internal->schedule);
+  silc_fsm_event_init(&conn->internal->wait_event, connfsm);
+  silc_fsm_start_sync(connfsm, silc_client_connection_st_run);
+
+  /* Schedule any events possibly set in initialization */
+  if (conn->internal->disconnected)
+    SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
+  if (conn->internal->connect)
+    SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
+  if (conn->internal->key_exchange)
+    SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
+
+  /* Wait until this thread is terminated from the machine destructor */
+  return SILC_FSM_WAIT;
 }
 
-/* Packet processing callback. This is used to send and receive packets
-   from network. This is generic task. */
+/* Connection machine main state.  This handles various connection related
+   events, but not packet processing.  It's done in dedicated packet
+   processing FSM thread. */
 
-SILC_TASK_CALLBACK(silc_client_packet_process)
+SILC_FSM_STATE(silc_client_connection_st_run)
 {
-  SilcClient client = (SilcClient)context;
-  SilcSocketConnection sock = NULL;
-  SilcClientConnection conn;
-  int ret;
-
-  SILC_LOG_DEBUG(("Processing packet"));
-
-  SILC_CLIENT_GET_SOCK(client, fd, sock);
-  if (sock == NULL)
-    return;
-
-  conn = (SilcClientConnection)sock->user_data;
-
-  /* Packet sending */
-  if (type == SILC_TASK_WRITE) {
-    SILC_LOG_DEBUG(("Writing data to connection"));
+  SilcClientConnection conn = fsm_context;
+  SilcFSMThread thread;
 
-    if (sock->outbuf->data - sock->outbuf->head)
-      silc_buffer_push(sock->outbuf, 
-                      sock->outbuf->data - sock->outbuf->head);
+  /* Wait for events */
+  SILC_FSM_EVENT_WAIT(&conn->internal->wait_event);
 
-    ret = silc_client_packet_send_real(client, sock, TRUE);
+  /* Process events */
+  thread = &conn->internal->event_thread;
 
-    /* If returned -2 could not write to connection now, will do
-       it later. */
-    if (ret == -2)
-      return;
-    
-    /* The packet has been sent and now it is time to set the connection
-       back to only for input. When there is again some outgoing data 
-       available for this connection it will be set for output as well. 
-       This call clears the output setting and sets it only for input. */
-    SILC_CLIENT_SET_CONNECTION_FOR_INPUT(fd);
-    SILC_UNSET_OUTBUF_PENDING(sock);
-
-    silc_buffer_clear(sock->outbuf);
-    return;
+  if (conn->internal->disconnected) {
+    /** Event: disconnected */
+    SILC_LOG_DEBUG(("Event: disconnected"));
+    silc_fsm_next(fsm, silc_client_connection_st_close);
+    return SILC_FSM_YIELD;
   }
 
-  /* Packet receiving */
-  if (type == SILC_TASK_READ) {
-    SILC_LOG_DEBUG(("Reading data from connection"));
-
-    /* Read data from network */
-    ret = silc_packet_receive(sock);
-    if (ret < 0)
-      return;
-    
-    /* EOF */
-    if (ret == 0) {
-      SILC_LOG_DEBUG(("Read EOF"));
-
-      /* If connection is disconnecting already we will finally
-        close the connection */
-      if (SILC_IS_DISCONNECTING(sock)) {
-       client->ops->disconnect(client, conn);
-       silc_client_close_connection(client, sock);
-       return;
-      }
-      
-      client->ops->say(client, conn, "Connection closed: premature EOF");
-      SILC_LOG_DEBUG(("Premature EOF from connection %d", sock->sock));
-      client->ops->disconnect(client, conn);
-      silc_client_close_connection(client, sock);
-      return;
-    }
+  if (conn->internal->connect) {
+    SILC_LOG_DEBUG(("Event: connect"));
+    conn->internal->connect = FALSE;
+    SILC_ASSERT(silc_fsm_is_started(thread) == FALSE);
 
-    /* Process the packet. This will call the parser that will then
-       decrypt and parse the packet. */
-    silc_packet_receive_process(sock, conn->receive_key, conn->hmac,
-                               silc_client_packet_parse, client);
+    /*** Event: connect */
+    silc_fsm_thread_init(thread, &conn->internal->fsm, conn,
+                        NULL, NULL, FALSE);
+    silc_fsm_start_sync(thread, silc_client_st_connect);
+    return SILC_FSM_CONTINUE;
   }
-}
 
-/* Parses whole packet, received earlier. */
+  if (conn->internal->key_exchange) {
+    SILC_LOG_DEBUG(("Event: key exchange"));
+    conn->internal->key_exchange = FALSE;
+    SILC_ASSERT(silc_fsm_is_started(thread) == FALSE);
 
-SILC_TASK_CALLBACK(silc_client_packet_parse_real)
-{
-  SilcPacketParserContext *parse_ctx = (SilcPacketParserContext *)context;
-  SilcClient client = (SilcClient)parse_ctx->context;
-  SilcPacketContext *packet = parse_ctx->packet;
-  SilcBuffer buffer = packet->buffer;
-  SilcSocketConnection sock = parse_ctx->sock;
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  int ret;
-
-  SILC_LOG_DEBUG(("Start"));
-
-  /* Decrypt the received packet */
-  ret = silc_packet_decrypt(conn->receive_key, conn->hmac, buffer, packet);
-  if (ret < 0)
-    goto out;
-
-  if (ret == 0) {
-    /* Parse the packet. Packet type is returned. */
-    ret = silc_packet_parse(packet);
-  } else {
-    /* Parse the packet header in special way as this is "special"
-       packet type. */
-    ret = silc_packet_parse_special(packet);
+    /*** Event: key exchange */
+    silc_fsm_thread_init(thread, &conn->internal->fsm, conn,
+                        NULL, NULL, FALSE);
+    silc_fsm_start_sync(thread, silc_client_st_connect_set_stream);
+    return SILC_FSM_CONTINUE;
   }
 
-  if (ret == SILC_PACKET_NONE)
-    goto out;
+  if (conn->internal->rekeying) {
+    SILC_LOG_DEBUG(("Event: rekey"));
+    conn->internal->rekeying = FALSE;
+    SILC_ASSERT(silc_fsm_is_started(thread) == FALSE);
 
-  /* Parse the incoming packet type */
-  silc_client_packet_parse_type(client, sock, packet);
+    /*** Event: rekey */
+    silc_fsm_thread_init(thread, &conn->internal->fsm, conn,
+                        NULL, NULL, FALSE);
+    silc_fsm_start_sync(thread, silc_client_st_rekey);
+    return SILC_FSM_CONTINUE;
+  }
 
- out:
-  silc_buffer_clear(buffer);
-  if (packet->src_id)
-    silc_free(packet->src_id);
-  if (packet->dst_id)
-    silc_free(packet->dst_id);
-  silc_free(packet);
-  silc_free(parse_ctx);
+  /* NOT REACHED */
+  SILC_ASSERT(FALSE);
+  return SILC_FSM_CONTINUE;
 }
 
-/* Parser callback called by silc_packet_receive_process. Thie merely
-   registers timeout that will handle the actual parsing when appropriate. */
+/* Packet processor thread.  Each incoming packet is processed in FSM
+   thread in this state.  The thread is run in the connection machine. */
 
-void silc_client_packet_parse(SilcPacketParserContext *parser_context)
+SILC_FSM_STATE(silc_client_connection_st_packet)
 {
-  SilcClient client = (SilcClient)parser_context->context;
-
-  /* Parse the packet */
-  silc_task_register(client->timeout_queue, parser_context->sock->sock, 
-                    silc_client_packet_parse_real,
-                    (void *)parser_context, 0, 1, 
-                    SILC_TASK_TIMEOUT,
-                    SILC_TASK_PRI_NORMAL);
-}
-  
-/* Parses the packet type and calls what ever routines the packet type
-   requires. This is done for all incoming packets. */
+  SilcClientConnection conn = fsm_context;
+  SilcPacket packet = state_context;
 
-void silc_client_packet_parse_type(SilcClient client, 
-                                  SilcSocketConnection sock,
-                                  SilcPacketContext *packet)
-{
-  SilcBuffer buffer = packet->buffer;
-  SilcPacketType type = packet->type;
+  SILC_LOG_DEBUG(("Parsing %s packet", silc_get_packet_name(packet->type)));
 
-  SILC_LOG_DEBUG(("Parsing packet type %d", type));
+  switch (packet->type) {
 
-  /* Parse the packet type */
-  switch(type) {
-  case SILC_PACKET_DISCONNECT:
-    silc_client_disconnected_by_server(client, sock, buffer);
+  case SILC_PACKET_PRIVATE_MESSAGE:
+    /** Private message */
+    silc_fsm_next(fsm, silc_client_private_message);
     break;
-  case SILC_PACKET_SUCCESS:
-    /*
-     * Success received for something. For now we can have only
-     * one protocol for connection executing at once hence this
-     * success message is for whatever protocol is executing currently.
-     */
-    if (sock->protocol) {
-      sock->protocol->execute(client->timeout_queue, 0,
-                             sock->protocol, sock->sock, 0, 0);
-    }
+
+  case SILC_PACKET_CHANNEL_MESSAGE:
+    /** Channel message */
+    silc_fsm_next(fsm, silc_client_channel_message);
     break;
-  case SILC_PACKET_FAILURE:
-    /*
-     * Failure received for some protocol. Set the protocol state to 
-     * error and call the protocol callback. This fill cause error on
-     * protocol and it will call the final callback.
-     */
-    if (sock->protocol) {
-      sock->protocol->state = SILC_PROTOCOL_STATE_FAILURE;
-      sock->protocol->execute(client->timeout_queue, 0,
-                             sock->protocol, sock->sock, 0, 0);
-
-      /* XXX We have only two protocols currently thus we know what this
-        failure indication is. */
-      if (buffer->len >= 4) {
-       unsigned int failure;
-
-       SILC_GET32_MSB(failure, buffer->data);
-
-       /* Notify application */
-       client->ops->failure(client, sock->user_data, sock->protocol,
-                            (void *)failure);
-      }
-    }
+
+  case SILC_PACKET_FTP:
+    /* File transfer packet */
+    silc_fsm_next(fsm, silc_client_ftp);
     break;
-  case SILC_PACKET_REJECT:
+
+  case SILC_PACKET_CHANNEL_KEY:
+    /** Channel key */
+    silc_fsm_next(fsm, silc_client_channel_key);
+    break;
+
+  case SILC_PACKET_COMMAND_REPLY:
+    /** Command reply */
+    silc_fsm_next(fsm, silc_client_command_reply);
     break;
 
   case SILC_PACKET_NOTIFY:
-    /*
-     * Received notify message 
-     */
-    silc_client_notify_by_server(client, sock, packet);
+    /** Notify */
+    silc_fsm_next(fsm, silc_client_notify);
     break;
 
-  case SILC_PACKET_ERROR:
-    /*
-     * Received error message
-     */
-    silc_client_error_by_server(client, sock, buffer);
+  case SILC_PACKET_PRIVATE_MESSAGE_KEY:
+    /* Private message key indicator */
+    silc_fsm_next(fsm, silc_client_private_message_key);
     break;
 
-  case SILC_PACKET_CHANNEL_MESSAGE:
-    /*
-     * Received message to (from, actually) a channel
-     */
-    silc_client_channel_message(client, sock, packet);
+  case SILC_PACKET_DISCONNECT:
+    /** Disconnect */
+    silc_fsm_next(fsm, silc_client_disconnect);
     break;
-  case SILC_PACKET_CHANNEL_KEY:
-    /*
-     * Received key for a channel. By receiving this key the client will be
-     * able to talk to the channel it has just joined. This can also be
-     * a new key for existing channel as keys expire peridiocally.
-     */
-    silc_client_receive_channel_key(client, sock, buffer);
+
+  case SILC_PACKET_ERROR:
+    /* Error by server */
+    silc_fsm_next(fsm, silc_client_error);
     break;
 
-  case SILC_PACKET_PRIVATE_MESSAGE:
-    /*
-     * Received private message
-     */
-    silc_client_private_message(client, sock, packet);
+  case SILC_PACKET_KEY_AGREEMENT:
+    /** Key agreement */
+    silc_fsm_next(fsm, silc_client_key_agreement);
     break;
-  case SILC_PACKET_PRIVATE_MESSAGE_KEY:
-    /*
-     * Received private message key
-     */
+
+  case SILC_PACKET_COMMAND:
+    /** Command packet */
+    silc_fsm_next(fsm, silc_client_command);
     break;
 
-  case SILC_PACKET_COMMAND_REPLY:
-    /*
-     * Recived reply for a command
-     */
-    silc_client_command_reply_process(client, sock, packet);
+  case SILC_PACKET_NEW_ID:
+    /** New ID */
+    silc_fsm_next(fsm, silc_client_new_id);
     break;
 
-  case SILC_PACKET_KEY_EXCHANGE:
-    if (sock->protocol) {
-      SilcClientKEInternalContext *proto_ctx = 
-       (SilcClientKEInternalContext *)sock->protocol->context;
-
-      proto_ctx->packet = buffer;
-      proto_ctx->dest_id_type = packet->src_id_type;
-      proto_ctx->dest_id = silc_id_str2id(packet->src_id, packet->src_id_type);
-
-      /* Let the protocol handle the packet */
-      sock->protocol->execute(client->timeout_queue, 0,
-                             sock->protocol, sock->sock, 0, 0);
-    } else {
-      SILC_LOG_ERROR(("Received Key Exchange packet but no key exchange "
-                     "protocol active, packet dropped."));
-
-      /* XXX Trigger KE protocol?? Rekey actually! */
-    }
+  case SILC_PACKET_CONNECTION_AUTH_REQUEST:
+    /** Connection auth resolve reply */
+    silc_fsm_next(fsm, silc_client_connect_auth_request);
     break;
 
-  case SILC_PACKET_KEY_EXCHANGE_1:
-    if (sock->protocol) {
+  case SILC_PACKET_REKEY:
+    /* Signal to start rekey */
+    conn->internal->rekey_responder = TRUE;
+    conn->internal->rekeying = TRUE;
+    SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
 
-    } else {
-      SILC_LOG_ERROR(("Received Key Exchange 1 packet but no key exchange "
-                     "protocol active, packet dropped."));
-    }
-    break;
-  case SILC_PACKET_KEY_EXCHANGE_2:
-    if (sock->protocol) {
-      SilcClientKEInternalContext *proto_ctx = 
-       (SilcClientKEInternalContext *)sock->protocol->context;
-
-      if (proto_ctx->packet)
-       silc_buffer_free(proto_ctx->packet);
-
-      proto_ctx->packet = buffer;
-      proto_ctx->dest_id_type = packet->src_id_type;
-      proto_ctx->dest_id = silc_id_str2id(packet->src_id, packet->src_id_type);
-
-      /* Let the protocol handle the packet */
-      sock->protocol->execute(client->timeout_queue, 0,
-                             sock->protocol, sock->sock, 0, 0);
-    } else {
-      SILC_LOG_ERROR(("Received Key Exchange 2 packet but no key exchange "
-                     "protocol active, packet dropped."));
-    }
+    silc_packet_free(packet);
+    return SILC_FSM_FINISH;
     break;
 
-  case SILC_PACKET_NEW_ID:
-    {
-      /*
-       * Received new ID from server. This packet is received at
-       * the connection to the server.  New ID is also received when 
-       * user changes nickname but in that case the new ID is received
-       * as command reply and not as this packet type.
-       */
-      SilcIDPayload idp;
-
-      idp = silc_id_payload_parse(buffer);
-      if (silc_id_payload_get_type(idp) != SILC_ID_CLIENT)
-       break;
-
-      silc_client_receive_new_id(client, sock, idp);
-      silc_id_payload_free(idp);
-      break;
-    }
-
   default:
-    SILC_LOG_DEBUG(("Incorrect packet type %d, packet dropped", type));
+    silc_packet_free(packet);
+    return SILC_FSM_FINISH;
     break;
   }
-}
 
-/* Sends packet. This doesn't actually send the packet instead it assembles
-   it and marks it to be sent. However, if force_send is TRUE the packet
-   is sent immediately. if dst_id, cipher and hmac are NULL those parameters
-   will be derived from sock argument. Otherwise the valid arguments sent
-   are used. */
-
-void silc_client_packet_send(SilcClient client, 
-                            SilcSocketConnection sock,
-                            SilcPacketType type, 
-                            void *dst_id,
-                            SilcIdType dst_id_type,
-                            SilcCipher cipher,
-                            SilcHmac hmac,
-                            unsigned char *data, 
-                            unsigned int data_len, 
-                            int force_send)
-{
-  SilcPacketContext packetdata;
+  return SILC_FSM_CONTINUE;
+}
 
-  SILC_LOG_DEBUG(("Sending packet, type %d", type));
+/* Disconnection event to close remote connection.  We close the connection
+   and finish the connection machine in this state.  The connection context
+   is deleted in the machine destructor.  The connection callback is called
+   in this state if it is set. */
 
-  /* Get data used in the packet sending, keys and stuff */
-  if ((!cipher || !hmac || !dst_id) && sock->user_data) {
-    if (!cipher && ((SilcClientConnection)sock->user_data)->send_key)
-      cipher = ((SilcClientConnection)sock->user_data)->send_key;
+SILC_FSM_STATE(silc_client_connection_st_close)
+{
+  SilcClientConnection conn = fsm_context;
+  SilcClientCommandContext cmd;
+
+  /* Finish running command threads.  This will also finish waiting packet
+     thread, as they are always waiting for some command.  If any thread is
+     waiting something else than command, they must be finished explicitly. */
+  if (silc_list_count(conn->internal->pending_commands)) {
+    SILC_LOG_DEBUG(("Finish pending commands"));
+    silc_list_start(conn->internal->pending_commands);
+    while ((cmd = silc_list_get(conn->internal->pending_commands))) {
+      if (silc_fsm_is_started(&cmd->thread)) {
+        cmd->verbose = FALSE;
+        silc_fsm_continue_sync(&cmd->thread);
+      }
+    }
 
-    if (!hmac && ((SilcClientConnection)sock->user_data)->hmac)
-      hmac = ((SilcClientConnection)sock->user_data)->hmac;
+    /* Give threads time to finish */
+    return SILC_FSM_YIELD;
+  }
 
-    if (!dst_id && ((SilcClientConnection)sock->user_data)->remote_id) {
-      dst_id = ((SilcClientConnection)sock->user_data)->remote_id;
-      dst_id_type = SILC_ID_SERVER;
-    }
+  /* Abort ongoing event */
+  if (conn->internal->op) {
+    SILC_LOG_DEBUG(("Abort event"));
+    silc_async_abort(conn->internal->op, NULL, NULL);
+    conn->internal->op = NULL;
   }
 
-  /* Set the packet context pointers */
-  packetdata.flags = 0;
-  packetdata.type = type;
-  if (((SilcClientConnection)sock->user_data)->local_id_data)
-    packetdata.src_id = ((SilcClientConnection)sock->user_data)->local_id_data;
-  else 
-    packetdata.src_id = silc_calloc(SILC_ID_CLIENT_LEN, sizeof(unsigned char));
-  packetdata.src_id_len = SILC_ID_CLIENT_LEN;
-  packetdata.src_id_type = SILC_ID_CLIENT;
-  if (dst_id) {
-    packetdata.dst_id = silc_id_id2str(dst_id, dst_id_type);
-    packetdata.dst_id_len = silc_id_get_len(dst_id_type);
-    packetdata.dst_id_type = dst_id_type;
-  } else {
-    packetdata.dst_id = NULL;
-    packetdata.dst_id_len = 0;
-    packetdata.dst_id_type = SILC_ID_NONE;
+  /* If event thread is running, finish it. */
+  if (silc_fsm_is_started(&conn->internal->event_thread)) {
+    SILC_LOG_DEBUG(("Finish event thread"));
+    silc_fsm_continue_sync(&conn->internal->event_thread);
+    return SILC_FSM_YIELD;
   }
-  packetdata.rng = client->rng;
-  packetdata.truelen = data_len + SILC_PACKET_HEADER_LEN + 
-    packetdata.src_id_len + packetdata.dst_id_len;
-  packetdata.padlen = SILC_PACKET_PADLEN(packetdata.truelen);
 
-  /* Prepare outgoing data buffer for packet sending */
-  silc_packet_send_prepare(sock, 
-                          SILC_PACKET_HEADER_LEN +
-                          packetdata.src_id_len + 
-                          packetdata.dst_id_len,
-                          packetdata.padlen,
-                          data_len);
+  /* Call the connection callback */
+  if (conn->callback)
+    conn->callback(conn->client, conn, conn->internal->status,
+                  conn->internal->error, conn->internal->disconnect_message,
+                  conn->callback_context);
+  silc_free(conn->internal->disconnect_message);
 
-  SILC_LOG_DEBUG(("Putting data to outgoing buffer, len %d", data_len));
+  SILC_LOG_DEBUG(("Closing remote connection"));
 
-  packetdata.buffer = sock->outbuf;
+  /* Close connection. */
+  if (conn->stream)
+    silc_packet_stream_destroy(conn->stream);
 
-  /* Put the data to the buffer */
-  if (data && data_len)
-    silc_buffer_put(sock->outbuf, data, data_len);
+  SILC_LOG_DEBUG(("Finishing connection machine"));
+  return SILC_FSM_FINISH;
+}
 
-  /* Create the outgoing packet */
-  silc_packet_assemble(&packetdata);
+/* Received error packet from server.  Send it to application. */
 
-  /* Encrypt the packet */
-  if (cipher)
-    silc_packet_encrypt(cipher, hmac, sock->outbuf, sock->outbuf->len);
+SILC_FSM_STATE(silc_client_error)
+{
+  SilcClientConnection conn = fsm_context;
+  SilcClient client = conn->client;
+  SilcPacket packet = state_context;
+  char *msg;
 
-  SILC_LOG_HEXDUMP(("Packet, len %d", sock->outbuf->len),
-                  sock->outbuf->data, sock->outbuf->len);
+  msg = silc_memdup(silc_buffer_data(&packet->buffer),
+                   silc_buffer_len(&packet->buffer));
+  if (msg)
+    client->internal->ops->say(client, conn, SILC_CLIENT_MESSAGE_AUDIT, msg);
+
+  silc_free(msg);
+  silc_packet_free(packet);
 
-  /* Now actually send the packet */
-  silc_client_packet_send_real(client, sock, force_send);
+  return SILC_FSM_FINISH;
 }
 
-/* Sends packet to a channel. Packet to channel is always encrypted
-   differently from "normal" packets. SILC header of the packet is 
-   encrypted with the next receiver's key and the rest of the packet is
-   encrypted with the channel specific key. Padding and HMAC is computed
-   with the next receiver's key. */
-
-void silc_client_packet_send_to_channel(SilcClient client, 
-                                       SilcSocketConnection sock,
-                                       SilcChannelEntry channel,
-                                       unsigned char *data, 
-                                       unsigned int data_len, 
-                                       int force_send)
-{
-  int i;
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  SilcBuffer payload;
-  SilcPacketContext packetdata;
-  SilcCipher cipher;
-  SilcHmac hmac;
-  unsigned char *id_string;
-
-  SILC_LOG_DEBUG(("Sending packet to channel"));
-
-  if (!channel || !channel->key) {
-    client->ops->say(client, conn, 
-                    "Cannot talk to channel: key does not exist");
-    return;
-  }
+/* Received disconnect packet from server.  We close the connection and
+   send the disconnect message to application. */
 
-  /* Generate IV */
-  if (!channel->iv)
-    for (i = 0; i < 16; i++)
-      channel->iv[i] = silc_rng_get_byte(client->rng);
-  else
-    silc_hash_make(client->md5hash, channel->iv, 16, channel->iv);
-
-  /* Encode the channel payload */
-  payload = silc_channel_payload_encode(data_len, data, 16, channel->iv, 
-                                       client->rng);
-  if (!payload) {
-    client->ops->say(client, conn, 
-                    "Error: Could not create packet to be sent to channel");
-    return;
-  }
+SILC_FSM_STATE(silc_client_disconnect)
+{
+  SilcClientConnection conn = fsm_context;
+  SilcPacket packet = state_context;
+  SilcStatus status;
+  char *message = NULL;
 
-  /* Get data used in packet header encryption, keys and stuff. Rest
-     of the packet (the payload) is, however, encrypted with the 
-     specified channel key. */
-  cipher = conn->send_key;
-  hmac = conn->hmac;
-  id_string = silc_id_id2str(channel->id, SILC_ID_CHANNEL);
-
-  /* Set the packet context pointers. The destination ID is always
-     the Channel ID of the channel. Server and router will handle the
-     distribution of the packet. */
-  packetdata.flags = 0;
-  packetdata.type = SILC_PACKET_CHANNEL_MESSAGE;
-  packetdata.src_id = conn->local_id_data;
-  packetdata.src_id_len = SILC_ID_CLIENT_LEN;
-  packetdata.src_id_type = SILC_ID_CLIENT;
-  packetdata.dst_id = id_string;
-  packetdata.dst_id_len = SILC_ID_CHANNEL_LEN;
-  packetdata.dst_id_type = SILC_ID_CHANNEL;
-  packetdata.rng = client->rng;
-  packetdata.truelen = payload->len + SILC_PACKET_HEADER_LEN + 
-    packetdata.src_id_len + packetdata.dst_id_len;
-  packetdata.padlen = SILC_PACKET_PADLEN((SILC_PACKET_HEADER_LEN +
-                                         packetdata.src_id_len +
-                                         packetdata.dst_id_len));
-
-  /* Prepare outgoing data buffer for packet sending */
-  silc_packet_send_prepare(sock, 
-                          SILC_PACKET_HEADER_LEN +
-                          packetdata.src_id_len + 
-                          packetdata.dst_id_len,
-                          packetdata.padlen,
-                          payload->len);
-
-  packetdata.buffer = sock->outbuf;
-
-  /* Encrypt payload of the packet. This is encrypted with the channel key. */
-  channel->channel_key->cipher->encrypt(channel->channel_key->context,
-                                       payload->data, payload->data,
-                                       payload->len - 16, /* -IV_LEN */
-                                       channel->iv);
-
-  /* Put the actual encrypted payload data into the buffer. */
-  silc_buffer_put(sock->outbuf, payload->data, payload->len);
-
-  /* Create the outgoing packet */
-  silc_packet_assemble(&packetdata);
-
-  /* Encrypt the header and padding of the packet. This is encrypted 
-     with normal session key shared with our server. */
-  silc_packet_encrypt(cipher, hmac, sock->outbuf, SILC_PACKET_HEADER_LEN + 
-                     packetdata.src_id_len + packetdata.dst_id_len +
-                     packetdata.padlen);
-
-  SILC_LOG_HEXDUMP(("Packet to channel, len %d", sock->outbuf->len),
-                  sock->outbuf->data, sock->outbuf->len);
-
-  /* Now actually send the packet */
-  silc_client_packet_send_real(client, sock, force_send);
-  silc_buffer_free(payload);
-  silc_free(id_string);
-}
+  SILC_LOG_DEBUG(("Server disconnected"));
 
-/* Sends private message to remote client. If private message key has
-   not been set with this client then the message will be encrypted using
-   normal session keys. Private messages are special packets in SILC
-   network hence we need this own function for them. This is similiar
-   to silc_client_packet_send_to_channel except that we send private
-   message. */
-
-void silc_client_packet_send_private_message(SilcClient client,
-                                            SilcSocketConnection sock,
-                                            SilcClientEntry client_entry,
-                                            unsigned char *data, 
-                                            unsigned int data_len, 
-                                            int force_send)
-{
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  SilcBuffer buffer;
-  SilcPacketContext packetdata;
-  unsigned int nick_len;
-  SilcCipher cipher;
-  SilcHmac hmac;
-
-  SILC_LOG_DEBUG(("Sending private message"));
-
-  /* Create private message payload */
-  nick_len = strlen(conn->nickname);
-  buffer = silc_buffer_alloc(2 + nick_len + data_len);
-  silc_buffer_pull_tail(buffer, SILC_BUFFER_END(buffer));
-  silc_buffer_format(buffer,
-                    SILC_STR_UI_SHORT(nick_len),
-                    SILC_STR_UI_XNSTRING(conn->nickname,
-                                         nick_len),
-                    SILC_STR_UI_XNSTRING(data, data_len),
-                    SILC_STR_END);
-
-  /* If we don't have private message specific key then private messages
-     are just as any normal packet thus call normal packet sending.  If
-     the key exist then the encryption process is a bit different and
-     will be done in the rest of this function. */
-  if (!client_entry->send_key) {
-    silc_client_packet_send(client, sock, SILC_PACKET_PRIVATE_MESSAGE,
-                           client_entry->id, SILC_ID_CLIENT, NULL, NULL,
-                           buffer->data, buffer->len, force_send);
-    goto out;
+  if (silc_buffer_len(&packet->buffer) < 1) {
+    silc_packet_free(packet);
+    return SILC_FSM_FINISH;
   }
 
-  /* We have private message specific key */
-
-  /* Get data used in the encryption */
-  cipher = client_entry->send_key;
-  hmac = conn->hmac;
-
-  /* Set the packet context pointers. */
-  packetdata.flags = 0;
-  packetdata.type = SILC_PACKET_PRIVATE_MESSAGE;
-  packetdata.src_id = conn->local_id_data;
-  packetdata.src_id_len = SILC_ID_CLIENT_LEN;
-  packetdata.src_id_type = SILC_ID_CLIENT;
-  if (client_entry)
-    packetdata.dst_id = silc_id_id2str(client_entry->id, SILC_ID_CLIENT);
-  else
-    packetdata.dst_id = conn->local_id_data;
-  packetdata.dst_id_len = SILC_ID_CLIENT_LEN;
-  packetdata.dst_id_type = SILC_ID_CLIENT;
-  packetdata.rng = client->rng;
-  packetdata.truelen = buffer->len + SILC_PACKET_HEADER_LEN + 
-    packetdata.src_id_len + packetdata.dst_id_len;
-  packetdata.padlen = SILC_PACKET_PADLEN((SILC_PACKET_HEADER_LEN +
-                                         packetdata.src_id_len +
-                                         packetdata.dst_id_len));
-
-  /* Prepare outgoing data buffer for packet sending */
-  silc_packet_send_prepare(sock, 
-                          SILC_PACKET_HEADER_LEN +
-                          packetdata.src_id_len + 
-                          packetdata.dst_id_len,
-                          packetdata.padlen,
-                          buffer->len);
-  
-  packetdata.buffer = sock->outbuf;
-
-  /* Encrypt payload of the packet. Encrypt with private message specific
-     key if it exist, otherwise with session key. */
-  cipher->cipher->encrypt(cipher->context, buffer->data, buffer->data,
-                         buffer->len, cipher->iv);
-      
-  /* Put the actual encrypted payload data into the buffer. */
-  silc_buffer_put(sock->outbuf, buffer->data, buffer->len);
-
-  /* Create the outgoing packet */
-  silc_packet_assemble(&packetdata);
-
-  /* Encrypt the header and padding of the packet. */
-  silc_packet_encrypt(cipher, hmac, sock->outbuf, SILC_PACKET_HEADER_LEN + 
-                     packetdata.src_id_len + packetdata.dst_id_len +
-                     packetdata.padlen);
-
-  SILC_LOG_HEXDUMP(("Private message packet, len %d", sock->outbuf->len),
-                  sock->outbuf->data, sock->outbuf->len);
-
-  /* Now actually send the packet */
-  silc_client_packet_send_real(client, sock, force_send);
-  silc_free(packetdata.dst_id);
-
- out:
-  silc_free(buffer);
-}     
-
-/* Closes connection to remote end. Free's all allocated data except
-   for some information such as nickname etc. that are valid at all time. */
-
-void silc_client_close_connection(SilcClient client,
-                                 SilcSocketConnection sock)
-{
-  SilcClientConnection conn;
+  status = (SilcStatus)packet->buffer.data[0];
 
-  /* We won't listen for this connection anymore */
-  silc_schedule_unset_listen_fd(sock->sock);
-
-  /* Unregister all tasks */
-  silc_task_unregister_by_fd(client->io_queue, sock->sock);
-  silc_task_unregister_by_fd(client->timeout_queue, sock->sock);
-
-  /* Close the actual connection */
-  silc_net_close_connection(sock->sock);
-
-  client->ops->say(client, sock->user_data,
-                  "Closed connection to host %s", sock->hostname ?
-                  sock->hostname : sock->ip);
-
-  /* Free everything */
-  if (sock->user_data) {
-    conn = (SilcClientConnection)sock->user_data;
-
-    /* XXX Free all client entries and channel entries. */
-
-    /* Clear ID caches */
-    silc_idcache_del_all(conn->client_cache);
-    silc_idcache_del_all(conn->channel_cache);
-
-    /* Free data */
-    if (conn->remote_host)
-      silc_free(conn->remote_host);
-    if (conn->local_id)
-      silc_free(conn->local_id);
-    if (conn->local_id_data)
-      silc_free(conn->local_id_data);
-    if (conn->send_key)
-      silc_cipher_free(conn->send_key);
-    if (conn->receive_key)
-      silc_cipher_free(conn->receive_key);
-    if (conn->hmac)
-      silc_hmac_free(conn->hmac);
-    if (conn->hmac_key) {
-      memset(conn->hmac_key, 0, conn->hmac_key_len);
-      silc_free(conn->hmac_key);
-    }
+  silc_buffer_pull(&packet->buffer, 1);
+  if (silc_buffer_len(&packet->buffer) > 1 &&
+      silc_utf8_valid(silc_buffer_data(&packet->buffer),
+                     silc_buffer_len(&packet->buffer)))
+    message = silc_memdup(silc_buffer_data(&packet->buffer),
+                         silc_buffer_len(&packet->buffer));
 
-    conn->sock = NULL;
-    conn->remote_port = 0;
-    conn->remote_type = 0;
-    conn->send_key = NULL;
-    conn->receive_key = NULL;
-    conn->hmac = NULL;
-    conn->hmac_key = NULL;
-    conn->hmac_key_len = 0;
-    conn->local_id = NULL;
-    conn->local_id_data = NULL;
-    conn->remote_host = NULL;
-    conn->current_channel = NULL;
+  /* Call connection callback */
+  conn->internal->status = SILC_CLIENT_CONN_DISCONNECTED;
+  conn->internal->error = status;
+  conn->internal->disconnect_message = message;
 
-    silc_client_del_connection(client, conn);
+  /* Signal to close connection */
+  if (!conn->internal->disconnected) {
+    conn->internal->disconnected = TRUE;
+    SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
   }
 
-  if (sock->protocol) {
-    silc_protocol_free(sock->protocol);
-    sock->protocol = NULL;
-  }
-  silc_socket_free(sock);
+  silc_packet_free(packet);
+
+  return SILC_FSM_FINISH;
 }
 
-/* Called when we receive disconnection packet from server. This 
-   closes our end properly and displays the reason of the disconnection
-   on the screen. */
+/*************************** Main client machine ****************************/
 
-void silc_client_disconnected_by_server(SilcClient client,
-                                       SilcSocketConnection sock,
-                                       SilcBuffer message)
+/* The client's main state where we wait for various events */
+
+SILC_FSM_STATE(silc_client_st_run)
 {
-  char *msg;
+  SilcClient client = fsm_context;
 
-  SILC_LOG_DEBUG(("Server disconnected us, sock %d", sock->sock));
+  /* Wait for events */
+  SILC_FSM_EVENT_WAIT(&client->internal->wait_event);
 
-  msg = silc_calloc(message->len + 1, sizeof(char));
-  memcpy(msg, message->data, message->len);
-  client->ops->say(client, sock->user_data, msg);
-  silc_free(msg);
+  /* Process events */
 
-  SILC_SET_DISCONNECTED(sock);
-  silc_client_close_connection(client, sock);
-}
+  if (client->internal->run_callback) {
+    /* Call running callbcak back to application */
+    client->internal->run_callback = FALSE;
+    if (client->internal->running) {
+      SILC_LOG_DEBUG(("We are up, call running callback"));
+      client->internal->running(client, client->internal->running_context);
+    }
+    return SILC_FSM_CONTINUE;
+  }
 
-/* Received error message from server. Display it on the screen. 
-   We don't take any action what so ever of the error message. */
+  if (client->internal->connection_closed) {
+    /* A connection finished */
+    SILC_LOG_DEBUG(("Event: connection closed"));
+    client->internal->connection_closed = FALSE;
+    if (silc_atomic_get_int32(&client->internal->conns) == 0 &&
+       client->internal->stop)
+      SILC_FSM_EVENT_SIGNAL(&client->internal->wait_event);
+    return SILC_FSM_CONTINUE;
+  }
 
-void silc_client_error_by_server(SilcClient client,
-                                SilcSocketConnection sock,
-                                SilcBuffer message)
-{
-  char *msg;
+  if (client->internal->stop) {
+    /* Stop client libarry.  If we have running connections, wait until
+       they finish first. */
+    if (silc_atomic_get_int32(&client->internal->conns) == 0) {
+      SILC_LOG_DEBUG(("Event: stop"));
+      silc_fsm_next(fsm, silc_client_st_stop);
+    }
+    return SILC_FSM_CONTINUE;
+  }
 
-  msg = silc_calloc(message->len + 1, sizeof(char));
-  memcpy(msg, message->data, message->len);
-  client->ops->say(client, sock->user_data, msg);
-  silc_free(msg);
+  /* NOT REACHED */
+  SILC_ASSERT(FALSE);
+  return SILC_FSM_CONTINUE;
 }
 
-/* Called when notify is received and some async operation (such as command)
-   is required before processing the notify message. This calls again the
-   silc_client_notify_by_server and reprocesses the original notify packet. */
+/* Stop event.  Stops the client library. */
 
-static void silc_client_notify_by_server_pending(void *context)
+SILC_FSM_STATE(silc_client_st_stop)
 {
-  SilcPacketContext *p = (SilcPacketContext *)context;
-  silc_client_notify_by_server(p->context, p->sock, p);
-  if (p->src_id)
-    silc_free(p->src_id);
-  if (p->dst_id)
-    silc_free(p->dst_id);
-  silc_buffer_free(p->buffer);
-  silc_free(p);
-}
+  SilcClient client = fsm_context;
 
-/* Received notify message from server */
+  SILC_LOG_DEBUG(("Client stopped"));
 
-void silc_client_notify_by_server(SilcClient client,
-                                 SilcSocketConnection sock,
-                                 SilcPacketContext *packet)
-{
-  SilcBuffer buffer = packet->buffer;
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  SilcNotifyPayload payload;
-  SilcNotifyType type;
-  SilcArgumentPayload args;
-  int i;
-
-  SilcClientID *client_id = NULL;
-  SilcChannelID *channel_id = NULL;
-  SilcClientEntry client_entry;
-  SilcClientEntry client_entry2;
-  SilcChannelEntry channel;
-  SilcIDCacheEntry id_cache = NULL;
-  unsigned char *tmp;
-  unsigned int tmp_len, mode;
-
-  payload = silc_notify_payload_parse(buffer);
-  type = silc_notify_get_type(payload);
-  args = silc_notify_get_args(payload);
-  if (!args)
-    goto out;
-
-  switch(type) {
-  case SILC_NOTIFY_TYPE_NONE:
-    /* Notify application */
-    client->ops->notify(client, conn, type, 
-                       silc_argument_get_arg_type(args, 1, NULL));
-    break;
+  /* Stop scheduler */
+  silc_schedule_stop(client->schedule);
+  silc_client_commands_unregister(client);
 
-  case SILC_NOTIFY_TYPE_INVITE:
-    /* 
-     * Someone invited me to a channel. Find Client and Channel entries
-     * for the application.
-     */
-    
-    /* Get Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find Client entry and if not found query it */
-    client_entry = silc_idlist_get_client_by_id(client, conn, client_id, TRUE);
-    if (!client_entry) {
-      SilcPacketContext *p = silc_packet_context_dup(packet);
-      p->context = (void *)client;
-      p->sock = sock;
-      silc_client_command_pending(SILC_COMMAND_WHOIS, 
-                                 silc_client_notify_by_server_pending, p);
-      goto out;
-    }
+  /* Call stopped callback to application */
+  if (client->internal->running)
+    client->internal->running(client, client->internal->running_context);
 
-    /* Get Channel ID */
-    tmp = silc_argument_get_arg_type(args, 2, &tmp_len);
-    if (!tmp)
-      goto out;
+  return SILC_FSM_FINISH;
+}
 
-    channel_id = silc_id_payload_parse_id(tmp, tmp_len);
+/******************************* Private API ********************************/
 
-    /* XXX Will ALWAYS fail because currently we don't have way to resolve
-       channel information for channel that we're not joined to. */
-    /* XXX ways to fix: use (extended) LIST command, or define the channel
-       name to the notfy type when name resolving is not mandatory. */
-    /* Find channel entry */
-    if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)channel_id,
-                                    SILC_ID_CHANNEL, &id_cache))
-      goto out;
+/* Adds new connection.  Creates the connection context and returns it. */
 
-    channel = (SilcChannelEntry)id_cache->context;
+SilcClientConnection
+silc_client_add_connection(SilcClient client,
+                          SilcConnectionType conn_type,
+                          SilcBool connect,
+                          SilcClientConnectionParams *params,
+                          SilcPublicKey public_key,
+                          SilcPrivateKey private_key,
+                          char *remote_host, int port,
+                          SilcClientConnectCallback callback,
+                          void *context)
+{
+  SilcClientConnection conn;
+  SilcFSMThread thread;
 
-    /* Notify application */
-    client->ops->notify(client, conn, type, client_entry, channel);
-    break;
+  if (!callback)
+    return NULL;
 
-  case SILC_NOTIFY_TYPE_JOIN:
-    /*
-     * Someone has joined to a channel. Get their ID and nickname and
-     * cache them for later use.
-     */
-
-    /* Get Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find Client entry and if not found query it */
-    client_entry = silc_idlist_get_client_by_id(client, conn, client_id, TRUE);
-    if (!client_entry) {
-      SilcPacketContext *p = silc_packet_context_dup(packet);
-      p->context = (void *)client;
-      p->sock = sock;
-      silc_client_command_pending(SILC_COMMAND_WHOIS, 
-                                 silc_client_notify_by_server_pending, p);
-      goto out;
-    }
+  SILC_LOG_DEBUG(("Adding new connection to %s:%d", remote_host, port));
 
-    /* Get channel entry */
-    channel_id = silc_id_str2id(packet->dst_id, SILC_ID_CHANNEL);
-    if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)channel_id,
-                                    SILC_ID_CHANNEL, &id_cache))
-      break;
+  conn = silc_calloc(1, sizeof(*conn));
+  if (!conn)
+    return NULL;
 
-    channel = (SilcChannelEntry)id_cache->context;
+  conn->client = client;
+  conn->public_key = public_key;
+  conn->private_key = private_key;
+  conn->remote_host = strdup(remote_host);
+  conn->remote_port = port ? port : 706;
+  conn->type = conn_type;
+  conn->callback = callback;
+  conn->callback_context = context;
+
+  conn->internal = silc_calloc(1, sizeof(*conn->internal));
+  if (!conn->internal) {
+    silc_free(conn);
+    return NULL;
+  }
+  conn->internal->retry_timer = SILC_CLIENT_RETRY_MIN;
+  silc_mutex_alloc(&conn->internal->lock);
+  silc_atomic_init16(&conn->internal->cmd_ident, 0);
 
-    /* Add client to channel */
-    for (i = 0; i < channel->clients_count; i++) {
-      if (channel->clients[i].client == NULL) {
-       channel->clients[channel->clients_count].client = client_entry;
-       channel->clients_count++;
-       break;
-      }
-    }
+  if (!silc_hash_alloc("sha1", &conn->internal->sha1hash)) {
+    silc_free(conn);
+    silc_free(conn->internal);
+    return NULL;
+  }
 
-    if (i == channel->clients_count) {
-      channel->clients = silc_realloc(channel->clients, 
-                                     sizeof(*channel->clients) * 
-                                     (channel->clients_count + 1));
-      channel->clients[channel->clients_count].client = client_entry;
-      channel->clients[channel->clients_count].mode = 0;
-      channel->clients_count++;
+  /* Set parameters */
+  if (params)
+    conn->internal->params = *params;
+  if (!conn->internal->params.rekey_secs)
+    conn->internal->params.rekey_secs = 3600;
+#ifndef SILC_DIST_INPLACE
+  if (conn->internal->params.rekey_secs < 300)
+    conn->internal->params.rekey_secs = 300;
+#endif /* SILC_DIST_INPLACE */
+
+  conn->internal->verbose = TRUE;
+  silc_list_init(conn->internal->pending_commands,
+                struct SilcClientCommandContextStruct, next);
+  silc_list_init(conn->internal->thread_pool, SilcFSMThreadStruct, next);
+
+  /* Allocate client, channel and serve caches */
+  if (conn_type != SILC_CONN_CLIENT) {
+    conn->internal->client_cache = silc_idcache_alloc(0, SILC_ID_CLIENT,
+                                                     NULL, NULL);
+    conn->internal->channel_cache = silc_idcache_alloc(0, SILC_ID_CHANNEL,
+                                                      NULL, NULL);
+    conn->internal->server_cache = silc_idcache_alloc(0, SILC_ID_SERVER,
+                                                     NULL, NULL);
+    if (!conn->internal->client_cache || !conn->internal->channel_cache ||
+       !conn->internal->server_cache) {
+      silc_client_del_connection(client, conn);
+      return NULL;
     }
+  }
 
-    /* XXX add support for multiple same nicks on same channel. Check
-       for them here */
-
-    /* Notify application. The channel entry is sent last as this notify
-       is for channel but application don't know it from the arguments
-       sent by server. */
-    client->ops->notify(client, conn, type, client_entry, channel);
-    break;
-
-  case SILC_NOTIFY_TYPE_LEAVE:
-    /*
-     * Someone has left a channel. We will remove it from the channel but
-     * we'll keep it in the cache in case we'll need it later.
-     */
-    
-    /* Get Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find Client entry */
-    client_entry = 
-      silc_idlist_get_client_by_id(client, conn, client_id, FALSE);
-    if (!client_entry)
-      goto out;
-
-    /* Get channel entry */
-    channel_id = silc_id_str2id(packet->dst_id, SILC_ID_CHANNEL);
-    if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)channel_id,
-                                    SILC_ID_CHANNEL, &id_cache))
-      break;
-
-    channel = (SilcChannelEntry)id_cache->context;
-
-    /* Remove client from channel */
-    for (i = 0; i < channel->clients_count; i++) {
-      if (channel->clients[i].client == client_entry) {
-       channel->clients[i].client = NULL;
-       channel->clients_count--;
-       break;
-      }
+  if (connect) {
+    /* Initialize our async operation so that application may abort us
+       while we're connecting. */
+    conn->internal->cop = silc_async_alloc(silc_client_connect_abort,
+                                          NULL, conn);
+    if (!conn->internal->cop) {
+      silc_client_del_connection(client, conn);
+      return NULL;
     }
+  }
 
-    /* Notify application. The channel entry is sent last as this notify
-       is for channel but application don't know it from the arguments
-       sent by server. */
-    client->ops->notify(client, conn, type, client_entry, channel);
-    break;
-
-  case SILC_NOTIFY_TYPE_SIGNOFF:
-    /*
-     * Someone left SILC. We'll remove it from all channels and from cache.
-     */
-
-    /* Get Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find Client entry */
-    client_entry = 
-      silc_idlist_get_client_by_id(client, conn, client_id, FALSE);
-    if (!client_entry)
-      goto out;
-
-    /* Remove from all channels */
-    silc_client_remove_from_channels(client, conn, client_entry);
-
-    /* Remove from cache */
-    silc_idcache_del_by_id(conn->client_cache, SILC_ID_CLIENT, 
-                          client_entry->id);
-
-    /* Notify application */
-    client->ops->notify(client, conn, type, client_entry);
-
-    /* Free data */
-    if (client_entry->nickname)
-      silc_free(client_entry->nickname);
-    if (client_entry->server)
-      silc_free(client_entry->server);
-    if (client_entry->id)
-      silc_free(client_entry->id);
-    if (client_entry->send_key)
-      silc_cipher_free(client_entry->send_key);
-    if (client_entry->receive_key)
-      silc_cipher_free(client_entry->receive_key);
-    break;
-
-  case SILC_NOTIFY_TYPE_TOPIC_SET:
-    /*
-     * Someone set the topic on a channel.
-     */
-
-    /* Get Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find Client entry */
-    client_entry = 
-      silc_idlist_get_client_by_id(client, conn, client_id, FALSE);
-    if (!client_entry)
-      goto out;
-
-    /* Get topic */
-    tmp = silc_argument_get_arg_type(args, 2, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    /* Get channel entry */
-    channel_id = silc_id_str2id(packet->dst_id, SILC_ID_CHANNEL);
-    if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)channel_id,
-                                    SILC_ID_CHANNEL, &id_cache))
-      break;
-
-    channel = (SilcChannelEntry)id_cache->context;
-
-    /* Notify application. The channel entry is sent last as this notify
-       is for channel but application don't know it from the arguments
-       sent by server. */
-    client->ops->notify(client, conn, type, client_entry, tmp, channel);
-    break;
+  /* Run the connection state machine.  If threads are in use the connection
+     machine is always run in a real thread. */
+  thread = silc_fsm_thread_alloc(&client->internal->fsm, conn,
+                                silc_client_connection_finished, NULL,
+                                client->internal->params->threads);
+  if (!thread) {
+    silc_client_del_connection(client, conn);
+    return NULL;
+  }
+  silc_fsm_set_state_context(thread, client);
+  silc_fsm_start(thread, silc_client_connection_st_start);
 
-  case SILC_NOTIFY_TYPE_NICK_CHANGE:
-    /*
-     * Someone changed their nickname. If we don't have entry for the new
-     * ID we will query it and return here after it's done. After we've
-     * returned we fetch the old entry and free it and notify the 
-     * application.
-     */
-
-    /* Get new Client ID */
-    tmp = silc_argument_get_arg_type(args, 2, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Ignore my ID */
-    if (!SILC_ID_CLIENT_COMPARE(client_id, conn->local_id))
-      break;
-
-    /* Find Client entry and if not found query it */
-    client_entry2 = 
-      silc_idlist_get_client_by_id(client, conn, client_id, TRUE);
-    if (!client_entry2) {
-      SilcPacketContext *p = silc_packet_context_dup(packet);
-      p->context = (void *)client;
-      p->sock = sock;
-      silc_client_command_pending(SILC_COMMAND_WHOIS, 
-                                 silc_client_notify_by_server_pending, p);
-      goto out;
-    }
+  SILC_LOG_DEBUG(("New connection %p", conn));
+  silc_atomic_add_int32(&client->internal->conns, 1);
 
-    /* Get old Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find old Client entry */
-    client_entry = 
-      silc_idlist_get_client_by_id(client, conn, client_id, FALSE);
-    if (!client_entry)
-      goto out;
-
-    /* Remove the old from cache */
-    silc_idcache_del_by_id(conn->client_cache, SILC_ID_CLIENT, 
-                          client_entry->id);
-
-    /* Replace old ID entry with new one on all channels. */
-    silc_client_replace_from_channels(client, conn, client_entry,
-                                     client_entry2);
-
-    /* Notify application */
-    client->ops->notify(client, conn, type, client_entry, client_entry2);
-
-    /* Free data */
-    if (client_entry->nickname)
-      silc_free(client_entry->nickname);
-    if (client_entry->server)
-      silc_free(client_entry->server);
-    if (client_entry->id)
-      silc_free(client_entry->id);
-    if (client_entry->send_key)
-      silc_cipher_free(client_entry->send_key);
-    if (client_entry->receive_key)
-      silc_cipher_free(client_entry->receive_key);
-    break;
+  return conn;
+}
 
-  case SILC_NOTIFY_TYPE_CMODE_CHANGE:
-    /*
-     * Someone changed a channel mode
-     */
+/* Deletes connection.  This is always called from the connection machine
+   destructor.  Do not call this directly other places. */
 
-    /* Get Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
+void silc_client_del_connection(SilcClient client, SilcClientConnection conn)
+{
+  SilcList list;
+  SilcIDCacheEntry entry;
+  SilcFSMThread thread;
 
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
+  SILC_LOG_DEBUG(("Freeing connection %p", conn));
 
-    /* Find Client entry */
-    client_entry = 
-      silc_idlist_get_client_by_id(client, conn, client_id, FALSE);
-    if (!client_entry)
-      goto out;
+  silc_schedule_task_del_by_context(conn->internal->schedule, conn);
 
-    /* Get the mode */
-    tmp = silc_argument_get_arg_type(args, 2, &tmp_len);
-    if (!tmp)
-      goto out;
+  /* Free all cache entries */
+  if (conn->internal->server_cache) {
+    if (silc_idcache_get_all(conn->internal->server_cache, &list)) {
+      silc_list_start(list);
+      while ((entry = silc_list_get(list)))
+       silc_client_del_server(client, conn, entry->context);
+    }
+  }
+  if (conn->internal->channel_cache) {
+    if (silc_idcache_get_all(conn->internal->channel_cache, &list)) {
+      silc_list_start(list);
+      while ((entry = silc_list_get(list))) {
+       silc_client_empty_channel(client, conn, entry->context);
+       silc_client_del_channel(client, conn, entry->context);
+      }
+    }
+  }
+  if (conn->internal->client_cache) {
+    if (silc_idcache_get_all(conn->internal->client_cache, &list)) {
+      silc_list_start(list);
+      while ((entry = silc_list_get(list)))
+       silc_client_del_client(client, conn, entry->context);
+    }
+  }
 
-    SILC_GET32_MSB(mode, tmp);
+  /* Free ID caches */
+  if (conn->internal->client_cache)
+    silc_idcache_free(conn->internal->client_cache);
+  if (conn->internal->channel_cache)
+    silc_idcache_free(conn->internal->channel_cache);
+  if (conn->internal->server_cache)
+    silc_idcache_free(conn->internal->server_cache);
+
+  /* Free thread pool */
+  silc_list_start(conn->internal->thread_pool);
+  while ((thread = silc_list_get(conn->internal->thread_pool)))
+    silc_fsm_free(thread);
+
+  silc_free(conn->remote_host);
+  silc_buffer_free(conn->internal->local_idp);
+  silc_buffer_free(conn->internal->remote_idp);
+  silc_mutex_free(conn->internal->lock);
+  if (conn->internal->hash)
+    silc_hash_free(conn->internal->hash);
+  if (conn->internal->sha1hash)
+    silc_hash_free(conn->internal->sha1hash);
+  silc_atomic_uninit16(&conn->internal->cmd_ident);
+  silc_free(conn->internal->away_message);
+  if (conn->internal->rekey)
+    silc_ske_free_rekey_material(conn->internal->rekey);
+  if (conn->internal->cop)
+    silc_async_free(conn->internal->cop);
+
+  silc_free(conn->internal);
+  memset(conn, 'F', sizeof(*conn));
+  silc_free(conn);
+}
 
-    /* Get channel entry */
-    channel_id = silc_id_str2id(packet->dst_id, SILC_ID_CHANNEL);
-    if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)channel_id,
-                                    SILC_ID_CHANNEL, &id_cache))
-      break;
+/******************************* Client API *********************************/
 
-    channel = (SilcChannelEntry)id_cache->context;
+/* Connects to remote server.  This is the main routine used to connect
+   to remote SILC server.  Performs key exchange also.  Returns the
+   connection context to the connection callback. */
 
-    /* Save the new mode */
-    channel->mode = mode;
+SilcAsyncOperation
+silc_client_connect_to_server(SilcClient client,
+                             SilcClientConnectionParams *params,
+                             SilcPublicKey public_key,
+                             SilcPrivateKey private_key,
+                             char *remote_host, int port,
+                             SilcClientConnectCallback callback,
+                             void *context)
+{
+  SilcClientConnection conn;
 
-    /* Notify application. The channel entry is sent last as this notify
-       is for channel but application don't know it from the arguments
-       sent by server. */
-    client->ops->notify(client, conn, type, client_entry, mode, channel);
-    break;
+  SILC_LOG_DEBUG(("Connecting to server"));
 
-  case SILC_NOTIFY_TYPE_CUMODE_CHANGE:
-    /*
-     * Someone changed user's mode on a channel
-     */
-
-    /* Get Client ID */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find Client entry */
-    client_entry = 
-      silc_idlist_get_client_by_id(client, conn, client_id, FALSE);
-    if (!client_entry)
-      goto out;
-
-    /* Get the mode */
-    tmp = silc_argument_get_arg_type(args, 2, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    SILC_GET32_MSB(mode, tmp);
-
-    /* Get target Client ID */
-    tmp = silc_argument_get_arg_type(args, 3, &tmp_len);
-    if (!tmp)
-      goto out;
-
-    silc_free(client_id);
-    client_id = silc_id_payload_parse_id(tmp, tmp_len);
-
-    /* Find target Client entry */
-    client_entry2 = 
-      silc_idlist_get_client_by_id(client, conn, client_id, FALSE);
-    if (!client_entry2)
-      goto out;
-
-    /* Get channel entry */
-    channel_id = silc_id_str2id(packet->dst_id, SILC_ID_CHANNEL);
-    if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)channel_id,
-                                    SILC_ID_CHANNEL, &id_cache))
-      break;
-
-    channel = (SilcChannelEntry)id_cache->context;
-
-    /* Save the mode */
-    for (i = 0; i < channel->clients_count; i++) {
-      if (channel->clients[i].client == client_entry2) {
-       channel->clients[i].mode = mode;
-       break;
-      }
-    }
+  if (!client || !remote_host)
+    return NULL;
 
-    /* Notify application. The channel entry is sent last as this notify
-       is for channel but application don't know it from the arguments
-       sent by server. */
-    client->ops->notify(client, conn, type, client_entry, mode, 
-                       client_entry2, channel);
-    break;
+  if (client->internal->run_callback) {
+    SILC_LOG_ERROR(("Client library is not started yet. SilcClientRunning "
+                   "callback has not been called yet."));
+    return NULL;
+  }
 
-  case SILC_NOTIFY_TYPE_MOTD:
-    /*
-     * Received Message of the day
-     */
-
-    /* Get motd */
-    tmp = silc_argument_get_arg_type(args, 1, &tmp_len);
-    if (!tmp)
-      goto out;
-    
-    /* Notify application */
-    client->ops->notify(client, conn, type, tmp);
-    break;
-    
-  default:
-    break;
+  /* Add new connection */
+  conn = silc_client_add_connection(client, SILC_CONN_SERVER, TRUE, params,
+                                   public_key, private_key, remote_host,
+                                   port, callback, context);
+  if (!conn) {
+    callback(client, NULL, SILC_CLIENT_CONN_ERROR, 0, NULL, context);
+    return NULL;
   }
 
- out:
-  silc_notify_payload_free(payload);
-  if (client_id)
-    silc_free(client_id);
-  if (channel_id)
-    silc_free(channel_id);
-}
+  client->internal->ops->say(client, conn, SILC_CLIENT_MESSAGE_AUDIT,
+                            "Connecting to port %d of server %s",
+                            port, remote_host);
 
-/* Processes the received new Client ID from server. Old Client ID is
-   deleted from cache and new one is added. */
+  /* Signal connection machine to start connecting */
+  conn->internal->connect = TRUE;
+  return conn->internal->cop;
+}
 
-void silc_client_receive_new_id(SilcClient client,
-                               SilcSocketConnection sock,
-                               SilcIDPayload idp)
+/* Connects to remote client.  Performs key exchange also.  Returns the
+   connection context to the connection callback. */
+
+SilcAsyncOperation
+silc_client_connect_to_client(SilcClient client,
+                             SilcClientConnectionParams *params,
+                             SilcPublicKey public_key,
+                             SilcPrivateKey private_key,
+                             char *remote_host, int port,
+                             SilcClientConnectCallback callback,
+                             void *context)
 {
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-
-  /* Delete old ID from ID cache */
-  silc_idcache_del_by_id(conn->client_cache, SILC_ID_CLIENT, conn->local_id);
-  
-  /* Save the new ID */
-  if (conn->local_id)
-    silc_free(conn->local_id);
-  if (conn->local_id_data)
-    silc_free(conn->local_id_data);
-
-  conn->local_id = silc_id_payload_get_id(idp);
-  conn->local_id_data = silc_id_payload_get_data(idp);
-  conn->local_id_data_len = silc_id_payload_get_len(idp);;
-
-  if (!conn->local_entry)
-    conn->local_entry = silc_calloc(1, sizeof(*conn->local_entry));
-
-  conn->local_entry->nickname = conn->nickname;
-  if (!conn->local_entry->username) {
-    conn->local_entry->username = 
-      silc_calloc(strlen(client->username) + strlen(client->hostname) + 1,
-                 sizeof(conn->local_entry->username));
-    sprintf(conn->local_entry->username, "%s@%s", client->username,
-           client->hostname);
-  }
-  conn->local_entry->id = conn->local_id;
-  
-  /* Put it to the ID cache */
-  silc_idcache_add(conn->client_cache, conn->nickname, SILC_ID_CLIENT,
-                  conn->local_id, (void *)conn->local_entry, TRUE);
-}
+  SilcClientConnection conn;
 
-/* Processed received Channel ID for a channel. This is called when client
-   joins to channel and server replies with channel ID. The ID is cached. */
+  SILC_LOG_DEBUG(("Connecting to client"));
 
-void silc_client_new_channel_id(SilcClient client,
-                               SilcSocketConnection sock,
-                               char *channel_name,
-                               unsigned int mode, SilcIDPayload idp)
-{
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  SilcChannelEntry channel;
+  if (!client || !remote_host)
+    return NULL;
 
-  SILC_LOG_DEBUG(("New channel ID"));
+  if (client->internal->run_callback) {
+    SILC_LOG_ERROR(("Client library is not started yet. SilcClientRunning "
+                   "callback has not been called yet."));
+    return NULL;
+  }
 
-  channel = silc_calloc(1, sizeof(*channel));
-  channel->channel_name = channel_name;
-  channel->id = silc_id_payload_get_id(idp);
-  channel->mode = mode;
-  conn->current_channel = channel;
+  if (params)
+    params->no_authentication = TRUE;
 
-  /* Put it to the ID cache */
-  silc_idcache_add(conn->channel_cache, channel_name, SILC_ID_CHANNEL,
-                  (void *)channel->id, (void *)channel, TRUE);
-}
+  /* Add new connection */
+  conn = silc_client_add_connection(client, SILC_CONN_CLIENT, TRUE, params,
+                                   public_key, private_key, remote_host,
+                                   port, callback, context);
+  if (!conn) {
+    callback(client, NULL, SILC_CLIENT_CONN_ERROR, 0, NULL, context);
+    return NULL;
+  }
 
-/* Processes received key for channel. The received key will be used
-   to protect the traffic on the channel for now on. Client must receive
-   the key to the channel before talking on the channel is possible. 
-   This is the key that server has generated, this is not the channel
-   private key, it is entirely local setting. */
+  /* Signal connection machine to start connecting */
+  conn->internal->connect = TRUE;
+  return conn->internal->cop;
+}
 
-void silc_client_receive_channel_key(SilcClient client,
-                                    SilcSocketConnection sock,
-                                    SilcBuffer packet)
+/* Starts key exchange in the remote stream indicated by `stream'.  This
+   creates the connection context and returns it in the connection callback. */
+
+SilcAsyncOperation
+silc_client_key_exchange(SilcClient client,
+                        SilcClientConnectionParams *params,
+                        SilcPublicKey public_key,
+                        SilcPrivateKey private_key,
+                        SilcStream stream,
+                        SilcConnectionType conn_type,
+                        SilcClientConnectCallback callback,
+                        void *context)
 {
-  unsigned char *id_string, *key, *cipher;
-  unsigned int tmp_len;
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  SilcChannelID *id;
-  SilcIDCacheEntry id_cache = NULL;
-  SilcChannelEntry channel;
-  SilcChannelKeyPayload payload;
-
-  SILC_LOG_DEBUG(("Received key for channel"));
-  
-  payload = silc_channel_key_payload_parse(packet);
-  if (!payload)
-    return;
+  SilcClientConnection conn;
+  const char *host;
+  SilcUInt16 port;
 
-  id_string = silc_channel_key_get_id(payload, &tmp_len);
-  if (!id_string) {
-    silc_channel_key_payload_free(payload);
-    return;
-  }
-  id = silc_id_payload_parse_id(id_string, tmp_len);
-
-  /* Find channel. */
-  if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)id,
-                                  SILC_ID_CHANNEL, &id_cache))
-    goto out;
-    
-  /* Save the key */
-  key = silc_channel_key_get_key(payload, &tmp_len);
-  cipher = silc_channel_key_get_cipher(payload, NULL);
-
-  channel = (SilcChannelEntry)id_cache->context;
-  channel->key_len = tmp_len;
-  channel->key = silc_calloc(tmp_len, sizeof(*channel->key));
-  memcpy(channel->key, key, tmp_len);
-
-  if (!silc_cipher_alloc(cipher, &channel->channel_key)) {
-    client->ops->say(client, conn,
-                    "Cannot talk to channel: unsupported cipher %s", cipher);
-    goto out;
-  }
-  channel->channel_key->cipher->set_key(channel->channel_key->context, 
-                                       key, tmp_len);
+  SILC_LOG_DEBUG(("Performing key exchange"));
 
-  /* Client is now joined to the channel */
-  channel->on_channel = TRUE;
+  if (!client || !stream)
+    return NULL;
 
- out:
-  silc_free(id);
-  silc_channel_key_payload_free(payload);
-}
+  if (client->internal->run_callback) {
+    SILC_LOG_ERROR(("Client library is not started yet. SilcClientRunning "
+                   "callback has not been called yet."));
+    return NULL;
+  }
 
-/* Process received message to a channel (or from a channel, really). This
-   decrypts the channel message with channel specific key and parses the
-   channel payload. Finally it displays the message on the screen. */
+  if (!silc_socket_stream_get_info(stream, NULL, &host, NULL, &port)) {
+    SILC_LOG_ERROR(("Socket stream does not have remote host name set"));
+    callback(client, NULL, SILC_CLIENT_CONN_ERROR, 0, NULL, context);
+    return NULL;
+  }
 
-void silc_client_channel_message(SilcClient client, 
-                                SilcSocketConnection sock, 
-                                SilcPacketContext *packet)
-{
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  SilcBuffer buffer = packet->buffer;
-  SilcChannelPayload payload = NULL;
-  SilcChannelID *id = NULL;
-  SilcChannelEntry channel;
-  SilcIDCacheEntry id_cache = NULL;
-  SilcClientID *client_id = NULL;
-  int i;
-  char *nickname;
-
-  /* Sanity checks */
-  if (packet->dst_id_type != SILC_ID_CHANNEL)
-    goto out;
-
-  client_id = silc_id_str2id(packet->src_id, SILC_ID_CLIENT);
-  id = silc_id_str2id(packet->dst_id, SILC_ID_CHANNEL);
-
-  /* Find the channel entry from channels on this connection */
-  if (!silc_idcache_find_by_id_one(conn->channel_cache, (void *)id,
-                                  SILC_ID_CHANNEL, &id_cache))
-    goto out;
-
-  channel = (SilcChannelEntry)id_cache->context;
-
-  /* Decrypt the channel message payload. Push the IV out of the way,
-     since it is not encrypted (after pushing buffer->tail has the IV). */
-  silc_buffer_push_tail(buffer, 16);
-  channel->channel_key->cipher->decrypt(channel->channel_key->context,
-                                       buffer->data, buffer->data,
-                                       buffer->len, buffer->tail);
-  silc_buffer_pull_tail(buffer, 16);
-
-  /* Parse the channel message payload */
-  payload = silc_channel_payload_parse(buffer);
-  if (!payload)
-    goto out;
-
-  /* Find nickname */
-  nickname = "[unknown]";
-  for (i = 0; i < channel->clients_count; i++) {
-    if (channel->clients[i].client && 
-       !SILC_ID_CLIENT_COMPARE(channel->clients[i].client->id, client_id))
-      nickname = channel->clients[i].client->nickname;
+  /* Add new connection */
+  conn = silc_client_add_connection(client, conn_type, TRUE, params,
+                                   public_key, private_key,
+                                   (char *)host, port, callback, context);
+  if (!conn) {
+    callback(client, NULL, SILC_CLIENT_CONN_ERROR, 0, NULL, context);
+    return NULL;
   }
+  conn->internal->user_stream = stream;
 
-  /* Pass the message to application */
-  client->ops->channel_message(client, conn, nickname,
-                              channel->channel_name,
-                              silc_channel_get_data(payload, NULL));
-
- out:
-  if (id)
-    silc_free(id);
-  if (client_id)
-    silc_free(client_id);
-  if (payload)
-    silc_channel_payload_free(payload);
+  /* Signal connection to start key exchange */
+  conn->internal->key_exchange = TRUE;
+  return conn->internal->cop;
 }
 
-/* Private message received. This processes the private message and
-   finally displays it on the screen. */
+/* Closes remote connection */
 
-void silc_client_private_message(SilcClient client, 
-                                SilcSocketConnection sock, 
-                                SilcPacketContext *packet)
+void silc_client_close_connection(SilcClient client,
+                                 SilcClientConnection conn)
 {
-  SilcClientConnection conn = (SilcClientConnection)sock->user_data;
-  SilcBuffer buffer = packet->buffer;
-  unsigned short nick_len;
-  unsigned char *nickname, *message;
-
-  /* Get nickname */
-  silc_buffer_unformat(buffer, 
-                      SILC_STR_UI16_NSTRING_ALLOC(&nickname, &nick_len),
-                      SILC_STR_END);
-  silc_buffer_pull(buffer, 2 + nick_len);
-     
-  message = silc_calloc(buffer->len + 1, sizeof(char));
-  memcpy(message, buffer->data, buffer->len);
-
-  /* Pass the private message to application */
-  client->ops->private_message(client, conn, nickname, message);
-
-  /* See if we are away (gone). If we are away we will reply to the
-     sender with the set away message. */
-  if (conn->away && conn->away->away) {
-    SilcClientID *remote_id;
-    SilcClientEntry remote_client;
-    SilcIDCacheEntry id_cache;
-
-    if (packet->src_id_type != SILC_ID_CLIENT)
-      goto out;
-
-    remote_id = silc_id_str2id(packet->src_id, SILC_ID_CLIENT);
-    if (!remote_id)
-      goto out;
-
-    /* If it's me, ignore */
-    if (!SILC_ID_CLIENT_COMPARE(remote_id, conn->local_id))
-      goto out;
-
-    /* Check whether we know this client already */
-    if (!silc_idcache_find_by_id_one(conn->client_cache, remote_id,
-                                    SILC_ID_CLIENT, &id_cache))
-      {
-       /* Allocate client entry */
-       remote_client = silc_calloc(1, sizeof(*remote_client));
-       remote_client->id = remote_id;
-       silc_parse_nickname(nickname, &remote_client->nickname, 
-                           &remote_client->server, &remote_client->num);
-
-       /* Save the client to cache */
-       silc_idcache_add(conn->client_cache, remote_client->nickname,
-                        SILC_ID_CLIENT, remote_client->id, remote_client, 
-                        TRUE);
-      } else {
-       silc_free(remote_id);
-       remote_client = (SilcClientEntry)id_cache->context;
-      }
+  SILC_LOG_DEBUG(("Closing connection %p", conn));
 
-    /* Send the away message */
-    silc_client_packet_send_private_message(client, sock, remote_client,
-                                           conn->away->away,
-                                           strlen(conn->away->away), TRUE);
+  /* Signal to close connection */
+  conn->internal->status = SILC_CLIENT_CONN_DISCONNECTED;
+  if (!conn->internal->disconnected) {
+    conn->internal->disconnected = TRUE;
+    SILC_FSM_EVENT_SIGNAL(&conn->internal->wait_event);
   }
-
- out:
-  memset(message, 0, buffer->len);
-  silc_free(message);
-  silc_free(nickname);
 }
 
-/* Removes a client entry from all channel it has joined. This really is
-   a performance killer (client_entry should have pointers to channel 
-   entry list). */
+/* Allocates new client object. This has to be done before client may
+   work. After calling this one must call silc_client_init to initialize
+   the client. The `application' is application specific user data pointer
+   and caller must free it. */
 
-void silc_client_remove_from_channels(SilcClient client,
-                                     SilcClientConnection conn,
-                                     SilcClientEntry client_entry)
+SilcClient silc_client_alloc(SilcClientOperations *ops,
+                            SilcClientParams *params,
+                            void *application,
+                            const char *version_string)
 {
-  SilcIDCacheEntry id_cache;
-  SilcIDCacheList list;
-  SilcChannelEntry channel;
-  int i;
-
-  if (!silc_idcache_find_by_id(conn->channel_cache, SILC_ID_CACHE_ANY,
-                              SILC_ID_CHANNEL, &list))
-    return;
+  SilcClient new_client;
 
-  silc_idcache_list_first(list, &id_cache);
-  channel = (SilcChannelEntry)id_cache->context;
-  
-  while (channel) {
-    
-    /* Remove client from channel */
-    for (i = 0; i < channel->clients_count; i++) {
-      if (channel->clients[i].client == client_entry) {
-       channel->clients[i].client = NULL;
-       channel->clients_count--;
-       break;
-      }
-    }
+  new_client = silc_calloc(1, sizeof(*new_client));
+  if (!new_client)
+    return NULL;
+  new_client->application = application;
 
-    if (!silc_idcache_list_next(list, &id_cache))
-      break;
-    
-    channel = (SilcChannelEntry)id_cache->context;
+  new_client->internal = silc_calloc(1, sizeof(*new_client->internal));
+  if (!new_client->internal) {
+    silc_free(new_client);
+    return NULL;
   }
+  new_client->internal->ops = ops;
+  new_client->internal->params =
+    silc_calloc(1, sizeof(*new_client->internal->params));
+  if (!version_string)
+    version_string = silc_version_string;
+  new_client->internal->silc_client_version = strdup(version_string);
 
-  silc_idcache_list_free(list);
-}
-
-/* Replaces `old' client entries from all channels to `new' client entry.
-   This can be called for example when nickname changes and old ID entry
-   is replaced from ID cache with the new one. If the old ID entry is only
-   updated, then this fucntion needs not to be called. */
+  if (params)
+    memcpy(new_client->internal->params, params, sizeof(*params));
 
-void silc_client_replace_from_channels(SilcClient client, 
-                                      SilcClientConnection conn,
-                                      SilcClientEntry old,
-                                      SilcClientEntry new)
-{
-  SilcIDCacheEntry id_cache;
-  SilcIDCacheList list;
-  SilcChannelEntry channel;
-  int i;
-
-  if (!silc_idcache_find_by_id(conn->channel_cache, SILC_ID_CACHE_ANY,
-                              SILC_ID_CHANNEL, &list))
-    return;
-
-  silc_idcache_list_first(list, &id_cache);
-  channel = (SilcChannelEntry)id_cache->context;
-  
-  while (channel) {
-    
-    /* Remove client from channel */
-    for (i = 0; i < channel->clients_count; i++) {
-      if (channel->clients[i].client == old) {
-       channel->clients[i].client = new;
-       break;
-      }
-    }
+  new_client->internal->params->
+    nickname_format[sizeof(new_client->internal->
+                          params->nickname_format) - 1] = 0;
 
-    if (!silc_idcache_list_next(list, &id_cache))
-      break;
-    
-    channel = (SilcChannelEntry)id_cache->context;
-  }
+  silc_atomic_init32(&new_client->internal->conns, 0);
 
-  silc_idcache_list_free(list);
+  return new_client;
 }
 
-/* Parses mode mask and returns the mode as string. */
+/* Frees client object and its internals. */
 
-char *silc_client_chmode(unsigned int mode)
+void silc_client_free(SilcClient client)
 {
-  char string[20];
+  if (client->schedule)
+    silc_schedule_uninit(client->schedule);
+
+  if (client->rng)
+    silc_rng_free(client->rng);
+
+  if (!client->internal->params->dont_register_crypto_library)
+    silc_crypto_uninit();
+
+  if (client->internal->packet_engine)
+    silc_packet_engine_stop(client->internal->packet_engine);
+  if (client->internal->ftp_sessions)
+    silc_dlist_uninit(client->internal->ftp_sessions);
+  if (client->internal->lock)
+    silc_mutex_free(client->internal->lock);
+  silc_atomic_uninit32(&client->internal->conns);
+  silc_free(client->username);
+  silc_free(client->hostname);
+  silc_free(client->realname);
+  silc_free(client->internal->params);
+  silc_free(client->internal->silc_client_version);
+  silc_free(client->internal);
+  silc_free(client);
+}
 
-  if (!mode)
-    return NULL;
+/* Initializes the client. This makes all the necessary steps to make
+   the client ready to be run. One must call silc_client_run to run the
+   client. Returns FALSE if error occured, TRUE otherwise. */
 
-  memset(string, 0, sizeof(string));
+SilcBool silc_client_init(SilcClient client, const char *username,
+                         const char *hostname, const char *realname,
+                         SilcClientRunning running, void *context)
+{
+  SILC_LOG_DEBUG(("Initializing client"));
 
-  if (mode & SILC_CHANNEL_MODE_PRIVATE)
-    strncat(string, "p", 1);
+  if (!client)
+    return FALSE;
 
-  if (mode & SILC_CHANNEL_MODE_SECRET)
-    strncat(string, "s", 1);
+  if (!username || !hostname) {
+    SILC_LOG_ERROR(("Username and hostname must be given to "
+                   "silc_client_init"));
+    return FALSE;
+  }
+  if (!realname)
+    realname = username;
+
+  /* Validate essential strings */
+  if (!silc_identifier_verify(username, strlen(username),
+                             SILC_STRING_UTF8, 128)) {
+    SILC_LOG_ERROR(("Malformed username '%s'. Username must be UTF-8 string",
+                   client->username));
+    return FALSE;
+  }
+  if (!silc_identifier_verify(hostname, strlen(hostname),
+                             SILC_STRING_UTF8, 256)) {
+    SILC_LOG_ERROR(("Malformed hostname '%s'. Hostname must be UTF-8 string",
+                   client->hostname));
+    return FALSE;
+  }
+  if (!silc_utf8_valid(realname, strlen(realname))) {
+    SILC_LOG_ERROR(("Malformed realname '%s'. Realname must be UTF-8 string",
+                   client->realname));
+    return FALSE;
+  }
 
-  if (mode & SILC_CHANNEL_MODE_PRIVKEY)
-    strncat(string, "k", 1);
+  /* Take the name strings */
+  client->username = strdup(username);
+  client->hostname = strdup(hostname);
+  client->realname = strdup(realname);
+  if (!username || !hostname || !realname)
+    return FALSE;
 
-  if (mode & SILC_CHANNEL_MODE_INVITE)
-    strncat(string, "i", 1);
+  client->internal->ftp_sessions = silc_dlist_init();
+  if (!client->internal->ftp_sessions)
+    return FALSE;
 
-  if (mode & SILC_CHANNEL_MODE_TOPIC)
-    strncat(string, "t", 1);
+  if (!client->internal->params->dont_register_crypto_library)
+    /* Initialize the crypto library.  If application has done this already
+       this has no effect. */
+    silc_crypto_init(NULL);
 
-  if (mode & SILC_CHANNEL_MODE_ULIMIT)
-    strncat(string, "l", 1);
+  /* Initialize random number generator */
+  client->rng = silc_rng_alloc();
+  if (!client->rng)
+    return FALSE;
+  silc_rng_init(client->rng);
+  silc_rng_global_init(client->rng);
 
-  if (mode & SILC_CHANNEL_MODE_PASSPHRASE)
-    strncat(string, "a", 1);
+  /* Initialize the scheduler */
+  client->schedule = silc_schedule_init(0, client, NULL, NULL);
+  if (!client->schedule)
+    return FALSE;
 
-  /* Rest of mode is ignored */
+  /* Allocate client lock */
+  silc_mutex_alloc(&client->internal->lock);
 
-  return strdup(string);
-}
+  /* Register commands */
+  silc_client_commands_register(client);
 
-/* Parses channel user mode mask and returns te mode as string */
+  /* Start packet engine */
+  client->internal->packet_engine =
+    silc_packet_engine_start(client->rng, FALSE, &silc_client_stream_cbs,
+                            client);
+  if (!client->internal->packet_engine)
+    return FALSE;
 
-char *silc_client_chumode(unsigned int mode)
-{
-  char string[4];
+  /* Initialize and start the client FSM */
+  client->internal->running = running;
+  client->internal->running_context = context;
+  silc_fsm_init(&client->internal->fsm, client, NULL, NULL, client->schedule);
+  silc_fsm_event_init(&client->internal->wait_event, &client->internal->fsm);
+  silc_fsm_start_sync(&client->internal->fsm, silc_client_st_run);
 
-  if (!mode)
-    return NULL;
+  /* Signal the application when we are running */
+  client->internal->run_callback = TRUE;
+  SILC_FSM_EVENT_SIGNAL(&client->internal->wait_event);
 
-  memset(string, 0, sizeof(string));
+  return TRUE;
+}
 
-  if (mode & SILC_CHANNEL_UMODE_CHANFO)
-    strncat(string, "f", 1);
+/* Starts the SILC client FSM machine and blocks here.  When this returns
+   the client has ended. */
 
-  if (mode & SILC_CHANNEL_UMODE_CHANOP)
-    strncat(string, "o", 1);
+void silc_client_run(SilcClient client)
+{
+  SILC_LOG_DEBUG(("Starting SILC client"));
 
-  return strdup(string);
+  /* Run the scheduler */
+  silc_schedule(client->schedule);
 }
 
-/* Parses channel user mode and returns it as special mode character. */
+/* Call scheduler one iteration and return. */
 
-char *silc_client_chumode_char(unsigned int mode)
+void silc_client_run_one(SilcClient client)
 {
-  char string[4];
+  if (silc_fsm_is_started(&client->internal->fsm))
+    silc_schedule_one(client->schedule, 0);
+}
 
-  if (!mode)
-    return NULL;
+/* Stops the client. This is called to stop the client and thus to stop
+   the program. */
 
-  memset(string, 0, sizeof(string));
+void silc_client_stop(SilcClient client, SilcClientStopped stopped,
+                     void *context)
+{
+  SILC_LOG_DEBUG(("Stopping client"));
 
-  if (mode & SILC_CHANNEL_UMODE_CHANFO)
-    strncat(string, "*", 1);
+  if (!silc_fsm_is_started(&client->internal->fsm)) {
+    SILC_LOG_WARNING(("Attempting to stop client library before it has been "
+                     "started (silc_client_init not called)"));
+    return;
+  }
 
-  if (mode & SILC_CHANNEL_UMODE_CHANOP)
-    strncat(string, "@", 1);
+  client->internal->running = (SilcClientRunning)stopped;
+  client->internal->running_context = context;
 
-  return strdup(string);
+  /* Signal to stop */
+  client->internal->stop = TRUE;
+  SILC_FSM_EVENT_SIGNAL(&client->internal->wait_event);
 }