Merge branch 'master' of ssh://gnunet.org/gnunet
[oweals/gnunet.git] / src / consensus / gnunet-service-consensus.c
index ad0266954992564557120f1dd68845fefee8c174..b934f468fbddad7cb6ea1a635e9f6175c5b147dd 100644 (file)
@@ -1,10 +1,10 @@
 /*
       This file is part of GNUnet
-      (C) 2012 Christian Grothoff (and other contributing authors)
+      Copyright (C) 2012, 2013, 2017 GNUnet e.V.
 
       GNUnet 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, or (at your
+      by the Free Software Foundation; either version 3, or (at your
       option) any later version.
 
       GNUnet is distributed in the hope that it will be useful, but
 
       You should have received a copy of the GNU General Public License
       along with GNUnet; see the file COPYING.  If not, write to the
-      Free Software Foundation, Inc., 59 Temple Place - Suite 330,
-      Boston, MA 02111-1307, USA.
+      Free Software Foundation, Inc., 51 Franklin Street, Fifth Floor,
+      Boston, MA 02110-1301, USA.
 */
 
-
 /**
  * @file consensus/gnunet-service-consensus.c
- * @brief 
+ * @brief multi-peer set reconciliation
  * @author Florian Dold
  */
 
 #include "platform.h"
-#include "gnunet_common.h"
+#include "gnunet_util_lib.h"
+#include "gnunet_block_lib.h"
 #include "gnunet_protocols.h"
 #include "gnunet_applications.h"
-#include "gnunet_util_lib.h"
+#include "gnunet_set_service.h"
+#include "gnunet_statistics_service.h"
 #include "gnunet_consensus_service.h"
-#include "gnunet_core_service.h"
-#include "gnunet_stream_lib.h"
 #include "consensus_protocol.h"
-#include "ibf.h"
 #include "consensus.h"
 
 
-/**
- * Number of IBFs in a strata estimator.
- */
-#define STRATA_COUNT 32
-/**
- * Number of buckets per IBF.
- */
-#define STRATA_IBF_BUCKETS 80
-/**
- * hash num parameter of the IBF
- */
-#define STRATA_HASH_NUM 3
-/**
- * Number of strata that can be transmitted in one message.
- */
-#define STRATA_PER_MESSAGE ((1<<15) / (IBF_BUCKET_SIZE * STRATA_IBF_BUCKETS))
-
-
-
-/* forward declarations */
-
-struct ConsensusSession;
-struct IncomingSocket;
-
-static void
-send_next (struct ConsensusSession *session);
-
-static void 
-write_strata (void *cls, enum GNUNET_STREAM_Status status, size_t size);
-
-static int
-get_peer_idx (const struct GNUNET_PeerIdentity *peer, const struct ConsensusSession *session);
-
-
-/**
- * An element that is waiting to be transmitted to a client.
- */
-struct PendingElement
+enum ReferendumVote
 {
   /**
-   * Pending elements are kept in a DLL.
+   * Vote that nothing should change.
+   * This option is never voted explicitly.
    */
-  struct PendingElement *next;
-
+  VOTE_STAY = 0,
   /**
-   * Pending elements are kept in a DLL.
+   * Vote that an element should be added.
    */
-  struct PendingElement *prev;
-
+  VOTE_ADD = 1,
   /**
-   * The actual element
+   * Vote that an element should be removed.
    */
-  struct GNUNET_CONSENSUS_Element *element;
+  VOTE_REMOVE = 2,
 };
 
-struct ConsensusPeerInformation
+
+enum EarlyStoppingPhase
 {
-  struct GNUNET_STREAM_Socket *socket;
+  EARLY_STOPPING_NONE = 0,
+  EARLY_STOPPING_ONE_MORE = 1,
+  EARLY_STOPPING_DONE = 2,
+};
 
-  /**
-   * Is socket's connection established, i.e. can we write to it?
-   * Only relevent on outgoing cpi.
-   */
-  int is_connected;
 
+GNUNET_NETWORK_STRUCT_BEGIN
+
+/**
+ * Tuple of integers that together
+ * identify a task uniquely.
+ */
+struct TaskKey {
   /**
-   * Type of the peer in the all-to-all rounds,
-   * GNUNET_YES if we initiate reconciliation.
+   * A value from 'enum PhaseKind'.
    */
-  int is_outgoing;
+  uint16_t kind GNUNET_PACKED;
 
   /**
-   * Did we receive/send a consensus hello?
+   * Number of the first peer
+   * in canonical order.
    */
-  int hello;
+  int16_t peer1 GNUNET_PACKED;
 
   /**
-   * Handle for currently active read
+   * Number of the second peer in canonical order.
    */
-  struct GNUNET_STREAM_ReadHandle *rh;
+  int16_t peer2 GNUNET_PACKED;
 
   /**
-   * Handle for currently active read
+   * Repetition of the gradecast phase.
    */
-  struct GNUNET_STREAM_WriteHandle *wh;
+  int16_t repetition GNUNET_PACKED;
 
   /**
-   * How many of the strate in the ibf were
-   * sent or received in this round?
+   * Leader in the gradecast phase.
+   *
+   * Can be different from both peer1 and peer2.
    */
-  int strata_counter;
+  int16_t leader GNUNET_PACKED;
+};
 
-  struct InvertibleBloomFilter *my_ibf;
 
-  int my_ibf_bucket_counter;
 
-  struct InvertibleBloomFilter *peer_ibf;
+struct SetKey
+{
+  int set_kind GNUNET_PACKED;
+  int k1 GNUNET_PACKED;
+  int k2 GNUNET_PACKED;
+};
 
-  int peer_ibf_bucket_counter;
 
+struct SetEntry
+{
+  struct SetKey key;
+  struct GNUNET_SET_Handle *h;
   /**
-   * Strata estimator of the peer, NULL if our peer
-   * initiated the reconciliation.
+   * GNUNET_YES if the set resulted
+   * from applying a referendum with contested
+   * elements.
    */
-  struct InvertibleBloomFilter **strata;
+  int is_contested;
+};
 
-  struct GNUNET_SERVER_MessageStreamTokenizer *mst;
 
-  struct ConsensusSession *session;
+struct DiffKey
+{
+  int diff_kind GNUNET_PACKED;
+  int k1 GNUNET_PACKED;
+  int k2 GNUNET_PACKED;
 };
 
-struct QueuedMessage
+struct RfnKey
 {
-  struct GNUNET_MessageHeader *msg;
+  int rfn_kind GNUNET_PACKED;
+  int k1 GNUNET_PACKED;
+  int k2 GNUNET_PACKED;
+};
+
 
+GNUNET_NETWORK_STRUCT_END
+
+enum PhaseKind
+{
+  PHASE_KIND_ALL_TO_ALL,
+  PHASE_KIND_ALL_TO_ALL_2,
+  PHASE_KIND_GRADECAST_LEADER,
+  PHASE_KIND_GRADECAST_ECHO,
+  PHASE_KIND_GRADECAST_ECHO_GRADE,
+  PHASE_KIND_GRADECAST_CONFIRM,
+  PHASE_KIND_GRADECAST_CONFIRM_GRADE,
   /**
-   * Queued messages are stored in a doubly linked list.
+   * Apply a repetition of the all-to-all
+   * gradecast to the current set.
    */
-  struct QueuedMessage *next;
+  PHASE_KIND_APPLY_REP,
+  PHASE_KIND_FINISH,
+};
+
 
+enum SetKind
+{
+  SET_KIND_NONE = 0,
+  SET_KIND_CURRENT,
   /**
-   * Queued messages are stored in a doubly linked list.
+   * Last result set from a gradecast
    */
-  struct QueuedMessage *prev;
+  SET_KIND_LAST_GRADECAST,
+  SET_KIND_LEADER_PROPOSAL,
+  SET_KIND_ECHO_RESULT,
+};
+
+enum DiffKind
+{
+  DIFF_KIND_NONE = 0,
+  DIFF_KIND_LEADER_PROPOSAL,
+  DIFF_KIND_LEADER_CONSENSUS,
+  DIFF_KIND_GRADECAST_RESULT,
+};
+
+enum RfnKind
+{
+  RFN_KIND_NONE = 0,
+  RFN_KIND_ECHO,
+  RFN_KIND_CONFIRM,
+  RFN_KIND_GRADECAST_RESULT
+};
+
+
+struct SetOpCls
+{
+  struct SetKey input_set;
+
+  struct SetKey output_set;
+  struct RfnKey output_rfn;
+  struct DiffKey output_diff;
+
+  int do_not_remove;
+
+  int transceive_contested;
+
+  struct GNUNET_SET_OperationHandle *op;
 };
 
 
+struct FinishCls
+{
+  struct SetKey input_set;
+};
+
 /**
- * A consensus session consists of one local client and the remote authorities.
+ * Closure for both @a start_task
+ * and @a cancel_task.
  */
-struct ConsensusSession
+union TaskFuncCls
+{
+  struct SetOpCls setop;
+  struct FinishCls finish;
+};
+
+struct TaskEntry;
+
+typedef void (*TaskFunc) (struct TaskEntry *task);
+
+/*
+ * Node in the consensus task graph.
+ */
+struct TaskEntry
+{
+  struct TaskKey key;
+
+  struct Step *step;
+
+  int is_started;
+
+  int is_finished;
+
+  TaskFunc start;
+  TaskFunc cancel;
+
+  union TaskFuncCls cls;
+};
+
+
+struct Step
 {
   /**
-   * Consensus sessions are kept in a DLL.
+   * All steps of one session are in a
+   * linked list for easier deallocation.
    */
-  struct ConsensusSession *next;
+  struct Step *prev;
 
   /**
-   * Consensus sessions are kept in a DLL.
+   * All steps of one session are in a
+   * linked list for easier deallocation.
    */
-  struct ConsensusSession *prev;
+  struct Step *next;
+
+  struct ConsensusSession *session;
 
   /**
-   * Join message. Used to initialize the session later,
-   * if the identity of the local peer is not yet known.
-   * NULL if the session has been fully initialized.
+   * Tasks that this step is composed of.
    */
-  struct GNUNET_CONSENSUS_JoinMessage *join_msg;
+  struct TaskEntry **tasks;
+  unsigned int tasks_len;
+  unsigned int tasks_cap;
+
+  unsigned int finished_tasks;
+
+  /*
+   * Tasks that have this task as dependency.
+   *
+   * We store pointers to subordinates rather
+   * than to prerequisites since it makes
+   * tracking the readiness of a task easier.
+   */
+  struct Step **subordinates;
+  unsigned int subordinates_len;
+  unsigned int subordinates_cap;
 
   /**
-  * Global consensus identification, computed
-  * from the local id and participating authorities.
-  */
-  struct GNUNET_HashCode global_id;
+   * Counter for the prerequisites of
+   * this step.
+   */
+  size_t pending_prereq;
 
-  /**
-   * Local client in this consensus session.
-   * There is only one client per consensus session.
+  /*
+   * Task that will run this step despite
+   * any pending prerequisites.
    */
-  struct GNUNET_SERVER_Client *client;
+  struct GNUNET_SCHEDULER_Task *timeout_task;
 
-  /**
-   * Values in the consensus set of this session,
-   * all of them either have been sent by or approved by the client.
+  unsigned int is_running;
+
+  unsigned int is_finished;
+
+  /*
+   * Synchrony round of the task.
+   * Determines the deadline for the task.
    */
-  struct GNUNET_CONTAINER_MultiHashMap *values;
+  unsigned int round;
 
   /**
-   * Elements that have not been sent to the client yet.
+   * Human-readable name for
+   * the task, used for debugging.
    */
-  struct PendingElement *transmit_pending_head;
+  char *debug_name;
 
   /**
-   * Elements that have not been sent to the client yet.
+   * When we're doing an early finish, how should this step be
+   * treated?
+   * If GNUNET_YES, the step will be marked as finished
+   * without actually running its tasks.
+   * Otherwise, the step will still be run even after
+   * an early finish.
+   *
+   * Note that a task may never be finished early if
+   * it is already running.
    */
-  struct PendingElement *transmit_pending_tail;
+  int early_finishable;
+};
 
-  /**
-   * Elements that have not been approved (or rejected) by the client yet.
+
+struct RfnElementInfo
+{
+  const struct GNUNET_SET_Element *element;
+
+  /*
+   * GNUNET_YES if the peer votes for the proposal.
    */
-  struct PendingElement *approval_pending_head;
+  int *votes;
 
   /**
-   * Elements that have not been approved (or rejected) by the client yet.
+   * Proposal for this element,
+   * can only be VOTE_ADD or VOTE_REMOVE.
    */
-  struct PendingElement *approval_pending_tail;
+  enum ReferendumVote proposal;
+};
 
-  struct QueuedMessage *client_messages_head;
 
-  struct QueuedMessage *client_messages_tail;
+struct ReferendumEntry
+{
+  struct RfnKey key;
 
-  /**
-   * Currently active transmit handle for sending to the client
+  /*
+   * Elements where there is at least one proposed change.
+   *
+   * Maps the hash of the GNUNET_SET_Element
+   * to 'struct RfnElementInfo'.
    */
-  struct GNUNET_SERVER_TransmitHandle *th;
+  struct GNUNET_CONTAINER_MultiHashMap *rfn_elements;
+
+  unsigned int num_peers;
 
   /**
-   * Once conclude_requested is GNUNET_YES, the client may not
-   * insert any more values.
+   * Stores, for every peer in the session,
+   * whether the peer finished the whole referendum.
+   *
+   * Votes from peers are only counted if they're
+   * marked as commited (#GNUNET_YES) in the referendum.
+   *
+   * Otherwise (#GNUNET_NO), the requested changes are
+   * not counted for majority votes or thresholds.
    */
-  int conclude_requested;
+  int *peer_commited;
+
 
   /**
-   * Minimum number of peers to form a consensus group
+   * Contestation state of the peer.  If a peer is contested, the values it
+   * contributed are still counted for applying changes, but the grading is
+   * affected.
    */
-  int conclude_group_min;
+  int *peer_contested;
+};
+
+
+struct DiffElementInfo
+{
+  const struct GNUNET_SET_Element *element;
 
   /**
-   * Current round of the conclusion
+   * Positive weight for 'add', negative
+   * weights for 'remove'.
    */
-  int current_round;
+  int weight;
+};
+
+
+/**
+ * Weighted diff.
+ */
+struct DiffEntry
+{
+  struct DiffKey key;
+  struct GNUNET_CONTAINER_MultiHashMap *changes;
+};
+
 
+
+/**
+ * A consensus session consists of one local client and the remote authorities.
+ */
+struct ConsensusSession
+{
   /**
-   * Soft deadline for conclude.
-   * Speed up the speed of the consensus at the cost of consensus quality, as
-   * the time approached or crosses the deadline.
+   * Consensus sessions are kept in a DLL.
    */
-  struct GNUNET_TIME_Absolute conclude_deadline;
+  struct ConsensusSession *next;
 
   /**
-   * Number of other peers in the consensus
+   * Consensus sessions are kept in a DLL.
    */
-  unsigned int num_peers;
+  struct ConsensusSession *prev;
 
-  struct ConsensusPeerInformation *info;
+  unsigned int num_client_insert_pending;
+
+  struct GNUNET_CONTAINER_MultiHashMap *setmap;
+  struct GNUNET_CONTAINER_MultiHashMap *rfnmap;
+  struct GNUNET_CONTAINER_MultiHashMap *diffmap;
 
   /**
-   * Sorted array of peer identities in this consensus session,
-   * includes the local peer.
+   * Array of peers with length 'num_peers'.
    */
-  struct GNUNET_PeerIdentity *peers;
+  int *peers_blacklisted;
+
+  /*
+   * Mapping from (hashed) TaskKey to TaskEntry.
+   *
+   * We map the application_id for a round to the task that should be
+   * executed, so we don't have to go through all task whenever we get
+   * an incoming set op request.
+   */
+  struct GNUNET_CONTAINER_MultiHashMap *taskmap;
+
+  struct Step *steps_head;
+  struct Step *steps_tail;
+
+  int conclude_started;
+
+  int conclude_done;
 
   /**
-   * Index of the local peer in the peers array
-   */
-  int local_peer_idx;
+  * Global consensus identification, computed
+  * from the session id and participating authorities.
+  */
+  struct GNUNET_HashCode global_id;
 
   /**
-   * Task identifier for the round timeout task
+   * Client that inhabits the session
    */
-  GNUNET_SCHEDULER_TaskIdentifier round_timeout_tid;
+  struct GNUNET_SERVICE_Client *client;
 
-  struct InvertibleBloomFilter **strata;
-};
+  /**
+   * Queued messages to the client.
+   */
+  struct GNUNET_MQ_Handle *client_mq;
 
+  /**
+   * Time when the conclusion of the consensus should begin.
+   */
+  struct GNUNET_TIME_Absolute conclude_start;
 
-/**
- * Sockets from other peers who want to communicate with us.
- * It may not be known yet which consensus session they belong to.
- */
-struct IncomingSocket
-{
   /**
-   * Incoming sockets are kept in a double linked list.
+   * Timeout for all rounds together, single rounds will schedule a timeout task
+   * with a fraction of the conclude timeout.
+   * Only valid once the current round is not CONSENSUS_ROUND_BEGIN.
    */
-  struct IncomingSocket *next;
+  struct GNUNET_TIME_Absolute conclude_deadline;
+
+  struct GNUNET_PeerIdentity *peers;
 
   /**
-   * Incoming sockets are kept in a double linked list.
+   * Number of other peers in the consensus.
    */
-  struct IncomingSocket *prev;
+  unsigned int num_peers;
 
   /**
-   * The actual socket.
+   * Index of the local peer in the peers array
    */
-  struct GNUNET_STREAM_Socket *socket;
+  unsigned int local_peer_idx;
 
   /**
-   * Handle for currently active read
+   * Listener for requests from other peers.
+   * Uses the session's global id as app id.
    */
-  struct GNUNET_STREAM_ReadHandle *rh;
+  struct GNUNET_SET_ListenHandle *set_listener;
 
   /**
-   * Peer that connected to us with the socket.
+   * State of our early stopping scheme.
    */
-  struct GNUNET_PeerIdentity *peer;
+  int early_stopping;
 
   /**
-   * Message stream tokenizer for this socket.
+   * Our set size from the first round.
    */
-  struct GNUNET_SERVER_MessageStreamTokenizer *mst;
+  uint64_t first_size;
+
+  uint64_t *first_sizes_received;
 
   /**
-   * Peer-in-session this socket belongs to, once known, otherwise NULL.
+   * Bounded Eppstein lower bound.
    */
-  struct ConsensusPeerInformation *cpi;
+  uint64_t lower_bound;
 };
 
-static struct IncomingSocket *incoming_sockets_head;
-static struct IncomingSocket *incoming_sockets_tail;
-
 /**
- * Linked list of sesstions this peer participates in.
+ * Linked list of sessions this peer participates in.
  */
 static struct ConsensusSession *sessions_head;
 
 /**
- * Linked list of sesstions this peer participates in.
+ * Linked list of sessions this peer participates in.
  */
 static struct ConsensusSession *sessions_tail;
 
@@ -344,1020 +516,2766 @@ static struct ConsensusSession *sessions_tail;
  */
 static const struct GNUNET_CONFIGURATION_Handle *cfg;
 
-/**
- * Handle to the server for this service.
- */
-static struct GNUNET_SERVER_Handle *srv;
-
 /**
  * Peer that runs this service.
  */
-static struct GNUNET_PeerIdentity *my_peer;
+static struct GNUNET_PeerIdentity my_peer;
 
 /**
- * Handle to the core service. Only used during service startup, will be NULL after that.
+ * Statistics handle.
  */
-static struct GNUNET_CORE_Handle *core;
+struct GNUNET_STATISTICS_Handle *statistics;
 
-/**
- * Listener for sockets from peers that want to reconcile with us.
- */
-static struct GNUNET_STREAM_ListenSocket *listener;
+
+static void
+finish_task (struct TaskEntry *task);
 
 
-static int
-estimate_difference (struct InvertibleBloomFilter** strata1,
-                     struct InvertibleBloomFilter** strata2)
+static void
+run_ready_steps (struct ConsensusSession *session);
+
+
+static const char *
+phasename (uint16_t phase)
 {
-  int i;
-  int count;
-  count = 0;
-  for (i = STRATA_COUNT - 1; i >= 0; i--)
-  {
-    struct InvertibleBloomFilter *diff;
-    int ibf_count;
-    int more;
-    ibf_count = 0;
-    diff = ibf_dup (strata1[i]);
-    ibf_subtract (diff, strata2[i]);
-    for (;;)
-    {
-      more = ibf_decode (diff, NULL, NULL);
-      if (GNUNET_NO == more)
-      {
-        count += ibf_count;
-        break;
-      }
-      if (GNUNET_SYSERR == more)
-      {
-        return count * (1 << (i + 1));
-      }
-      ibf_count++;
-    }
-    ibf_destroy (diff);
+  switch (phase)
+  {
+    case PHASE_KIND_ALL_TO_ALL: return "ALL_TO_ALL";
+    case PHASE_KIND_ALL_TO_ALL_2: return "ALL_TO_ALL_2";
+    case PHASE_KIND_FINISH: return "FINISH";
+    case PHASE_KIND_GRADECAST_LEADER: return "GRADECAST_LEADER";
+    case PHASE_KIND_GRADECAST_ECHO: return "GRADECAST_ECHO";
+    case PHASE_KIND_GRADECAST_ECHO_GRADE: return "GRADECAST_ECHO_GRADE";
+    case PHASE_KIND_GRADECAST_CONFIRM: return "GRADECAST_CONFIRM";
+    case PHASE_KIND_GRADECAST_CONFIRM_GRADE: return "GRADECAST_CONFIRM_GRADE";
+    case PHASE_KIND_APPLY_REP: return "APPLY_REP";
+    default: return "(unknown)";
   }
-  return count;
 }
 
 
-/**
- * Functions of this signature are called whenever data is available from the
- * stream.
- *
- * @param cls the closure from GNUNET_STREAM_read
- * @param status the status of the stream at the time this function is called
- * @param data traffic from the other side
- * @param size the number of bytes available in data read; will be 0 on timeout 
- * @return number of bytes of processed from 'data' (any data remaining should be
- *         given to the next time the read processor is called).
- */
-static size_t
-stream_data_processor (void *cls,
-                       enum GNUNET_STREAM_Status status,
-                       const void *data,
-                       size_t size)
+static const char *
+setname (uint16_t kind)
 {
-  struct IncomingSocket *incoming;
-  int ret;
-
-  GNUNET_assert (GNUNET_STREAM_OK == status);
-
-  incoming = (struct IncomingSocket *) cls;
-
-  ret = GNUNET_SERVER_mst_receive (incoming->mst, incoming, data, size, GNUNET_NO, GNUNET_NO);
-  if (GNUNET_SYSERR == ret)
+  switch (kind)
   {
-    /* FIXME: handle this correctly */
-    GNUNET_assert (0);
+    case SET_KIND_CURRENT: return "CURRENT";
+    case SET_KIND_LEADER_PROPOSAL: return "LEADER_PROPOSAL";
+    case SET_KIND_NONE: return "NONE";
+    default: return "(unknown)";
   }
-
-  /* read again */
-  incoming->rh = GNUNET_STREAM_read (incoming->socket, GNUNET_TIME_UNIT_FOREVER_REL,
-                                     &stream_data_processor, incoming);
-
-  /* we always read all data */
-  return size;
 }
 
-static int
-handle_p2p_strata (struct ConsensusPeerInformation *cpi, const struct StrataMessage *strata_msg)
+static const char *
+rfnname (uint16_t kind)
 {
-  int i;
-  int num_strata;
-  struct GNUNET_HashCode *hash_src;
-  uint8_t *count_src;
-
-  GNUNET_assert (GNUNET_NO == cpi->is_outgoing);
-
-  if (NULL == cpi->strata)
+  switch (kind)
   {
-    cpi->strata = GNUNET_malloc (STRATA_COUNT * sizeof (struct InvertibleBloomFilter *));
-    for (i = 0; i < STRATA_COUNT; i++)
-      cpi->strata[i] = ibf_create (STRATA_IBF_BUCKETS, STRATA_HASH_NUM, 0);
+    case RFN_KIND_NONE: return "NONE";
+    case RFN_KIND_ECHO: return "ECHO";
+    case RFN_KIND_CONFIRM: return "CONFIRM";
+    default: return "(unknown)";
   }
+}
 
-  num_strata = ntohs (strata_msg->num_strata);
-
-  /* for correct message alignment, copy bucket types seperately */
-  hash_src = (struct GNUNET_HashCode *) &strata_msg[1];
-
-  for (i = 0; i < num_strata; i++)
+static const char *
+diffname (uint16_t kind)
+{
+  switch (kind)
   {
-    memcpy (cpi->strata[cpi->strata_counter+i]->hash_sum, hash_src, STRATA_IBF_BUCKETS * sizeof *hash_src);
-    hash_src += STRATA_IBF_BUCKETS;
+    case DIFF_KIND_NONE: return "NONE";
+    case DIFF_KIND_LEADER_CONSENSUS: return "LEADER_CONSENSUS";
+    case DIFF_KIND_GRADECAST_RESULT: return "GRADECAST_RESULT";
+    case DIFF_KIND_LEADER_PROPOSAL: return "LEADER_PROPOSAL";
+    default: return "(unknown)";
   }
+}
 
-  for (i = 0; i < num_strata; i++)
-  {
-    memcpy (cpi->strata[cpi->strata_counter+i]->id_sum, hash_src, STRATA_IBF_BUCKETS * sizeof *hash_src);
-    hash_src += STRATA_IBF_BUCKETS;
-  }
+#ifdef GNUNET_EXTRA_LOGGING
 
-  count_src = (uint8_t *) hash_src;
 
-  for (i = 0; i < num_strata; i++)
-  {
-    uint8_t zero[STRATA_IBF_BUCKETS];
-    memset (zero, 0, STRATA_IBF_BUCKETS);
-    memcpy (cpi->strata[cpi->strata_counter+i]->count, count_src, STRATA_IBF_BUCKETS);
-    count_src += STRATA_IBF_BUCKETS;
-  }
+static const char *
+debug_str_element (const struct GNUNET_SET_Element *el)
+{
+  struct GNUNET_HashCode hash;
 
-  GNUNET_assert (count_src == (((uint8_t *) &strata_msg[1]) + STRATA_IBF_BUCKETS * num_strata * IBF_BUCKET_SIZE));
+  GNUNET_SET_element_hash (el, &hash);
 
-  cpi->strata_counter += num_strata;
+  return GNUNET_h2s (&hash);
+}
 
-  if (STRATA_COUNT == cpi->strata_counter)
-  {
-    int diff;
-    diff = estimate_difference (cpi->session->strata, cpi->strata);
-    GNUNET_log (GNUNET_ERROR_TYPE_INFO, "diff=%d\n", diff);
-  }
+static const char *
+debug_str_task_key (struct TaskKey *tk)
+{
+  static char buf[256];
 
-  return GNUNET_YES;
-}
+  snprintf (buf, sizeof (buf),
+            "TaskKey kind=%s, p1=%d, p2=%d, l=%d, rep=%d",
+            phasename (tk->kind), tk->peer1, tk->peer2,
+            tk->leader, tk->repetition);
 
+  return buf;
+}
 
-static int
-handle_p2p_ibf (struct ConsensusPeerInformation *cpi, const struct DifferenceDigest *strata)
+static const char *
+debug_str_diff_key (struct DiffKey *dk)
 {
-  return GNUNET_YES;
-}
+  static char buf[256];
 
+  snprintf (buf, sizeof (buf),
+            "DiffKey kind=%s, k1=%d, k2=%d",
+            diffname (dk->diff_kind), dk->k1, dk->k2);
 
-static int
-handle_p2p_element (struct ConsensusPeerInformation *cpi, const struct Element *strata)
-{
-  return GNUNET_YES;
+  return buf;
 }
 
-
-static int
-handle_p2p_hello (struct IncomingSocket *inc, const struct ConsensusHello *hello)
+static const char *
+debug_str_set_key (const struct SetKey *sk)
 {
-  struct ConsensusSession *session;
-  session = sessions_head;
-  while (NULL != session)
-  {
-    if (0 == GNUNET_CRYPTO_hash_cmp (&session->global_id, &hello->global_id))
-    {
-      int idx;
-      GNUNET_log (GNUNET_ERROR_TYPE_INFO, "peer helloed session\n");
-      idx = get_peer_idx (inc->peer, session);
-      GNUNET_assert (-1 != idx);
-      GNUNET_log (GNUNET_ERROR_TYPE_INFO, "idx is %d\n", idx);
-      inc->cpi = &session->info[idx];
-      GNUNET_assert (GNUNET_NO == inc->cpi->is_outgoing);
-      inc->cpi->mst = inc->mst;
-      inc->cpi->hello = GNUNET_YES;
-      inc->cpi->socket = inc->socket;
-      return GNUNET_YES;
-    }
-    session = session->next;
-  }
-  GNUNET_assert (0);
-  return GNUNET_NO;
-}
+  static char buf[256];
 
+  snprintf (buf, sizeof (buf),
+            "SetKey kind=%s, k1=%d, k2=%d",
+            setname (sk->set_kind), sk->k1, sk->k2);
 
-/**
- * Functions with this signature are called whenever a
- * complete message is received by the tokenizer.
- *
- * Do not call GNUNET_SERVER_mst_destroy in callback
- *
- * @param cls closure
- * @param client identification of the client
- * @param message the actual message
- *
- * @return GNUNET_OK on success, GNUNET_SYSERR to stop further processing
- */
-static int
-mst_session_callback (void *cls, void *client, const struct GNUNET_MessageHeader *message)
-{
-  struct ConsensusPeerInformation *cpi;
-  cpi = (struct ConsensusPeerInformation *) cls;
-  switch (ntohs( message->type))
-  {
-    case GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_DELTA_ESTIMATE:
-      return handle_p2p_strata (cpi, (struct StrataMessage *) message);
-    case GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_DIFFERENCE_DIGEST:
-      return handle_p2p_ibf (cpi, (struct DifferenceDigest *) message);
-    case GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_ELEMENTS:
-      return handle_p2p_element (cpi, (struct Element *) message);
-    default:
-      /* FIXME: handle correctly */
-      GNUNET_assert (0);
-  }
-  return GNUNET_OK;
+  return buf;
 }
 
 
-/**
- * Handle tokenized messages from stream sockets.
- * Delegate them if the socket belongs to a session,
- * handle hello messages otherwise.
- *
- * Do not call GNUNET_SERVER_mst_destroy in callback
- *
- * @param cls closure, unused
- * @param client incoming socket this message comes from
- * @param message the actual message
- *
- * @return GNUNET_OK on success, GNUNET_SYSERR to stop further processing
- */
-static int
-mst_incoming_callback (void *cls, void *client, const struct GNUNET_MessageHeader *message)
+static const char *
+debug_str_rfn_key (const struct RfnKey *rk)
 {
-  struct IncomingSocket *inc;
-  inc = (struct IncomingSocket *) client;
-  switch (ntohs( message->type))
-  {
-    case GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_HELLO:
-      return handle_p2p_hello (inc, (struct ConsensusHello *) message);
-    default:
-      if (NULL != inc->cpi)
-        return mst_session_callback (inc->cpi, client, message);
-      /* FIXME: disconnect peer properly */
-      GNUNET_assert (0);
-  }
-  return GNUNET_OK;
+  static char buf[256];
+
+  snprintf (buf, sizeof (buf),
+            "RfnKey kind=%s, k1=%d, k2=%d",
+            rfnname (rk->rfn_kind), rk->k1, rk->k2);
+
+  return buf;
 }
 
+#endif /* GNUNET_EXTRA_LOGGING */
+
 
 /**
- * Functions of this type are called upon new stream connection from other peers
- * or upon binding error which happen when the app_port given in
- * GNUNET_STREAM_listen() is already taken.
+ * Send the final result set of the consensus to the client, element by
+ * element.
  *
- * @param cls the closure from GNUNET_STREAM_listen
- * @param socket the socket representing the stream; NULL on binding error
- * @param initiator the identity of the peer who wants to establish a stream
- *            with us; NULL on binding error
- * @return GNUNET_OK to keep the socket open, GNUNET_SYSERR to close the
- *             stream (the socket will be invalid after the call)
+ * @param cls closure
+ * @param element the current element, NULL if all elements have been
+ *        iterated over
+ * @return #GNUNET_YES to continue iterating, #GNUNET_NO to stop.
  */
 static int
-listen_cb (void *cls,
-           struct GNUNET_STREAM_Socket *socket,
-           const struct GNUNET_PeerIdentity *initiator)
+send_to_client_iter (void *cls,
+                     const struct GNUNET_SET_Element *element)
 {
-  struct IncomingSocket *incoming;
-
-  GNUNET_assert (NULL != socket);
-
-  incoming = GNUNET_malloc (sizeof *incoming);
+  struct TaskEntry *task = (struct TaskEntry *) cls;
+  struct ConsensusSession *session = task->step->session;
+  struct GNUNET_MQ_Envelope *ev;
 
-  incoming->socket = socket;
-  incoming->peer = GNUNET_memdup (initiator, sizeof *initiator);
+  if (NULL != element)
+  {
+    struct GNUNET_CONSENSUS_ElementMessage *m;
+    const struct ConsensusElement *ce;
 
-  incoming->rh = GNUNET_STREAM_read (socket, GNUNET_TIME_UNIT_FOREVER_REL,
-                                     &stream_data_processor, incoming);
+    GNUNET_assert (GNUNET_BLOCK_TYPE_CONSENSUS_ELEMENT == element->element_type);
+    ce = element->data;
 
+    GNUNET_log (GNUNET_ERROR_TYPE_INFO, "marker is %u\n", (unsigned) ce->marker);
 
-  incoming->mst = GNUNET_SERVER_mst_create (mst_incoming_callback, incoming);
+    if (0 != ce->marker)
+      return GNUNET_YES;
 
-  GNUNET_CONTAINER_DLL_insert_tail (incoming_sockets_head, incoming_sockets_tail, incoming);
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "P%d: sending element %s to client\n",
+                session->local_peer_idx,
+                debug_str_element (element));
 
-  return GNUNET_OK;
-}
+    ev = GNUNET_MQ_msg_extra (m, element->size - sizeof (struct ConsensusElement),
+                              GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_RECEIVED_ELEMENT);
+    m->element_type = ce->payload_type;
+    GNUNET_memcpy (&m[1], &ce[1], element->size - sizeof (struct ConsensusElement));
+    GNUNET_MQ_send (session->client_mq, ev);
+  }
+  else
+  {
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "P%d: finished iterating elements for client\n",
+                session->local_peer_idx);
+    ev = GNUNET_MQ_msg_header (GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_CONCLUDE_DONE);
+    GNUNET_MQ_send (session->client_mq, ev);
+  }
+  return GNUNET_YES;
+}
+
+
+static struct SetEntry *
+lookup_set (struct ConsensusSession *session, struct SetKey *key)
+{
+  struct GNUNET_HashCode hash;
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "P%u: looking up set {%s}\n",
+              session->local_peer_idx,
+              debug_str_set_key (key));
+
+  GNUNET_assert (SET_KIND_NONE != key->set_kind);
+  GNUNET_CRYPTO_hash (key, sizeof (struct SetKey), &hash);
+  return GNUNET_CONTAINER_multihashmap_get (session->setmap, &hash);
+}
+
+
+static struct DiffEntry *
+lookup_diff (struct ConsensusSession *session, struct DiffKey *key)
+{
+  struct GNUNET_HashCode hash;
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "P%u: looking up diff {%s}\n",
+              session->local_peer_idx,
+              debug_str_diff_key (key));
+
+  GNUNET_assert (DIFF_KIND_NONE != key->diff_kind);
+  GNUNET_CRYPTO_hash (key, sizeof (struct DiffKey), &hash);
+  return GNUNET_CONTAINER_multihashmap_get (session->diffmap, &hash);
+}
+
+
+static struct ReferendumEntry *
+lookup_rfn (struct ConsensusSession *session, struct RfnKey *key)
+{
+  struct GNUNET_HashCode hash;
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "P%u: looking up rfn {%s}\n",
+              session->local_peer_idx,
+              debug_str_rfn_key (key));
+
+  GNUNET_assert (RFN_KIND_NONE != key->rfn_kind);
+  GNUNET_CRYPTO_hash (key, sizeof (struct RfnKey), &hash);
+  return GNUNET_CONTAINER_multihashmap_get (session->rfnmap, &hash);
+}
 
 
 static void
-destroy_session (struct ConsensusSession *session)
+diff_insert (struct DiffEntry *diff,
+             int weight,
+             const struct GNUNET_SET_Element *element)
 {
-  /* FIXME: more stuff to free! */
-  GNUNET_CONTAINER_DLL_remove (sessions_head, sessions_tail, session);
-  GNUNET_SERVER_client_drop (session->client);
-  GNUNET_free (session);
+  struct DiffElementInfo *di;
+  struct GNUNET_HashCode hash;
+
+  GNUNET_assert ( (1 == weight) || (-1 == weight));
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "diff_insert with element size %u\n",
+              element->size);
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "hashing element\n");
+
+  GNUNET_SET_element_hash (element, &hash);
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "hashed element\n");
+
+  di = GNUNET_CONTAINER_multihashmap_get (diff->changes, &hash);
+
+  if (NULL == di)
+  {
+    di = GNUNET_new (struct DiffElementInfo);
+    di->element = GNUNET_SET_element_dup (element);
+    GNUNET_assert (GNUNET_OK ==
+                   GNUNET_CONTAINER_multihashmap_put (diff->changes,
+                                                      &hash, di,
+                                                      GNUNET_CONTAINER_MULTIHASHMAPOPTION_UNIQUE_FAST));
+  }
+
+  di->weight = weight;
+}
+
+
+static void
+rfn_commit (struct ReferendumEntry *rfn,
+            uint16_t commit_peer)
+{
+  GNUNET_assert (commit_peer < rfn->num_peers);
+
+  rfn->peer_commited[commit_peer] = GNUNET_YES;
+}
+
+
+static void
+rfn_contest (struct ReferendumEntry *rfn,
+             uint16_t contested_peer)
+{
+  GNUNET_assert (contested_peer < rfn->num_peers);
+
+  rfn->peer_contested[contested_peer] = GNUNET_YES;
+}
+
+
+static uint16_t
+rfn_noncontested (struct ReferendumEntry *rfn)
+{
+  uint16_t i;
+  uint16_t ret;
+
+  ret = 0;
+  for (i = 0; i < rfn->num_peers; i++)
+    if ( (GNUNET_YES == rfn->peer_commited[i]) && (GNUNET_NO == rfn->peer_contested[i]) )
+      ret++;
+
+  return ret;
+}
+
+
+static void
+rfn_vote (struct ReferendumEntry *rfn,
+          uint16_t voting_peer,
+          enum ReferendumVote vote,
+          const struct GNUNET_SET_Element *element)
+{
+  struct RfnElementInfo *ri;
+  struct GNUNET_HashCode hash;
+
+  GNUNET_assert (voting_peer < rfn->num_peers);
+
+  /* Explicit voting only makes sense with VOTE_ADD or VOTE_REMOTE,
+     since VOTE_KEEP is implicit in not voting. */
+  GNUNET_assert ( (VOTE_ADD == vote) || (VOTE_REMOVE == vote) );
+
+  GNUNET_SET_element_hash (element, &hash);
+  ri = GNUNET_CONTAINER_multihashmap_get (rfn->rfn_elements, &hash);
+
+  if (NULL == ri)
+  {
+    ri = GNUNET_new (struct RfnElementInfo);
+    ri->element = GNUNET_SET_element_dup (element);
+    ri->votes = GNUNET_new_array (rfn->num_peers, int);
+    GNUNET_assert (GNUNET_OK ==
+                   GNUNET_CONTAINER_multihashmap_put (rfn->rfn_elements,
+                                                      &hash, ri,
+                                                      GNUNET_CONTAINER_MULTIHASHMAPOPTION_UNIQUE_FAST));
+  }
+
+  ri->votes[voting_peer] = GNUNET_YES;
+  ri->proposal = vote;
+}
+
+
+static uint16_t
+task_other_peer (struct TaskEntry *task)
+{
+  uint16_t me = task->step->session->local_peer_idx;
+  if (task->key.peer1 == me)
+    return task->key.peer2;
+  return task->key.peer1;
+}
+
+
+static int
+cmp_uint64_t (const void *pa, const void *pb)
+{
+  uint64_t a = *(uint64_t *) pa;
+  uint64_t b = *(uint64_t *) pb;
+
+  if (a == b)
+    return 0;
+  if (a < b)
+    return -1;
+  return 1;
 }
 
 
 /**
- * Disconnect a client, and destroy all sessions associated with it.
+ * Callback for set operation results. Called for each element
+ * in the result set.
  *
- * @param client the client to disconnect
+ * @param cls closure
+ * @param element a result element, only valid if status is GNUNET_SET_STATUS_OK
+ * @param current_size current set size
+ * @param status see enum GNUNET_SET_Status
  */
 static void
-disconnect_client (struct GNUNET_SERVER_Client *client)
+set_result_cb (void *cls,
+               const struct GNUNET_SET_Element *element,
+               uint64_t current_size,
+               enum GNUNET_SET_Status status)
 {
-  struct ConsensusSession *session;
-  GNUNET_SERVER_client_disconnect (client);
-  
-  /* if the client owns a session, remove it */
-  session = sessions_head;
-  while (NULL != session)
+  struct TaskEntry *task = cls;
+  struct ConsensusSession *session = task->step->session;
+  struct SetEntry *output_set = NULL;
+  struct DiffEntry *output_diff = NULL;
+  struct ReferendumEntry *output_rfn = NULL;
+  unsigned int other_idx;
+  struct SetOpCls *setop;
+  const struct ConsensusElement *consensus_element = NULL;
+
+  if (NULL != element)
+  {
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "P%u: got element of type %u, status %u\n",
+                session->local_peer_idx,
+                (unsigned) element->element_type,
+                (unsigned) status);
+    GNUNET_assert (GNUNET_BLOCK_TYPE_CONSENSUS_ELEMENT == element->element_type);
+    consensus_element = element->data;
+  }
+
+  setop = &task->cls.setop;
+
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "P%u: got set result for {%s}, status %u\n",
+              session->local_peer_idx,
+              debug_str_task_key (&task->key),
+              status);
+
+  if (GNUNET_NO == task->is_started)
+  {
+    GNUNET_break_op (0);
+    return;
+  }
+
+  if (GNUNET_YES == task->is_finished)
+  {
+    GNUNET_break_op (0);
+    return;
+  }
+
+  other_idx = task_other_peer (task);
+
+  if (SET_KIND_NONE != setop->output_set.set_kind)
+  {
+    output_set = lookup_set (session, &setop->output_set);
+    GNUNET_assert (NULL != output_set);
+  }
+
+  if (DIFF_KIND_NONE != setop->output_diff.diff_kind)
+  {
+    output_diff = lookup_diff (session, &setop->output_diff);
+    GNUNET_assert (NULL != output_diff);
+  }
+
+  if (RFN_KIND_NONE != setop->output_rfn.rfn_kind)
+  {
+    output_rfn = lookup_rfn (session, &setop->output_rfn);
+    GNUNET_assert (NULL != output_rfn);
+  }
+
+  if (GNUNET_YES == session->peers_blacklisted[other_idx])
+  {
+    /* Peer might have been blacklisted
+       by a gradecast running in parallel, ignore elements from now */
+    if (GNUNET_SET_STATUS_ADD_LOCAL == status)
+      return;
+    if (GNUNET_SET_STATUS_ADD_REMOTE == status)
+      return;
+  }
+
+  if ( (NULL != consensus_element) && (0 != consensus_element->marker) )
   {
-    if (client == session->client)
+    GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                "P%u: got some marker\n",
+                  session->local_peer_idx);
+    if ( (GNUNET_YES == setop->transceive_contested) &&
+         (CONSENSUS_MARKER_CONTESTED == consensus_element->marker) )
     {
-      destroy_session (session);
-      break;
+      GNUNET_assert (NULL != output_rfn);
+      rfn_contest (output_rfn, task_other_peer (task));
+      return;
+    }
+
+    if (CONSENSUS_MARKER_SIZE == consensus_element->marker)
+    {
+
+      GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                  "P%u: got size marker\n",
+                  session->local_peer_idx);
+
+
+      struct ConsensusSizeElement *cse = (void *) consensus_element;
+
+      if (cse->sender_index == other_idx)
+      {
+        if (NULL == session->first_sizes_received)
+          session->first_sizes_received = GNUNET_new_array (session->num_peers, uint64_t);
+        session->first_sizes_received[other_idx] = GNUNET_ntohll (cse->size);
+
+        uint64_t *copy = GNUNET_memdup (session->first_sizes_received, sizeof (uint64_t) * session->num_peers);
+        qsort (copy, session->num_peers, sizeof (uint64_t), cmp_uint64_t);
+        session->lower_bound = copy[session->num_peers / 3 + 1];
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: lower bound %llu\n",
+                    session->local_peer_idx,
+                    (long long) session->lower_bound);
+      }
+      return;
     }
-    session = session->next;
+
+    return;
+  }
+
+  switch (status)
+  {
+    case GNUNET_SET_STATUS_ADD_LOCAL:
+      GNUNET_assert (NULL != consensus_element);
+      GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                  "Adding element in Task {%s}\n",
+                  debug_str_task_key (&task->key));
+      if (NULL != output_set)
+      {
+        // FIXME: record pending adds, use callback
+        GNUNET_SET_add_element (output_set->h,
+                                element,
+                                NULL,
+                                NULL);
+#ifdef GNUNET_EXTRA_LOGGING
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: adding element %s into set {%s} of task {%s}\n",
+                    session->local_peer_idx,
+                    debug_str_element (element),
+                    debug_str_set_key (&setop->output_set),
+                    debug_str_task_key (&task->key));
+#endif
+      }
+      if (NULL != output_diff)
+      {
+        diff_insert (output_diff, 1, element);
+#ifdef GNUNET_EXTRA_LOGGING
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: adding element %s into diff {%s} of task {%s}\n",
+                    session->local_peer_idx,
+                    debug_str_element (element),
+                    debug_str_diff_key (&setop->output_diff),
+                    debug_str_task_key (&task->key));
+#endif
+      }
+      if (NULL != output_rfn)
+      {
+        rfn_vote (output_rfn, task_other_peer (task), VOTE_ADD, element);
+#ifdef GNUNET_EXTRA_LOGGING
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: adding element %s into rfn {%s} of task {%s}\n",
+                    session->local_peer_idx,
+                    debug_str_element (element),
+                    debug_str_rfn_key (&setop->output_rfn),
+                    debug_str_task_key (&task->key));
+#endif
+      }
+      // XXX: add result to structures in task
+      break;
+    case GNUNET_SET_STATUS_ADD_REMOTE:
+      GNUNET_assert (NULL != consensus_element);
+      if (GNUNET_YES == setop->do_not_remove)
+        break;
+      if (CONSENSUS_MARKER_CONTESTED == consensus_element->marker)
+        break;
+      GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                  "Removing element in Task {%s}\n",
+                  debug_str_task_key (&task->key));
+      if (NULL != output_set)
+      {
+        // FIXME: record pending adds, use callback
+        GNUNET_SET_remove_element (output_set->h,
+                                   element,
+                                   NULL,
+                                   NULL);
+#ifdef GNUNET_EXTRA_LOGGING
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: removing element %s from set {%s} of task {%s}\n",
+                    session->local_peer_idx,
+                    debug_str_element (element),
+                    debug_str_set_key (&setop->output_set),
+                    debug_str_task_key (&task->key));
+#endif
+      }
+      if (NULL != output_diff)
+      {
+        diff_insert (output_diff, -1, element);
+#ifdef GNUNET_EXTRA_LOGGING
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: removing element %s from diff {%s} of task {%s}\n",
+                    session->local_peer_idx,
+                    debug_str_element (element),
+                    debug_str_diff_key (&setop->output_diff),
+                    debug_str_task_key (&task->key));
+#endif
+      }
+      if (NULL != output_rfn)
+      {
+        rfn_vote (output_rfn, task_other_peer (task), VOTE_REMOVE, element);
+#ifdef GNUNET_EXTRA_LOGGING
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: removing element %s from rfn {%s} of task {%s}\n",
+                    session->local_peer_idx,
+                    debug_str_element (element),
+                    debug_str_rfn_key (&setop->output_rfn),
+                    debug_str_task_key (&task->key));
+#endif
+      }
+      break;
+    case GNUNET_SET_STATUS_DONE:
+      // XXX: check first if any changes to the underlying
+      // set are still pending
+      GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                  "Finishing setop in Task {%s}\n",
+                  debug_str_task_key (&task->key));
+      if (NULL != output_rfn)
+      {
+        rfn_commit (output_rfn, task_other_peer (task));
+      }
+      if (PHASE_KIND_ALL_TO_ALL == task->key.kind)
+      {
+        session->first_size = current_size;
+      }
+      finish_task (task);
+      break;
+    case GNUNET_SET_STATUS_FAILURE:
+      // XXX: cleanup
+      GNUNET_break_op (0);
+      finish_task (task);
+      return;
+    default:
+      /* not reached */
+      GNUNET_assert (0);
   }
 }
 
+#ifdef EVIL
+
+enum EvilnessType
+{
+  EVILNESS_NONE,
+  EVILNESS_CRAM_ALL,
+  EVILNESS_CRAM_LEAD,
+  EVILNESS_CRAM_ECHO,
+  EVILNESS_SLACK,
+  EVILNESS_SLACK_A2A,
+};
+
+enum EvilnessSubType
+{
+  EVILNESS_SUB_NONE,
+  EVILNESS_SUB_REPLACEMENT,
+  EVILNESS_SUB_NO_REPLACEMENT,
+};
+
+struct Evilness
+{
+  enum EvilnessType type;
+  enum EvilnessSubType subtype;
+  unsigned int num;
+};
+
+
+static int
+parse_evilness_cram_subtype (const char *evil_subtype_str, struct Evilness *evil)
+{
+  if (0 == strcmp ("replace", evil_subtype_str))
+  {
+    evil->subtype = EVILNESS_SUB_REPLACEMENT;
+  }
+  else if (0 == strcmp ("noreplace", evil_subtype_str))
+  {
+    evil->subtype = EVILNESS_SUB_NO_REPLACEMENT;
+  }
+  else
+  {
+    GNUNET_log (GNUNET_ERROR_TYPE_ERROR,
+                "Malformed field '%s' in EVIL_SPEC (unknown subtype), behaving like a good peer.\n",
+                evil_subtype_str);
+    return GNUNET_SYSERR;
+  }
+  return GNUNET_OK;
+}
+
 
-/**
- * Compute a global, (hopefully) unique consensus session id,
- * from the local id of the consensus session, and the identities of all participants.
- * Thus, if the local id of two consensus sessions coincide, but are not comprised of
- * exactly the same peers, the global id will be different.
- *
- * @param local_id local id of the consensus session
- * @param peers array of all peers participating in the consensus session
- * @param num_peers number of elements in the peers array
- * @param dst where the result is stored, may not be NULL
- */
 static void
-compute_global_id (const struct GNUNET_HashCode *local_id,
-                   const struct GNUNET_PeerIdentity *peers, int num_peers, 
-                   struct GNUNET_HashCode *dst)
+get_evilness (struct ConsensusSession *session, struct Evilness *evil)
 {
-  int i;
-  struct GNUNET_HashCode tmp;
+  char *evil_spec;
+  char *field;
+  char *evil_type_str = NULL;
+  char *evil_subtype_str = NULL;
+
+  GNUNET_assert (NULL != evil);
+
+  if (GNUNET_OK != GNUNET_CONFIGURATION_get_value_string (cfg, "consensus", "EVIL_SPEC", &evil_spec))
+  {
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "P%u: no evilness\n",
+                session->local_peer_idx);
+    evil->type = EVILNESS_NONE;
+    return;
+  }
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "P%u: got evilness spec\n",
+              session->local_peer_idx);
 
-  *dst = *local_id;
-  for (i = 0; i < num_peers; ++i)
+  for (field = strtok (evil_spec, "/");
+       NULL != field;
+       field = strtok (NULL, "/"))
   {
-    GNUNET_CRYPTO_hash_xor (dst, &peers[0].hashPubKey, &tmp);
-    *dst = tmp;
-    GNUNET_CRYPTO_hash (dst, sizeof (struct GNUNET_PeerIdentity), &tmp);
-    *dst = tmp;
+    unsigned int peer_num;
+    unsigned int evil_num;
+    int ret;
+
+    evil_type_str = NULL;
+    evil_subtype_str = NULL;
+
+    ret = sscanf (field, "%u;%m[a-z-];%m[a-z-];%u", &peer_num, &evil_type_str, &evil_subtype_str, &evil_num);
+
+    if (ret != 4)
+    {
+      GNUNET_log (GNUNET_ERROR_TYPE_ERROR,
+                  "Malformed field '%s' in EVIL_SPEC (expected 4 components got %d), behaving like a good peer.\n",
+                  field,
+                  ret);
+      goto not_evil;
+    }
+
+    GNUNET_assert (NULL != evil_type_str);
+    GNUNET_assert (NULL != evil_subtype_str);
+
+    if (peer_num == session->local_peer_idx)
+    {
+      if (0 == strcmp ("slack", evil_type_str))
+      {
+        evil->type = EVILNESS_SLACK;
+      }
+      if (0 == strcmp ("slack-a2a", evil_type_str))
+      {
+        evil->type = EVILNESS_SLACK_A2A;
+      }
+      else if (0 == strcmp ("cram-all", evil_type_str))
+      {
+        evil->type = EVILNESS_CRAM_ALL;
+        evil->num = evil_num;
+        if (GNUNET_OK != parse_evilness_cram_subtype (evil_subtype_str, evil))
+          goto not_evil;
+      }
+      else if (0 == strcmp ("cram-lead", evil_type_str))
+      {
+        evil->type = EVILNESS_CRAM_LEAD;
+        evil->num = evil_num;
+        if (GNUNET_OK != parse_evilness_cram_subtype (evil_subtype_str, evil))
+          goto not_evil;
+      }
+      else if (0 == strcmp ("cram-echo", evil_type_str))
+      {
+        evil->type = EVILNESS_CRAM_ECHO;
+        evil->num = evil_num;
+        if (GNUNET_OK != parse_evilness_cram_subtype (evil_subtype_str, evil))
+          goto not_evil;
+      }
+      else
+      {
+        GNUNET_log (GNUNET_ERROR_TYPE_ERROR,
+                    "Malformed field '%s' in EVIL_SPEC (unknown type), behaving like a good peer.\n",
+                    evil_type_str);
+        goto not_evil;
+      }
+      goto cleanup;
+    }
+    /* No GNUNET_free since memory was allocated by libc */
+    free (evil_type_str);
+    evil_type_str = NULL;
+    evil_subtype_str = NULL;
   }
+not_evil:
+  evil->type = EVILNESS_NONE;
+cleanup:
+  GNUNET_free (evil_spec);
+  /* no GNUNET_free_non_null since it wasn't
+   * allocated with GNUNET_malloc */
+  if (NULL != evil_type_str)
+    free (evil_type_str);
+  if (NULL != evil_subtype_str)
+    free (evil_subtype_str);
 }
 
+#endif
+
 
 /**
- * Function called to notify a client about the connection
- * begin ready to queue more data.  "buf" will be
- * NULL and "size" zero if the connection was closed for
- * writing in the meantime.
- *
- * @param cls consensus session
- * @param size number of bytes available in buf
- * @param buf where the callee should write the message
- * @return number of bytes written to buf
+ * Commit the appropriate set for a
+ * task.
  */
-static size_t
-transmit_queued (void *cls, size_t size,
-                 void *buf)
+static void
+commit_set (struct ConsensusSession *session,
+            struct TaskEntry *task)
 {
-  struct ConsensusSession *session;
-  struct QueuedMessage *qmsg;
-  size_t msg_size;
+  struct SetEntry *set;
+  struct SetOpCls *setop = &task->cls.setop;
 
-  session = (struct ConsensusSession *) cls;
-  session->th = NULL;
+  GNUNET_assert (NULL != setop->op);
+  set = lookup_set (session, &setop->input_set);
+  GNUNET_assert (NULL != set);
 
+  if ( (GNUNET_YES == setop->transceive_contested) && (GNUNET_YES == set->is_contested) )
+  {
+    struct GNUNET_SET_Element element;
+    struct ConsensusElement ce = { 0 };
+    ce.marker = CONSENSUS_MARKER_CONTESTED;
+    element.data = &ce;
+    element.size = sizeof (struct ConsensusElement);
+    element.element_type = GNUNET_BLOCK_TYPE_CONSENSUS_ELEMENT;
+    GNUNET_SET_add_element (set->h, &element, NULL, NULL);
+  }
 
-  qmsg = session->client_messages_head;
-  GNUNET_CONTAINER_DLL_remove (session->client_messages_head, session->client_messages_tail, qmsg);
-  GNUNET_assert (qmsg);
+  if (PHASE_KIND_ALL_TO_ALL_2 == task->key.kind)
+  {
+    struct GNUNET_SET_Element element;
+    struct ConsensusSizeElement cse = { 0 };
+    GNUNET_log (GNUNET_ERROR_TYPE_INFO, "inserting size marker\n");
+    cse.ce.marker = CONSENSUS_MARKER_SIZE;
+    cse.size = GNUNET_htonll (session->first_size);
+    cse.sender_index = session->local_peer_idx;
+    element.data = &cse;
+    element.size = sizeof (struct ConsensusSizeElement);
+    element.element_type = GNUNET_BLOCK_TYPE_CONSENSUS_ELEMENT;
+    GNUNET_SET_add_element (set->h, &element, NULL, NULL);
+  }
 
-  if (NULL == buf)
+#ifdef EVIL
   {
-    destroy_session (session);
-    return 0;
+    unsigned int i;
+    struct Evilness evil;
+
+    get_evilness (session, &evil);
+    if (EVILNESS_NONE != evil.type)
+    {
+      /* Useful for evaluation */
+      GNUNET_STATISTICS_set (statistics,
+                             "is evil",
+                             1,
+                             GNUNET_NO);
+    }
+    switch (evil.type)
+    {
+      case EVILNESS_CRAM_ALL:
+      case EVILNESS_CRAM_LEAD:
+      case EVILNESS_CRAM_ECHO:
+        /* We're not cramming elements in the
+           all-to-all round, since that would just
+           add more elements to the result set, but
+           wouldn't test robustness. */
+        if (PHASE_KIND_ALL_TO_ALL == task->key.kind)
+        {
+          GNUNET_SET_commit (setop->op, set->h);
+          break;
+        }
+        if ((EVILNESS_CRAM_LEAD == evil.type) &&
+            ((PHASE_KIND_GRADECAST_LEADER != task->key.kind) || SET_KIND_CURRENT != set->key.set_kind))
+        {
+          GNUNET_SET_commit (setop->op, set->h);
+          break;
+        }
+        if (EVILNESS_CRAM_ECHO == evil.type && (PHASE_KIND_GRADECAST_ECHO != task->key.kind))
+        {
+          GNUNET_SET_commit (setop->op, set->h);
+          break;
+        }
+        for (i = 0; i < evil.num; i++)
+        {
+          struct GNUNET_SET_Element element;
+          struct ConsensusStuffedElement se = { 0 };
+          element.data = &se;
+          element.size = sizeof (struct ConsensusStuffedElement);
+          element.element_type = GNUNET_BLOCK_TYPE_CONSENSUS_ELEMENT;
+
+          if (EVILNESS_SUB_REPLACEMENT == evil.subtype)
+          {
+            /* Always generate a new element. */
+            GNUNET_CRYPTO_hash_create_random (GNUNET_CRYPTO_QUALITY_WEAK, &se.rand);
+          }
+          else if (EVILNESS_SUB_NO_REPLACEMENT == evil.subtype)
+          {
+            /* Always cram the same elements, derived from counter. */
+            GNUNET_CRYPTO_hash (&i, sizeof (i), &se.rand);
+          }
+          else
+          {
+            GNUNET_assert (0);
+          }
+          GNUNET_SET_add_element (set->h, &element, NULL, NULL);
+#ifdef GNUNET_EXTRA_LOGGING
+          GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                      "P%u: evil peer: cramming element %s into set {%s} of task {%s}\n",
+                      session->local_peer_idx,
+                      debug_str_element (&element),
+                      debug_str_set_key (&setop->input_set),
+                      debug_str_task_key (&task->key));
+#endif
+        }
+        GNUNET_STATISTICS_update (statistics,
+                                  "# stuffed elements",
+                                  evil.num,
+                                  GNUNET_NO);
+        GNUNET_SET_commit (setop->op, set->h);
+        break;
+      case EVILNESS_SLACK:
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: evil peer: slacking\n",
+                    (unsigned int) session->local_peer_idx);
+        /* Do nothing. */
+      case EVILNESS_SLACK_A2A:
+        if ( (PHASE_KIND_ALL_TO_ALL_2 == task->key.kind ) ||
+             (PHASE_KIND_ALL_TO_ALL == task->key.kind) )
+        {
+          struct GNUNET_SET_Handle *empty_set;
+          empty_set = GNUNET_SET_create (cfg, GNUNET_SET_OPERATION_UNION);
+          GNUNET_SET_commit (setop->op, empty_set);
+          GNUNET_SET_destroy (empty_set);
+        }
+        else
+        {
+          GNUNET_SET_commit (setop->op, set->h);
+        }
+        break;
+      case EVILNESS_NONE:
+        GNUNET_SET_commit (setop->op, set->h);
+        break;
+    }
+  }
+#else
+  if (GNUNET_NO == session->peers_blacklisted[task_other_peer (task)])
+  {
+    GNUNET_SET_commit (setop->op, set->h);
+  }
+  else
+  {
+    /* For our testcases, we don't want the blacklisted
+       peers to wait. */
+    GNUNET_SET_operation_cancel (setop->op);
+    setop->op = NULL;
   }
+#endif
+}
+
+
+static void
+put_diff (struct ConsensusSession *session,
+         struct DiffEntry *diff)
+{
+  struct GNUNET_HashCode hash;
+
+  GNUNET_assert (NULL != diff);
 
-  msg_size = ntohs (qmsg->msg->size);
+  GNUNET_CRYPTO_hash (&diff->key, sizeof (struct DiffKey), &hash);
+  GNUNET_assert (GNUNET_OK ==
+                 GNUNET_CONTAINER_multihashmap_put (session->diffmap, &hash, diff,
+                                                    GNUNET_CONTAINER_MULTIHASHMAPOPTION_UNIQUE_ONLY));
+}
 
-  GNUNET_assert (size >= msg_size);
+static void
+put_set (struct ConsensusSession *session,
+         struct SetEntry *set)
+{
+  struct GNUNET_HashCode hash;
 
-  memcpy (buf, qmsg->msg, msg_size);
-  GNUNET_free (qmsg->msg);
-  GNUNET_free (qmsg);
+  GNUNET_assert (NULL != set->h);
 
-  send_next (session);
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Putting set %s\n",
+              debug_str_set_key (&set->key));
 
-  return msg_size;
+  GNUNET_CRYPTO_hash (&set->key, sizeof (struct SetKey), &hash);
+  GNUNET_assert (GNUNET_SYSERR !=
+                 GNUNET_CONTAINER_multihashmap_put (session->setmap, &hash, set,
+                                                    GNUNET_CONTAINER_MULTIHASHMAPOPTION_REPLACE));
 }
 
 
-/**
- * Schedule sending the next message (if there is any) to a client.
+static void
+put_rfn (struct ConsensusSession *session,
+         struct ReferendumEntry *rfn)
+{
+  struct GNUNET_HashCode hash;
+
+  GNUNET_CRYPTO_hash (&rfn->key, sizeof (struct RfnKey), &hash);
+  GNUNET_assert (GNUNET_OK ==
+                 GNUNET_CONTAINER_multihashmap_put (session->rfnmap, &hash, rfn,
+                                                    GNUNET_CONTAINER_MULTIHASHMAPOPTION_UNIQUE_ONLY));
+}
+
+
+
+static void
+task_cancel_reconcile (struct TaskEntry *task)
+{
+  /* not implemented yet */
+  GNUNET_assert (0);
+}
+
+
+static void
+apply_diff_to_rfn (struct DiffEntry *diff,
+                   struct ReferendumEntry *rfn,
+                   uint16_t voting_peer,
+                   uint16_t num_peers)
+{
+  struct GNUNET_CONTAINER_MultiHashMapIterator *iter;
+  struct DiffElementInfo *di;
+
+  iter = GNUNET_CONTAINER_multihashmap_iterator_create (diff->changes);
+
+  while (GNUNET_YES ==
+         GNUNET_CONTAINER_multihashmap_iterator_next (iter,
+                                                      NULL,
+                                                      (const void **) &di))
+  {
+    if (di->weight > 0)
+    {
+      rfn_vote (rfn, voting_peer, VOTE_ADD, di->element);
+    }
+    if (di->weight < 0)
+    {
+      rfn_vote (rfn, voting_peer, VOTE_REMOVE, di->element);
+    }
+  }
+
+  GNUNET_CONTAINER_multihashmap_iterator_destroy (iter);
+}
+
+
+struct DiffEntry *
+diff_create ()
+{
+  struct DiffEntry *d = GNUNET_new (struct DiffEntry);
+
+  d->changes = GNUNET_CONTAINER_multihashmap_create (8, GNUNET_NO);
+
+  return d;
+}
+
+
+struct DiffEntry *
+diff_compose (struct DiffEntry *diff_1,
+              struct DiffEntry *diff_2)
+{
+  struct DiffEntry *diff_new;
+  struct GNUNET_CONTAINER_MultiHashMapIterator *iter;
+  struct DiffElementInfo *di;
+
+  diff_new = diff_create ();
+
+  iter = GNUNET_CONTAINER_multihashmap_iterator_create (diff_1->changes);
+  while (GNUNET_YES == GNUNET_CONTAINER_multihashmap_iterator_next (iter, NULL, (const void **) &di))
+  {
+    diff_insert (diff_new, di->weight, di->element);
+  }
+  GNUNET_CONTAINER_multihashmap_iterator_destroy (iter);
+
+  iter = GNUNET_CONTAINER_multihashmap_iterator_create (diff_2->changes);
+  while (GNUNET_YES == GNUNET_CONTAINER_multihashmap_iterator_next (iter, NULL, (const void **) &di))
+  {
+    diff_insert (diff_new, di->weight, di->element);
+  }
+  GNUNET_CONTAINER_multihashmap_iterator_destroy (iter);
+
+  return diff_new;
+}
+
+
+struct ReferendumEntry *
+rfn_create (uint16_t size)
+{
+  struct ReferendumEntry *rfn;
+
+  rfn = GNUNET_new (struct ReferendumEntry);
+  rfn->rfn_elements = GNUNET_CONTAINER_multihashmap_create (8, GNUNET_NO);
+  rfn->peer_commited = GNUNET_new_array (size, int);
+  rfn->peer_contested = GNUNET_new_array (size, int);
+  rfn->num_peers = size;
+
+  return rfn;
+}
+
+
+#if UNUSED
+static void
+diff_destroy (struct DiffEntry *diff)
+{
+  GNUNET_CONTAINER_multihashmap_destroy (diff->changes);
+  GNUNET_free (diff);
+}
+#endif
+
+
+/**
+ * For a given majority, count what the outcome
+ * is (add/remove/keep), and give the number
+ * of peers that voted for this outcome.
+ */
+static void
+rfn_majority (const struct ReferendumEntry *rfn,
+              const struct RfnElementInfo *ri,
+              uint16_t *ret_majority,
+              enum ReferendumVote *ret_vote)
+{
+  uint16_t votes_yes = 0;
+  uint16_t num_commited = 0;
+  uint16_t i;
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Computing rfn majority for element %s of rfn {%s}\n",
+              debug_str_element (ri->element),
+              debug_str_rfn_key (&rfn->key));
+
+  for (i = 0; i < rfn->num_peers; i++)
+  {
+    if (GNUNET_NO == rfn->peer_commited[i])
+      continue;
+    num_commited++;
+
+    if (GNUNET_YES == ri->votes[i])
+      votes_yes++;
+  }
+
+  if (votes_yes > (num_commited) / 2)
+  {
+    *ret_vote = ri->proposal;
+    *ret_majority = votes_yes;
+  }
+  else
+  {
+    *ret_vote = VOTE_STAY;
+    *ret_majority = num_commited - votes_yes;
+  }
+}
+
+
+struct SetCopyCls
+{
+  struct TaskEntry *task;
+  struct SetKey dst_set_key;
+};
+
+
+static void
+set_copy_cb (void *cls, struct GNUNET_SET_Handle *copy)
+{
+  struct SetCopyCls *scc = cls;
+  struct TaskEntry *task = scc->task;
+  struct SetKey dst_set_key = scc->dst_set_key;
+  struct SetEntry *set;
+
+  GNUNET_free (scc);
+  set = GNUNET_new (struct SetEntry);
+  set->h = copy;
+  set->key = dst_set_key;
+  put_set (task->step->session, set);
+
+  task->start (task);
+}
+
+
+/**
+ * Call the start function of the given
+ * task again after we created a copy of the given set.
+ */
+static void
+create_set_copy_for_task (struct TaskEntry *task,
+                          struct SetKey *src_set_key,
+                          struct SetKey *dst_set_key)
+{
+  struct SetEntry *src_set;
+  struct SetCopyCls *scc = GNUNET_new (struct SetCopyCls);
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Copying set {%s} to {%s} for task {%s}\n",
+              debug_str_set_key (src_set_key),
+              debug_str_set_key (dst_set_key),
+              debug_str_task_key (&task->key));
+
+  scc->task = task;
+  scc->dst_set_key = *dst_set_key;
+  src_set = lookup_set (task->step->session, src_set_key);
+  GNUNET_assert (NULL != src_set);
+  GNUNET_SET_copy_lazy (src_set->h,
+                        set_copy_cb,
+                        scc);
+}
+
+
+struct SetMutationProgressCls
+{
+  int num_pending;
+  /**
+   * Task to finish once all changes are through.
+   */
+  struct TaskEntry *task;
+};
+
+
+static void
+set_mutation_done (void *cls)
+{
+  struct SetMutationProgressCls *pc = cls;
+
+  GNUNET_assert (pc->num_pending > 0);
+
+  pc->num_pending--;
+
+  if (0 == pc->num_pending)
+  {
+    struct TaskEntry *task = pc->task;
+    GNUNET_free (pc);
+    finish_task (task);
+  }
+}
+
+
+static void
+try_finish_step_early (struct Step *step)
+{
+  unsigned int i;
+
+  if (GNUNET_YES == step->is_running)
+    return;
+  if (GNUNET_YES == step->is_finished)
+    return;
+  if (GNUNET_NO == step->early_finishable)
+    return;
+
+  step->is_finished = GNUNET_YES;
+
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Finishing step `%s' early.\n",
+              step->debug_name);
+#endif
+
+  for (i = 0; i < step->subordinates_len; i++)
+  {
+    GNUNET_assert (step->subordinates[i]->pending_prereq > 0);
+    step->subordinates[i]->pending_prereq--;
+#ifdef GNUNET_EXTRA_LOGGING
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "Decreased pending_prereq to %u for step `%s'.\n",
+                (unsigned int) step->subordinates[i]->pending_prereq,
+                step->subordinates[i]->debug_name);
+
+#endif
+    try_finish_step_early (step->subordinates[i]);
+  }
+
+  // XXX: maybe schedule as task to avoid recursion?
+  run_ready_steps (step->session);
+}
+
+
+static void
+finish_step (struct Step *step)
+{
+  unsigned int i;
+
+  GNUNET_assert (step->finished_tasks == step->tasks_len);
+  GNUNET_assert (GNUNET_YES == step->is_running);
+  GNUNET_assert (GNUNET_NO == step->is_finished);
+
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "All tasks of step `%s' with %u subordinates finished.\n",
+              step->debug_name,
+              step->subordinates_len);
+#endif
+
+  for (i = 0; i < step->subordinates_len; i++)
+  {
+    GNUNET_assert (step->subordinates[i]->pending_prereq > 0);
+    step->subordinates[i]->pending_prereq--;
+#ifdef GNUNET_EXTRA_LOGGING
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "Decreased pending_prereq to %u for step `%s'.\n",
+                (unsigned int) step->subordinates[i]->pending_prereq,
+                step->subordinates[i]->debug_name);
+
+#endif
+  }
+
+  step->is_finished = GNUNET_YES;
+
+  // XXX: maybe schedule as task to avoid recursion?
+  run_ready_steps (step->session);
+}
+
+
+
+/**
+ * Apply the result from one round of gradecasts (i.e. every peer
+ * should have gradecasted) to the peer's current set.
+ *
+ * @param task the task with context information
+ */
+static void
+task_start_apply_round (struct TaskEntry *task)
+{
+  struct ConsensusSession *session = task->step->session;
+  struct SetKey sk_in;
+  struct SetKey sk_out;
+  struct RfnKey rk_in;
+  struct SetEntry *set_out;
+  struct ReferendumEntry *rfn_in;
+  struct GNUNET_CONTAINER_MultiHashMapIterator *iter;
+  struct RfnElementInfo *ri;
+  struct SetMutationProgressCls *progress_cls;
+  uint16_t worst_majority = UINT16_MAX;
+
+  sk_in = (struct SetKey) { SET_KIND_CURRENT, task->key.repetition };
+  rk_in = (struct RfnKey) { RFN_KIND_GRADECAST_RESULT, task->key.repetition };
+  sk_out = (struct SetKey) { SET_KIND_CURRENT, task->key.repetition + 1 };
+
+  set_out = lookup_set (session, &sk_out);
+  if (NULL == set_out)
+  {
+    create_set_copy_for_task (task, &sk_in, &sk_out);
+    return;
+  }
+
+  rfn_in = lookup_rfn (session, &rk_in);
+  GNUNET_assert (NULL != rfn_in);
+
+  progress_cls = GNUNET_new (struct SetMutationProgressCls);
+  progress_cls->task = task;
+
+  iter = GNUNET_CONTAINER_multihashmap_iterator_create (rfn_in->rfn_elements);
+
+  while (GNUNET_YES ==
+         GNUNET_CONTAINER_multihashmap_iterator_next (iter,
+                                                      NULL,
+                                                      (const void **) &ri))
+  {
+    uint16_t majority_num;
+    enum ReferendumVote majority_vote;
+
+    rfn_majority (rfn_in, ri, &majority_num, &majority_vote);
+
+    if (worst_majority > majority_num)
+      worst_majority = majority_num;
+
+    switch (majority_vote)
+    {
+      case VOTE_ADD:
+        progress_cls->num_pending++;
+        GNUNET_assert (GNUNET_OK ==
+                       GNUNET_SET_add_element (set_out->h,
+                                               ri->element,
+                                               &set_mutation_done,
+                                               progress_cls));
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: apply round: adding element %s with %u-majority.\n",
+                    session->local_peer_idx,
+                    debug_str_element (ri->element), majority_num);
+        break;
+      case VOTE_REMOVE:
+        progress_cls->num_pending++;
+        GNUNET_assert (GNUNET_OK ==
+                       GNUNET_SET_remove_element (set_out->h,
+                                                  ri->element,
+                                                  &set_mutation_done,
+                                                  progress_cls));
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: apply round: deleting element %s with %u-majority.\n",
+                    session->local_peer_idx,
+                    debug_str_element (ri->element), majority_num);
+        break;
+      case VOTE_STAY:
+        GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                    "P%u: apply round: keeping element %s with %u-majority.\n",
+                    session->local_peer_idx,
+                    debug_str_element (ri->element), majority_num);
+        // do nothing
+        break;
+      default:
+        GNUNET_assert (0);
+        break;
+    }
+  }
+
+  if (0 == progress_cls->num_pending)
+  {
+    // call closure right now, no pending ops
+    GNUNET_free (progress_cls);
+    finish_task (task);
+  }
+
+  {
+    uint16_t thresh = (session->num_peers / 3) * 2;
+
+    if (worst_majority >= thresh)
+    {
+      switch (session->early_stopping)
+      {
+        case EARLY_STOPPING_NONE:
+          session->early_stopping = EARLY_STOPPING_ONE_MORE;
+          GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+                      "P%u: Stopping early (after one more superround)\n",
+                      session->local_peer_idx);
+          break;
+        case EARLY_STOPPING_ONE_MORE:
+          GNUNET_log (GNUNET_ERROR_TYPE_INFO, "P%u: finishing steps due to early finish\n",
+                      session->local_peer_idx);
+          session->early_stopping = EARLY_STOPPING_DONE;
+          {
+            struct Step *step;
+            for (step = session->steps_head; NULL != step; step = step->next)
+              try_finish_step_early (step);
+          }
+          break;
+        case EARLY_STOPPING_DONE:
+          /* We shouldn't be here anymore after early stopping */
+          GNUNET_break (0);
+          break;
+        default:
+          GNUNET_assert (0);
+          break;
+      }
+    }
+    else if (EARLY_STOPPING_NONE != session->early_stopping)
+    {
+      // Our assumption about the number of bad peers
+      // has been broken.
+      GNUNET_break_op (0);
+    }
+    else
+    {
+      GNUNET_log (GNUNET_ERROR_TYPE_INFO, "P%u: NOT finishing early (majority not good enough)\n",
+                  session->local_peer_idx);
+    }
+  }
+  GNUNET_CONTAINER_multihashmap_iterator_destroy (iter);
+}
+
+
+static void
+task_start_grade (struct TaskEntry *task)
+{
+  struct ConsensusSession *session = task->step->session;
+  struct ReferendumEntry *output_rfn;
+  struct ReferendumEntry *input_rfn;
+  struct DiffEntry *input_diff;
+  struct RfnKey rfn_key;
+  struct DiffKey diff_key;
+  struct GNUNET_CONTAINER_MultiHashMapIterator *iter;
+  struct RfnElementInfo *ri;
+  unsigned int gradecast_confidence = 2;
+
+  rfn_key = (struct RfnKey) { RFN_KIND_GRADECAST_RESULT, task->key.repetition };
+  output_rfn = lookup_rfn (session, &rfn_key);
+  if (NULL == output_rfn)
+  {
+    output_rfn = rfn_create (session->num_peers);
+    output_rfn->key = rfn_key;
+    put_rfn (session, output_rfn);
+  }
+
+  diff_key = (struct DiffKey) { DIFF_KIND_LEADER_PROPOSAL, task->key.repetition, task->key.leader };
+  input_diff = lookup_diff (session, &diff_key);
+  GNUNET_assert (NULL != input_diff);
+
+  rfn_key = (struct RfnKey) { RFN_KIND_ECHO, task->key.repetition, task->key.leader };
+  input_rfn = lookup_rfn (session, &rfn_key);
+  GNUNET_assert (NULL != input_rfn);
+
+  iter = GNUNET_CONTAINER_multihashmap_iterator_create (input_rfn->rfn_elements);
+
+  apply_diff_to_rfn (input_diff, output_rfn, task->key.leader, session->num_peers);
+
+  while (GNUNET_YES ==
+         GNUNET_CONTAINER_multihashmap_iterator_next (iter,
+                                                      NULL,
+                                                      (const void **) &ri))
+  {
+    uint16_t majority_num;
+    enum ReferendumVote majority_vote;
+
+    // XXX: we need contested votes and non-contested votes here
+    rfn_majority (input_rfn, ri, &majority_num, &majority_vote);
+
+    if (majority_num <= session->num_peers / 3)
+      majority_vote = VOTE_REMOVE;
+
+    switch (majority_vote)
+    {
+      case VOTE_STAY:
+        break;
+      case VOTE_ADD:
+        rfn_vote (output_rfn, task->key.leader, VOTE_ADD, ri->element);
+        break;
+      case VOTE_REMOVE:
+        rfn_vote (output_rfn, task->key.leader, VOTE_REMOVE, ri->element);
+        break;
+      default:
+        GNUNET_assert (0);
+        break;
+    }
+  }
+  GNUNET_CONTAINER_multihashmap_iterator_destroy (iter);
+
+  {
+    uint16_t noncontested;
+    noncontested = rfn_noncontested (input_rfn);
+    if (noncontested < (session->num_peers / 3) * 2)
+    {
+      gradecast_confidence = GNUNET_MIN(1, gradecast_confidence);
+    }
+    if (noncontested < (session->num_peers / 3) + 1)
+    {
+      gradecast_confidence = 0;
+    }
+  }
+
+  if (gradecast_confidence >= 1)
+    rfn_commit (output_rfn, task->key.leader);
+
+  if (gradecast_confidence <= 1)
+    session->peers_blacklisted[task->key.leader] = GNUNET_YES;
+
+  finish_task (task);
+}
+
+
+static void
+task_start_reconcile (struct TaskEntry *task)
+{
+  struct SetEntry *input;
+  struct SetOpCls *setop = &task->cls.setop;
+  struct ConsensusSession *session = task->step->session;
+
+  input = lookup_set (session, &setop->input_set);
+  GNUNET_assert (NULL != input);
+  GNUNET_assert (NULL != input->h);
+
+  /* We create the outputs for the operation here
+     (rather than in the set operation callback)
+     because we want something valid in there, even
+     if the other peer doesn't talk to us */
+
+  if (SET_KIND_NONE != setop->output_set.set_kind)
+  {
+    /* If we don't have an existing output set,
+       we clone the input set. */
+    if (NULL == lookup_set (session, &setop->output_set))
+    {
+      create_set_copy_for_task (task, &setop->input_set, &setop->output_set);
+      return;
+    }
+  }
+
+  if (RFN_KIND_NONE != setop->output_rfn.rfn_kind)
+  {
+    if (NULL == lookup_rfn (session, &setop->output_rfn))
+    {
+      struct ReferendumEntry *rfn;
+
+      GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                  "P%u: output rfn <%s> missing, creating.\n",
+                  session->local_peer_idx,
+                  debug_str_rfn_key (&setop->output_rfn));
+
+      rfn = rfn_create (session->num_peers);
+      rfn->key = setop->output_rfn;
+      put_rfn (session, rfn);
+    }
+  }
+
+  if (DIFF_KIND_NONE != setop->output_diff.diff_kind)
+  {
+    if (NULL == lookup_diff (session, &setop->output_diff))
+    {
+      struct DiffEntry *diff;
+
+      diff = diff_create ();
+      diff->key = setop->output_diff;
+      put_diff (session, diff);
+    }
+  }
+
+  if ( (task->key.peer1 == session->local_peer_idx) && (task->key.peer2 == session->local_peer_idx) )
+  {
+    /* XXX: mark the corresponding rfn as commited if necessary */
+    finish_task (task);
+    return;
+  }
+
+  if (task->key.peer1 == session->local_peer_idx)
+  {
+    struct GNUNET_CONSENSUS_RoundContextMessage rcm = { 0 };
+
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "P%u: Looking up set {%s} to run remote union\n",
+                session->local_peer_idx,
+                debug_str_set_key (&setop->input_set));
+
+    rcm.header.type = htons (GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_ROUND_CONTEXT);
+    rcm.header.size = htons (sizeof (struct GNUNET_CONSENSUS_RoundContextMessage));
+
+    rcm.kind = htons (task->key.kind);
+    rcm.peer1 = htons (task->key.peer1);
+    rcm.peer2 = htons (task->key.peer2);
+    rcm.leader = htons (task->key.leader);
+    rcm.repetition = htons (task->key.repetition);
+
+    GNUNET_assert (NULL == setop->op);
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "P%u: initiating set op with P%u, our set is %s\n",
+                session->local_peer_idx, task->key.peer2, debug_str_set_key (&setop->input_set));
+
+    struct GNUNET_SET_Option opts[] = {
+      { GNUNET_SET_OPTION_BYZANTINE, { .num = session->lower_bound } },
+      { GNUNET_SET_OPTION_END },
+    };
+
+    // XXX: maybe this should be done while
+    // setting up tasks alreays?
+    setop->op = GNUNET_SET_prepare (&session->peers[task->key.peer2],
+                                    &session->global_id,
+                                    &rcm.header,
+                                    GNUNET_SET_RESULT_SYMMETRIC,
+                                    opts,
+                                    set_result_cb,
+                                    task);
+
+    commit_set (session, task);
+  }
+  else if (task->key.peer2 == session->local_peer_idx)
+  {
+    /* Wait for the other peer to contact us */
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "P%u: waiting set op with P%u\n",
+                session->local_peer_idx, task->key.peer1);
+
+    if (NULL != setop->op)
+    {
+      commit_set (session, task);
+    }
+  }
+  else
+  {
+    /* We made an error while constructing the task graph. */
+    GNUNET_assert (0);
+  }
+}
+
+
+static void
+task_start_eval_echo (struct TaskEntry *task)
+{
+  struct GNUNET_CONTAINER_MultiHashMapIterator *iter;
+  struct ReferendumEntry *input_rfn;
+  struct RfnElementInfo *ri;
+  struct SetEntry *output_set;
+  struct SetMutationProgressCls *progress_cls;
+  struct ConsensusSession *session = task->step->session;
+  struct SetKey sk_in;
+  struct SetKey sk_out;
+  struct RfnKey rk_in;
+
+  sk_in = (struct SetKey) { SET_KIND_LEADER_PROPOSAL, task->key.repetition, task->key.leader };
+  sk_out = (struct SetKey) { SET_KIND_ECHO_RESULT, task->key.repetition, task->key.leader };
+  output_set = lookup_set (session, &sk_out);
+  if (NULL == output_set)
+  {
+    create_set_copy_for_task (task, &sk_in, &sk_out);
+    return;
+  }
+
+
+  {
+    // FIXME: should be marked as a shallow copy, so
+    // we can destroy everything correctly
+    struct SetEntry *last_set = GNUNET_new (struct SetEntry);
+    last_set->h = output_set->h;
+    last_set->key = (struct SetKey) { SET_KIND_LAST_GRADECAST };
+    put_set (session, last_set);
+  }
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Evaluating referendum in Task {%s}\n",
+              debug_str_task_key (&task->key));
+
+  progress_cls = GNUNET_new (struct SetMutationProgressCls);
+  progress_cls->task = task;
+
+  rk_in = (struct RfnKey) { RFN_KIND_ECHO, task->key.repetition, task->key.leader };
+  input_rfn = lookup_rfn (session, &rk_in);
+
+  GNUNET_assert (NULL != input_rfn);
+
+  iter = GNUNET_CONTAINER_multihashmap_iterator_create (input_rfn->rfn_elements);
+  GNUNET_assert (NULL != iter);
+
+  while (GNUNET_YES ==
+         GNUNET_CONTAINER_multihashmap_iterator_next (iter,
+                                                      NULL,
+                                                      (const void **) &ri))
+  {
+    enum ReferendumVote majority_vote;
+    uint16_t majority_num;
+
+    rfn_majority (input_rfn, ri, &majority_num, &majority_vote);
+
+    if (majority_num < session->num_peers / 3)
+    {
+      /* It is not the case that all nonfaulty peers
+         echoed the same value.  Since we're doing a set reconciliation, we
+         can't simply send "nothing" for the value.  Thus we mark our 'confirm'
+         reconciliation as contested.  Other peers might not know that the
+         leader is faulty, thus we still re-distribute in the confirmation
+         round. */
+      output_set->is_contested = GNUNET_YES;
+    }
+
+    switch (majority_vote)
+    {
+      case VOTE_ADD:
+        progress_cls->num_pending++;
+        GNUNET_assert (GNUNET_OK ==
+                       GNUNET_SET_add_element (output_set->h,
+                                               ri->element,
+                                               set_mutation_done,
+                                               progress_cls));
+        break;
+      case VOTE_REMOVE:
+        progress_cls->num_pending++;
+        GNUNET_assert (GNUNET_OK ==
+                       GNUNET_SET_remove_element (output_set->h,
+                                                  ri->element,
+                                                  set_mutation_done,
+                                                  progress_cls));
+        break;
+      case VOTE_STAY:
+        /* Nothing to do. */
+        break;
+      default:
+        /* not reached */
+        GNUNET_assert (0);
+    }
+  }
+
+  GNUNET_CONTAINER_multihashmap_iterator_destroy (iter);
+
+  if (0 == progress_cls->num_pending)
+  {
+    // call closure right now, no pending ops
+    GNUNET_free (progress_cls);
+    finish_task (task);
+  }
+}
+
+
+static void
+task_start_finish (struct TaskEntry *task)
+{
+  struct SetEntry *final_set;
+  struct ConsensusSession *session = task->step->session;
+
+  final_set = lookup_set (session, &task->cls.finish.input_set);
+
+  GNUNET_assert (NULL != final_set);
+
+
+  GNUNET_SET_iterate (final_set->h,
+                      send_to_client_iter,
+                      task);
+}
+
+static void
+start_task (struct ConsensusSession *session, struct TaskEntry *task)
+{
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "P%u: starting task {%s}\n", session->local_peer_idx, debug_str_task_key (&task->key));
+
+  GNUNET_assert (GNUNET_NO == task->is_started);
+  GNUNET_assert (GNUNET_NO == task->is_finished);
+  GNUNET_assert (NULL != task->start);
+
+  task->start (task);
+
+  task->is_started = GNUNET_YES;
+}
+
+
+
+
+/*
+ * Run all steps of the session that don't any
+ * more dependencies.
+ */
+static void
+run_ready_steps (struct ConsensusSession *session)
+{
+  struct Step *step;
+
+  step = session->steps_head;
+
+  while (NULL != step)
+  {
+    if ( (GNUNET_NO == step->is_running) && (0 == step->pending_prereq) && (GNUNET_NO == step->is_finished) )
+    {
+      size_t i;
+
+      GNUNET_assert (0 == step->finished_tasks);
+
+#ifdef GNUNET_EXTRA_LOGGING
+      GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "P%u: Running step `%s' of round %d with %d tasks and %d subordinates\n",
+                  session->local_peer_idx,
+                  step->debug_name,
+                  step->round, step->tasks_len, step->subordinates_len);
+#endif
+
+      step->is_running = GNUNET_YES;
+      for (i = 0; i < step->tasks_len; i++)
+        start_task (session, step->tasks[i]);
+
+      /* Sometimes there is no task to trigger finishing the step, so we have to do it here. */
+      if ( (step->finished_tasks == step->tasks_len) && (GNUNET_NO == step->is_finished))
+        finish_step (step);
+
+      /* Running the next ready steps will be triggered by task completion */
+      return;
+    }
+    step = step->next;
+  }
+
+  return;
+}
+
+
+
+static void
+finish_task (struct TaskEntry *task)
+{
+  GNUNET_assert (GNUNET_NO == task->is_finished);
+  task->is_finished = GNUNET_YES;
+
+  task->step->finished_tasks++;
+
+  if (task->step->finished_tasks == task->step->tasks_len)
+    finish_step (task->step);
+}
+
+
+/**
+ * Search peer in the list of peers in session.
+ *
+ * @param peer peer to find
+ * @param session session with peer
+ * @return index of peer, -1 if peer is not in session
+ */
+static int
+get_peer_idx (const struct GNUNET_PeerIdentity *peer, const struct ConsensusSession *session)
+{
+  int i;
+  for (i = 0; i < session->num_peers; i++)
+    if (0 == memcmp (peer, &session->peers[i], sizeof (struct GNUNET_PeerIdentity)))
+      return i;
+  return -1;
+}
+
+
+/**
+ * Compute a global, (hopefully) unique consensus session id,
+ * from the local id of the consensus session, and the identities of all participants.
+ * Thus, if the local id of two consensus sessions coincide, but are not comprised of
+ * exactly the same peers, the global id will be different.
  *
- * @param cli the client to send the next message to
+ * @param session session to generate the global id for
+ * @param local_session_id local id of the consensus session
  */
 static void
-send_next (struct ConsensusSession *session)
+compute_global_id (struct ConsensusSession *session,
+                  const struct GNUNET_HashCode *local_session_id)
 {
-
-  GNUNET_assert (NULL != session);
-
-  if (NULL != session->th)
-    return;
-
-  if (NULL != session->client_messages_head)
-  {
-    int msize;
-    msize = ntohs (session->client_messages_head->msg->size);
-    GNUNET_log (GNUNET_ERROR_TYPE_INFO, "scheduling queued\n");
-    session->th = GNUNET_SERVER_notify_transmit_ready (session->client, msize, 
-                                                       GNUNET_TIME_UNIT_FOREVER_REL,
-                                                       &transmit_queued, session);
-  }
+  const char *salt = "gnunet-service-consensus/session_id";
+
+  GNUNET_assert (GNUNET_YES ==
+                 GNUNET_CRYPTO_kdf (&session->global_id,
+                                    sizeof (struct GNUNET_HashCode),
+                                    salt,
+                                    strlen (salt),
+                                    session->peers,
+                                    session->num_peers * sizeof (struct GNUNET_PeerIdentity),
+                                    local_session_id,
+                                    sizeof (struct GNUNET_HashCode),
+                                    NULL));
 }
 
 
 /**
- * Although GNUNET_CRYPTO_hash_cmp exisits, it does not have
- * the correct signature to be used with e.g. qsort.
- * We use this function instead.
+ * Compare two peer identities.
  *
- * @param h1 some hash code
- * @param h2 some hash code
+ * @param h1 some peer identity
+ * @param h2 some peer identity
  * @return 1 if h1 > h2, -1 if h1 < h2 and 0 if h1 == h2.
  */
 static int
-hash_cmp (const void *a, const void *b)
+peer_id_cmp (const void *h1, const void *h2)
 {
-  return GNUNET_CRYPTO_hash_cmp ((struct GNUNET_HashCode *) a, (struct GNUNET_HashCode *) b);
+  return memcmp (h1, h2, sizeof (struct GNUNET_PeerIdentity));
 }
 
 
 /**
- * Search peer in the list of peers in session.
+ * Create the sorted list of peers for the session,
+ * add the local peer if not in the join message.
  *
- * @param peer peer to find
- * @param session session with peer
- * @return index of peer, -1 if peer is not in session
+ * @param session session to initialize
+ * @param join_msg join message with the list of peers participating at the end
  */
-static int
-get_peer_idx (const struct GNUNET_PeerIdentity *peer, const struct ConsensusSession *session)
+static void
+initialize_session_peer_list (struct ConsensusSession *session,
+                              const struct GNUNET_CONSENSUS_JoinMessage *join_msg)
 {
-  const struct GNUNET_PeerIdentity *needle;
-  needle = bsearch (peer, session->peers, session->num_peers, sizeof (struct GNUNET_PeerIdentity), &hash_cmp);
-  if (NULL == needle)
-    return -1;
-  return needle - session->peers;
-}
+  const struct GNUNET_PeerIdentity *msg_peers
+    = (const struct GNUNET_PeerIdentity *) &join_msg[1];
+  int local_peer_in_list;
 
+  session->num_peers = ntohl (join_msg->num_peers);
 
+  /* Peers in the join message, may or may not include the local peer,
+     Add it if it is missing. */
+  local_peer_in_list = GNUNET_NO;
+  for (unsigned int i = 0; i < session->num_peers; i++)
+  {
+    if (0 == memcmp (&msg_peers[i],
+                     &my_peer,
+                     sizeof (struct GNUNET_PeerIdentity)))
+    {
+      local_peer_in_list = GNUNET_YES;
+      break;
+    }
+  }
+  if (GNUNET_NO == local_peer_in_list)
+    session->num_peers++;
 
-static void
-hello_cont (void *cls, enum GNUNET_STREAM_Status status, size_t size)
-{
-  struct ConsensusPeerInformation *cpi;
+  session->peers = GNUNET_new_array (session->num_peers,
+                                     struct GNUNET_PeerIdentity);
+  if (GNUNET_NO == local_peer_in_list)
+    session->peers[session->num_peers - 1] = my_peer;
+
+  GNUNET_memcpy (session->peers,
+                 msg_peers,
+                 ntohl (join_msg->num_peers) * sizeof (struct GNUNET_PeerIdentity));
+  qsort (session->peers,
+         session->num_peers,
+         sizeof (struct GNUNET_PeerIdentity),
+         &peer_id_cmp);
+}
 
-  cpi = (struct ConsensusPeerInformation *) cls;
-  cpi->hello = GNUNET_YES;
-  
-  GNUNET_assert (GNUNET_STREAM_OK == status);
 
-  cpi = (struct ConsensusPeerInformation *) cls;
+static struct TaskEntry *
+lookup_task (struct ConsensusSession *session,
+             struct TaskKey *key)
+{
+  struct GNUNET_HashCode hash;
 
-  if (cpi->session->conclude_requested)
-  {
-    write_strata (cpi, GNUNET_STREAM_OK, 0);  
-  }
+
+  GNUNET_CRYPTO_hash (key, sizeof (struct TaskKey), &hash);
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "Looking up task hash %s\n",
+              GNUNET_h2s (&hash));
+  return GNUNET_CONTAINER_multihashmap_get (session->taskmap, &hash);
 }
 
 
 /**
- * Functions of this type will be called when a stream is established
+ * Called when another peer wants to do a set operation with the
+ * local peer.
  *
- * @param cls the closure from GNUNET_STREAM_open
- * @param socket socket to use to communicate with the other side (read/write)
+ * @param cls closure
+ * @param other_peer the other peer
+ * @param context_msg message with application specific information from
+ *        the other peer
+ * @param request request from the other peer, use GNUNET_SET_accept
+ *        to accept it, otherwise the request will be refused
+ *        Note that we don't use a return value here, as it is also
+ *        necessary to specify the set we want to do the operation with,
+ *        whith sometimes can be derived from the context message.
+ *        Also necessary to specify the timeout.
  */
 static void
-open_cb (void *cls, struct GNUNET_STREAM_Socket *socket)
+set_listen_cb (void *cls,
+               const struct GNUNET_PeerIdentity *other_peer,
+               const struct GNUNET_MessageHeader *context_msg,
+               struct GNUNET_SET_Request *request)
 {
-  struct ConsensusPeerInformation *cpi;
-  struct ConsensusHello *hello;
+  struct ConsensusSession *session = cls;
+  struct TaskKey tk;
+  struct TaskEntry *task;
+  struct GNUNET_CONSENSUS_RoundContextMessage *cm;
 
+  if (NULL == context_msg)
+  {
+    GNUNET_break_op (0);
+    return;
+  }
 
-  cpi = (struct ConsensusPeerInformation *) cls;
-  cpi->is_connected = GNUNET_YES;
-
-  hello = GNUNET_malloc (sizeof *hello);
-  hello->header.size = htons (sizeof *hello);
-  hello->header.type = htons (GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_HELLO);
-  memcpy (&hello->global_id, &cpi->session->global_id, sizeof (struct GNUNET_HashCode));
+  if (GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_ROUND_CONTEXT != ntohs (context_msg->type))
+  {
+    GNUNET_break_op (0);
+    return;
+  }
 
+  if (sizeof (struct GNUNET_CONSENSUS_RoundContextMessage) != ntohs (context_msg->size))
+  {
+    GNUNET_break_op (0);
+    return;
+  }
 
-  cpi->wh =
-      GNUNET_STREAM_write (socket, hello, sizeof *hello, GNUNET_TIME_UNIT_FOREVER_REL, hello_cont, cpi);
+  cm = (struct GNUNET_CONSENSUS_RoundContextMessage *) context_msg;
 
-}
+  tk = ((struct TaskKey) {
+      .kind = ntohs (cm->kind),
+      .peer1 = ntohs (cm->peer1),
+      .peer2 = ntohs (cm->peer2),
+      .repetition = ntohs (cm->repetition),
+      .leader = ntohs (cm->leader),
+  });
 
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "P%u: got req for task %s\n",
+              session->local_peer_idx, debug_str_task_key (&tk));
 
-static void
-initialize_session_info (struct ConsensusSession *session)
-{
-  int i;
-  int last;
+  task = lookup_task (session, &tk);
 
-  for (i = 0; i < session->num_peers; ++i)
+  if (NULL == task)
   {
-    /* initialize back-references, so consensus peer information can
-     * be used as closure */
-    session->info[i].session = session;
+    GNUNET_break_op (0);
+    return;
+  }
 
+  if (GNUNET_YES == task->is_finished)
+  {
+    GNUNET_break_op (0);
+    return;
   }
 
-  last = (session->local_peer_idx + (session->num_peers / 2)) % session->num_peers;
-  i = (session->local_peer_idx + 1) % session->num_peers;
-  while (i != last)
+  if (task->key.peer2 != session->local_peer_idx)
   {
-    session->info[i].is_outgoing = GNUNET_YES;
-    session->info[i].socket = GNUNET_STREAM_open (cfg, &session->peers[i], GNUNET_APPLICATION_TYPE_CONSENSUS,
-                                                  open_cb, &session->info[i], GNUNET_STREAM_OPTION_END);
-    session->info[i].mst = GNUNET_SERVER_mst_create (mst_session_callback, session);
-    i = (i + 1) % session->num_peers;
+    /* We're being asked, so we must be thne 2nd peer. */
+    GNUNET_break_op (0);
+    return;
   }
-  // tie-breaker for even number of peers
-  if (((session->num_peers % 2) == 0) && (session->local_peer_idx < last))
+
+  GNUNET_assert (! ((task->key.peer1 == session->local_peer_idx) &&
+                    (task->key.peer2 == session->local_peer_idx)));
+
+  struct GNUNET_SET_Option opts[] = {
+    { GNUNET_SET_OPTION_BYZANTINE, { .num = session->lower_bound } },
+    { GNUNET_SET_OPTION_END },
+  };
+
+  task->cls.setop.op = GNUNET_SET_accept (request,
+                                          GNUNET_SET_RESULT_SYMMETRIC,
+                                          opts,
+                                          set_result_cb,
+                                          task);
+
+  /* If the task hasn't been started yet,
+     we wait for that until we commit. */
+
+  if (GNUNET_YES == task->is_started)
   {
-    session->info[last].is_outgoing = GNUNET_YES;
-    session->info[last].socket = GNUNET_STREAM_open (cfg, &session->peers[last], GNUNET_APPLICATION_TYPE_CONSENSUS,
-                                                     open_cb, &session->info[last], GNUNET_STREAM_OPTION_END);
+    commit_set (session, task);
   }
 }
 
 
-/**
- * Create the sorted list of peers for the session,
- * add the local peer if not in the join message.
- */
+
 static void
-initialize_session_peer_list (struct ConsensusSession *session)
+put_task (struct GNUNET_CONTAINER_MultiHashMap *taskmap,
+          struct TaskEntry *t)
 {
-  int local_peer_in_list;
-  int listed_peers;
-  const struct GNUNET_PeerIdentity *msg_peers;
-  unsigned int i;
+  struct GNUNET_HashCode round_hash;
+  struct Step *s;
 
-  GNUNET_assert (NULL != session->join_msg);
+  GNUNET_assert (NULL != t->step);
 
-  /* peers in the join message, may or may not include the local peer */
-  listed_peers = ntohs (session->join_msg->num_peers);
-  
-  session->num_peers = listed_peers;
+  t = GNUNET_memdup (t, sizeof (struct TaskEntry));
 
-  msg_peers = (struct GNUNET_PeerIdentity *) &session->join_msg[1];
+  s = t->step;
 
-  local_peer_in_list = GNUNET_NO;
-  for (i = 0; i < listed_peers; i++)
+  if (s->tasks_len == s->tasks_cap)
   {
-    if (0 == memcmp (&msg_peers[i], my_peer, sizeof (struct GNUNET_PeerIdentity)))
-    {
-      local_peer_in_list = GNUNET_YES;
-      break;
-    }
+    unsigned int target_size = 3 * (s->tasks_cap + 1) / 2;
+    GNUNET_array_grow (s->tasks,
+                       s->tasks_cap,
+                       target_size);
   }
 
-  if (GNUNET_NO == local_peer_in_list)
-    session->num_peers++;
-
-  session->peers = GNUNET_malloc (session->num_peers * sizeof (struct GNUNET_PeerIdentity));
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_assert (NULL != s->debug_name);
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "Putting task <%s> into step `%s'\n",
+              debug_str_task_key (&t->key),
+              s->debug_name);
+#endif
 
-  if (GNUNET_NO == local_peer_in_list)
-    session->peers[session->num_peers - 1] = *my_peer;
+  s->tasks[s->tasks_len] = t;
+  s->tasks_len++;
 
-  memcpy (session->peers, msg_peers, listed_peers * sizeof (struct GNUNET_PeerIdentity));
-  qsort (session->peers, session->num_peers, sizeof (struct GNUNET_PeerIdentity), &hash_cmp);
+  GNUNET_CRYPTO_hash (&t->key, sizeof (struct TaskKey), &round_hash);
+  GNUNET_assert (GNUNET_OK ==
+      GNUNET_CONTAINER_multihashmap_put (taskmap, &round_hash, t,
+                                         GNUNET_CONTAINER_MULTIHASHMAPOPTION_UNIQUE_ONLY));
 }
 
 
 static void
-strata_insert (struct InvertibleBloomFilter **strata, struct GNUNET_HashCode *key)
+install_step_timeouts (struct ConsensusSession *session)
 {
-  uint32_t v;
-  int i;
-  v = key->bits[0];
-  /* count trailing '1'-bits of v */
-  for (i = 0; v & 1; v>>=1, i++);
+  /* Given the fully constructed task graph
+     with rounds for tasks, we can give the tasks timeouts. */
 
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "strata insert at %d\n", i);
+  // unsigned int max_round;
 
-  ibf_insert (strata[i], key);
+  /* XXX: implement! */
 }
 
 
-/**
- * Initialize the session, continue receiving messages from the owning client
- *
- * @param session the session to initialize
+
+/*
+ * Arrange two peers in some canonical order.
  */
 static void
-initialize_session (struct ConsensusSession *session)
+arrange_peers (uint16_t *p1, uint16_t *p2, uint16_t n)
 {
-  const struct ConsensusSession *other_session;
-  int i;
-
-  GNUNET_assert (NULL != session->join_msg);
-
-  initialize_session_peer_list (session);
-
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "session with %u peers\n", session->num_peers);
+  uint16_t a;
+  uint16_t b;
 
-  compute_global_id (&session->join_msg->session_id, session->peers, session->num_peers, &session->global_id);
+  GNUNET_assert (*p1 < n);
+  GNUNET_assert (*p2 < n);
 
-  /* Check if some local client already owns the session. */
-  other_session = sessions_head;
-  while (NULL != other_session)
+  if (*p1 < *p2)
   {
-    if ((other_session != session) && 
-        (0 == GNUNET_CRYPTO_hash_cmp (&session->global_id, &other_session->global_id)))
-    {
-      /* session already owned by another client */
-      GNUNET_break (0);
-      disconnect_client (session->client);
-      return;
-    }
-    other_session = other_session->next;
+    a = *p1;
+    b = *p2;
+  }
+  else
+  {
+    a = *p2;
+    b = *p1;
   }
 
-  session->values = GNUNET_CONTAINER_multihashmap_create (256, GNUNET_NO);
+  /* For uniformly random *p1, *p2,
+     this condition is true with 50% chance */
+  if (((b - a) + n) % n <= n / 2)
+  {
+    *p1 = a;
+    *p2 = b;
+  }
+  else
+  {
+    *p1 = b;
+    *p2 = a;
+  }
+}
 
-  session->local_peer_idx = get_peer_idx (my_peer, session);
-  GNUNET_assert (-1 != session->local_peer_idx);
 
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "%d is the local peer\n", session->local_peer_idx);
+/**
+ * Record @a dep as a dependency of @a step.
+ */
+static void
+step_depend_on (struct Step *step, struct Step *dep)
+{
+  /* We're not checking for cyclic dependencies,
+     but this is a cheap sanity check. */
+  GNUNET_assert (step != dep);
+  GNUNET_assert (NULL != step);
+  GNUNET_assert (NULL != dep);
+  GNUNET_assert (dep->round <= step->round);
+
+#ifdef GNUNET_EXTRA_LOGGING
+  /* Make sure we have complete debugging information.
+     Also checks that we don't screw up too badly
+     constructing the task graph. */
+  GNUNET_assert (NULL != step->debug_name);
+  GNUNET_assert (NULL != dep->debug_name);
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Making step `%s' depend on `%s'\n",
+              step->debug_name,
+              dep->debug_name);
+#endif
+
+  if (dep->subordinates_cap == dep->subordinates_len)
+  {
+    unsigned int target_size = 3 * (dep->subordinates_cap + 1) / 2;
+    GNUNET_array_grow (dep->subordinates,
+                       dep->subordinates_cap,
+                       target_size);
+  }
 
-  session->strata = GNUNET_malloc (STRATA_COUNT * sizeof (struct InvertibleBloomFilter *));
-  for (i = 0; i < STRATA_COUNT; i++)
-    session->strata[i] = ibf_create (STRATA_IBF_BUCKETS, STRATA_HASH_NUM, 0);
+  GNUNET_assert (dep->subordinates_len <= dep->subordinates_cap);
 
-  session->info = GNUNET_malloc (session->num_peers * sizeof (struct ConsensusPeerInformation));
+  dep->subordinates[dep->subordinates_len] = step;
+  dep->subordinates_len++;
 
-  initialize_session_info (session);
+  step->pending_prereq++;
+}
 
-  GNUNET_free (session->join_msg);
-  session->join_msg = NULL;
 
-  GNUNET_SERVER_receive_done (session->client, GNUNET_OK);
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "session %s initialized\n", GNUNET_h2s (&session->global_id));
+static struct Step *
+create_step (struct ConsensusSession *session, int round, int early_finishable)
+{
+  struct Step *step;
+  step = GNUNET_new (struct Step);
+  step->session = session;
+  step->round = round;
+  step->early_finishable = early_finishable;
+  GNUNET_CONTAINER_DLL_insert_tail (session->steps_head,
+                                    session->steps_tail,
+                                    step);
+  return step;
 }
 
 
 /**
- * Called when a client wants to join a consensus session.
- *
- * @param cls unused
- * @param client client that sent the message
- * @param m message sent by the client
+ * Construct the task graph for a single
+ * gradecast.
  */
 static void
-client_join (void *cls,
-             struct GNUNET_SERVER_Client *client,
-             const struct GNUNET_MessageHeader *m)
+construct_task_graph_gradecast (struct ConsensusSession *session,
+                                uint16_t rep,
+                                uint16_t lead,
+                                struct Step *step_before,
+                                struct Step *step_after)
 {
-  struct ConsensusSession *session;
+  uint16_t n = session->num_peers;
+  uint16_t me = session->local_peer_idx;
+
+  uint16_t p1;
+  uint16_t p2;
+
+  /* The task we're currently setting up. */
+  struct TaskEntry task;
+
+  struct Step *step;
+  struct Step *prev_step;
+
+  uint16_t round;
+
+  unsigned int k;
+
+  round = step_before->round + 1;
+
+  /* gcast step 1: leader disseminates */
 
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "join received\n");
+  step = create_step (session, round, GNUNET_YES);
 
-  // make sure the client has not already joined a session
-  session = sessions_head;
-  while (NULL != session)
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_asprintf (&step->debug_name, "disseminate leader %u rep %u", lead, rep);
+#endif
+  step_depend_on (step, step_before);
+
+  if (lead == me)
   {
-    if (session->client == client)
+    for (k = 0; k < n; k++)
     {
-      GNUNET_break (0);
-      disconnect_client (client);
-      return;
+      if (k == me)
+        continue;
+      p1 = me;
+      p2 = k;
+      arrange_peers (&p1, &p2, n);
+      task = ((struct TaskEntry) {
+        .step = step,
+        .start = task_start_reconcile,
+        .cancel = task_cancel_reconcile,
+        .key = (struct TaskKey) { PHASE_KIND_GRADECAST_LEADER, p1, p2, rep, me },
+      });
+      task.cls.setop.input_set = (struct SetKey) { SET_KIND_CURRENT, rep };
+      put_task (session->taskmap, &task);
     }
-    session = session->next;
+    /* We run this task to make sure that the leader
+       has the stored the SET_KIND_LEADER set of himself,
+       so he can participate in the rest of the gradecast
+       without the code having to handle any special cases. */
+    task = ((struct TaskEntry) {
+      .step = step,
+      .key = (struct TaskKey) { PHASE_KIND_GRADECAST_LEADER, me, me, rep, me },
+      .start = task_start_reconcile,
+      .cancel = task_cancel_reconcile,
+    });
+    task.cls.setop.input_set = (struct SetKey) { SET_KIND_CURRENT, rep };
+    task.cls.setop.output_set = (struct SetKey) { SET_KIND_LEADER_PROPOSAL, rep, me };
+    task.cls.setop.output_diff = (struct DiffKey) { DIFF_KIND_LEADER_PROPOSAL, rep, me };
+    put_task (session->taskmap, &task);
+  }
+  else
+  {
+    p1 = me;
+    p2 = lead;
+    arrange_peers (&p1, &p2, n);
+    task = ((struct TaskEntry) {
+      .step = step,
+      .key = (struct TaskKey) { PHASE_KIND_GRADECAST_LEADER, p1, p2, rep, lead },
+      .start = task_start_reconcile,
+      .cancel = task_cancel_reconcile,
+    });
+    task.cls.setop.input_set = (struct SetKey) { SET_KIND_CURRENT, rep };
+    task.cls.setop.output_set = (struct SetKey) { SET_KIND_LEADER_PROPOSAL, rep, lead };
+    task.cls.setop.output_diff = (struct DiffKey) { DIFF_KIND_LEADER_PROPOSAL, rep, lead };
+    put_task (session->taskmap, &task);
   }
 
-  session = GNUNET_malloc (sizeof (struct ConsensusSession));
-  session->join_msg = (struct GNUNET_CONSENSUS_JoinMessage *) GNUNET_copy_message (m);
-  session->client = client;
-  GNUNET_SERVER_client_keep (client);
+  /* gcast phase 2: echo */
+  prev_step = step;
+  round += 1;
+  step = create_step (session, round, GNUNET_YES);
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_asprintf (&step->debug_name, "echo leader %u rep %u", lead, rep);
+#endif
+  step_depend_on (step, prev_step);
 
-  GNUNET_CONTAINER_DLL_insert (sessions_head, sessions_tail, session);
+  for (k = 0; k < n; k++)
+  {
+    p1 = k;
+    p2 = me;
+    arrange_peers (&p1, &p2, n);
+    task = ((struct TaskEntry) {
+      .step = step,
+      .key = (struct TaskKey) { PHASE_KIND_GRADECAST_ECHO, p1, p2, rep, lead },
+      .start = task_start_reconcile,
+      .cancel = task_cancel_reconcile,
+    });
+    task.cls.setop.input_set = (struct SetKey) { SET_KIND_LEADER_PROPOSAL, rep, lead };
+    task.cls.setop.output_rfn = (struct RfnKey) { RFN_KIND_ECHO, rep, lead };
+    put_task (session->taskmap, &task);
+  }
 
-  // Initialize session later if local peer identity is not known yet.
-  if (NULL == my_peer)
+  prev_step = step;
+  /* Same round, since step only has local tasks */
+  step = create_step (session, round, GNUNET_YES);
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_asprintf (&step->debug_name, "echo grade leader %u rep %u", lead, rep);
+#endif
+  step_depend_on (step, prev_step);
+
+  arrange_peers (&p1, &p2, n);
+  task = ((struct TaskEntry) {
+    .key = (struct TaskKey) { PHASE_KIND_GRADECAST_ECHO_GRADE, -1, -1, rep, lead },
+    .step = step,
+    .start = task_start_eval_echo
+  });
+  put_task (session->taskmap, &task);
+
+  prev_step = step;
+  round += 1;
+  step = create_step (session, round, GNUNET_YES);
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_asprintf (&step->debug_name, "confirm leader %u rep %u", lead, rep);
+#endif
+  step_depend_on (step, prev_step);
+
+  /* gcast phase 3: confirmation and grading */
+  for (k = 0; k < n; k++)
   {
-    GNUNET_SERVER_disable_receive_done_warning (client);
-    GNUNET_log (GNUNET_ERROR_TYPE_INFO, "session init delayed\n");
-    return;
+    p1 = k;
+    p2 = me;
+    arrange_peers (&p1, &p2, n);
+    task = ((struct TaskEntry) {
+      .step = step,
+      .start = task_start_reconcile,
+      .cancel = task_cancel_reconcile,
+      .key = (struct TaskKey) { PHASE_KIND_GRADECAST_CONFIRM, p1, p2, rep, lead},
+    });
+    task.cls.setop.input_set = (struct SetKey) { SET_KIND_ECHO_RESULT, rep, lead };
+    task.cls.setop.output_rfn = (struct RfnKey) { RFN_KIND_CONFIRM, rep, lead };
+    /* If there was at least one element in the echo round that was
+       contested (i.e. it had no n-t majority), then we let the other peers
+       know, and other peers let us know.  The contested flag for each peer is
+       stored in the rfn. */
+    task.cls.setop.transceive_contested = GNUNET_YES;
+    put_task (session->taskmap, &task);
   }
 
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "session init now\n");
-  initialize_session (session);
+  prev_step = step;
+  /* Same round, since step only has local tasks */
+  step = create_step (session, round, GNUNET_YES);
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_asprintf (&step->debug_name, "confirm grade leader %u rep %u", lead, rep);
+#endif
+  step_depend_on (step, prev_step);
+
+  task = ((struct TaskEntry) {
+    .step = step,
+    .key = (struct TaskKey) { PHASE_KIND_GRADECAST_CONFIRM_GRADE, -1, -1, rep, lead },
+    .start = task_start_grade,
+  });
+  put_task (session->taskmap, &task);
+
+  step_depend_on (step_after, step);
 }
 
 
-/**
- * Called when a client performs an insert operation.
- *
- * @param cls (unused)
- * @param client client handle
- * @param message message sent by the client
- */
-void
-client_insert (void *cls,
-             struct GNUNET_SERVER_Client *client,
-             const struct GNUNET_MessageHeader *m)
+static void
+construct_task_graph (struct ConsensusSession *session)
 {
-  struct ConsensusSession *session;
-  struct GNUNET_CONSENSUS_ElementMessage *msg;
-  struct GNUNET_CONSENSUS_Element *element;
-  struct GNUNET_HashCode key;
-  int element_size;
-
-  GNUNET_log(GNUNET_ERROR_TYPE_INFO, "insert\n");
+  uint16_t n = session->num_peers;
+  uint16_t t = n / 3;
 
-  session = sessions_head;
-  while (NULL != session)
-  {
-    if (session->client == client)
-      break;
-  }
-
-  if (NULL == session)
-  {
-    GNUNET_log (GNUNET_ERROR_TYPE_WARNING, "client tried to insert, but client is not in any session\n");
-    GNUNET_SERVER_client_disconnect (client);
-    return;
-  }
+  uint16_t me = session->local_peer_idx;
 
-  msg = (struct GNUNET_CONSENSUS_ElementMessage *) m;
-  element_size = msg->header.size - sizeof (struct GNUNET_CONSENSUS_ElementMessage);
+  /* The task we're currently setting up. */
+  struct TaskEntry task;
 
-  element = GNUNET_malloc (sizeof (struct GNUNET_CONSENSUS_Element) + element_size);
+  /* Current leader */
+  unsigned int lead;
 
-  element->type = msg->element_type;
-  element->size = element_size;
-  memcpy (&element[1], &msg[1], element_size);
-  element->data = &element[1];
+  struct Step *step;
+  struct Step *prev_step;
 
-  GNUNET_CRYPTO_hash (element, element_size, &key);
+  unsigned int round = 0;
 
-  GNUNET_CONTAINER_multihashmap_put (session->values, &key, element,
-                                     GNUNET_CONTAINER_MULTIHASHMAPOPTION_MULTIPLE);
+  unsigned int i;
 
-  strata_insert (session->strata, &key);
+  // XXX: introduce first step,
+  // where we wait for all insert acks
+  // from the set service
 
-  GNUNET_SERVER_receive_done (client, GNUNET_OK);
+  /* faster but brittle all-to-all */
 
-  send_next (session);
-}
+  // XXX: Not implemented yet
 
+  /* all-to-all step */
 
+  step = create_step (session, round, GNUNET_NO);
 
-/**
- * Functions of this signature are called whenever writing operations
- * on a stream are executed
- *
- * @param cls the closure from GNUNET_STREAM_write
- * @param status the status of the stream at the time this function is called;
- *          GNUNET_STREAM_OK if writing to stream was completed successfully;
- *          GNUNET_STREAM_TIMEOUT if the given data is not sent successfully
- *          (this doesn't mean that the data is never sent, the receiver may
- *          have read the data but its ACKs may have been lost);
- *          GNUNET_STREAM_SHUTDOWN if the stream is shutdown for writing in the
- *          mean time; GNUNET_STREAM_SYSERR if the stream is broken and cannot
- *          be processed.
- * @param size the number of bytes written
- */
-static void 
-write_strata (void *cls, enum GNUNET_STREAM_Status status, size_t size)
-{
-  struct ConsensusPeerInformation *cpi;
-  struct StrataMessage *strata_msg;
-  size_t msize;
-  int i;
-  struct GNUNET_HashCode *hash_dst;
-  uint8_t *count_dst;
-  int num_strata;
+#ifdef GNUNET_EXTRA_LOGGING
+  step->debug_name = GNUNET_strdup ("all to all");
+#endif
 
-  cpi = (struct ConsensusPeerInformation *) cls;
+  for (i = 0; i < n; i++)
+  {
+    uint16_t p1;
+    uint16_t p2;
+
+    p1 = me;
+    p2 = i;
+    arrange_peers (&p1, &p2, n);
+    task = ((struct TaskEntry) {
+      .key = (struct TaskKey) { PHASE_KIND_ALL_TO_ALL, p1, p2, -1, -1 },
+      .step = step,
+      .start = task_start_reconcile,
+      .cancel = task_cancel_reconcile,
+    });
+    task.cls.setop.input_set = (struct SetKey) { SET_KIND_CURRENT, 0 };
+    task.cls.setop.output_set = task.cls.setop.input_set;
+    task.cls.setop.do_not_remove = GNUNET_YES;
+    put_task (session->taskmap, &task);
+  }
 
-  GNUNET_assert (GNUNET_YES == cpi->is_outgoing);
+  round += 1;
+  prev_step = step;
+  step = create_step (session, round, GNUNET_NO);;
+#ifdef GNUNET_EXTRA_LOGGING
+  step->debug_name = GNUNET_strdup ("all to all 2");
+#endif
+  step_depend_on (step, prev_step);
 
-  /* FIXME: handle this */
-  GNUNET_assert (GNUNET_STREAM_OK == status);
 
-  if (STRATA_COUNT == cpi->strata_counter)
+  for (i = 0; i < n; i++)
   {
-    /* strata have been written, wait for other side's IBF */
-    return;
+    uint16_t p1;
+    uint16_t p2;
+
+    p1 = me;
+    p2 = i;
+    arrange_peers (&p1, &p2, n);
+    task = ((struct TaskEntry) {
+      .key = (struct TaskKey) { PHASE_KIND_ALL_TO_ALL_2, p1, p2, -1, -1 },
+      .step = step,
+      .start = task_start_reconcile,
+      .cancel = task_cancel_reconcile,
+    });
+    task.cls.setop.input_set = (struct SetKey) { SET_KIND_CURRENT, 0 };
+    task.cls.setop.output_set = task.cls.setop.input_set;
+    task.cls.setop.do_not_remove = GNUNET_YES;
+    put_task (session->taskmap, &task);
   }
 
-  if ((STRATA_COUNT - cpi->strata_counter) < STRATA_PER_MESSAGE)
-    num_strata = (STRATA_COUNT - cpi->strata_counter);
-  else
-    num_strata = STRATA_PER_MESSAGE;
+  round += 1;
 
+  prev_step = step;
+  step = NULL;
 
-  msize = (sizeof *strata_msg) + (num_strata * IBF_BUCKET_SIZE * STRATA_IBF_BUCKETS);
 
-  strata_msg = GNUNET_malloc (msize);
-  strata_msg->header.size = htons (msize);
-  strata_msg->header.type = htons (GNUNET_MESSAGE_TYPE_CONSENSUS_P2P_DELTA_ESTIMATE);
-  strata_msg->num_strata = htons (num_strata);
 
-  /* for correct message alignment, copy bucket types seperately */
-  hash_dst = (struct GNUNET_HashCode *) &strata_msg[1];
+  /* Byzantine union */
 
-  for (i = 0; i < num_strata; i++)
+  /* sequential repetitions of the gradecasts */
+  for (i = 0; i < t + 1; i++)
   {
-    memcpy (hash_dst, cpi->session->strata[cpi->strata_counter+i]->hash_sum, STRATA_IBF_BUCKETS * sizeof *hash_dst);
-    hash_dst += STRATA_IBF_BUCKETS;
+    struct Step *step_rep_start;
+    struct Step *step_rep_end;
+
+    /* Every repetition is in a separate round. */
+    step_rep_start = create_step (session, round, GNUNET_YES);
+#ifdef GNUNET_EXTRA_LOGGING
+    GNUNET_asprintf (&step_rep_start->debug_name, "gradecast start rep %u", i);
+#endif
+
+    step_depend_on (step_rep_start, prev_step);
+
+    /* gradecast has three rounds */
+    round += 3;
+    step_rep_end = create_step (session, round, GNUNET_YES);
+#ifdef GNUNET_EXTRA_LOGGING
+    GNUNET_asprintf (&step_rep_end->debug_name, "gradecast end rep %u", i);
+#endif
+
+    /* parallel gradecasts */
+    for (lead = 0; lead < n; lead++)
+      construct_task_graph_gradecast (session, i, lead, step_rep_start, step_rep_end);
+
+    task = ((struct TaskEntry) {
+      .step = step_rep_end,
+      .key = (struct TaskKey) { PHASE_KIND_APPLY_REP, -1, -1, i, -1},
+      .start = task_start_apply_round,
+    });
+    put_task (session->taskmap, &task);
+
+    prev_step = step_rep_end;
   }
 
-  for (i = 0; i < num_strata; i++)
+ /* There is no next gradecast round, thus the final
+    start step is the overall end step of the gradecasts */
+  round += 1;
+  step = create_step (session, round, GNUNET_NO);
+#ifdef GNUNET_EXTRA_LOGGING
+  GNUNET_asprintf (&step->debug_name, "finish");
+#endif
+  step_depend_on (step, prev_step);
+
+  task = ((struct TaskEntry) {
+    .step = step,
+    .key = (struct TaskKey) { PHASE_KIND_FINISH, -1, -1, -1, -1 },
+    .start = task_start_finish,
+  });
+  task.cls.finish.input_set = (struct SetKey) { SET_KIND_LAST_GRADECAST };
+
+  put_task (session->taskmap, &task);
+}
+
+
+
+/**
+ * Check join message.
+ *
+ * @param cls session of client that sent the message
+ * @param m message sent by the client
+ * @return #GNUNET_OK if @a m is well-formed
+ */
+static int
+check_client_join (void *cls,
+                   const struct GNUNET_CONSENSUS_JoinMessage *m)
+{
+  uint32_t listed_peers = ntohl (m->num_peers);
+
+  if ( (ntohs (m->header.size) - sizeof (*m)) !=
+       listed_peers * sizeof (struct GNUNET_PeerIdentity))
   {
-    memcpy (hash_dst, cpi->session->strata[cpi->strata_counter+i]->id_sum, STRATA_IBF_BUCKETS * sizeof *hash_dst);
-    hash_dst += STRATA_IBF_BUCKETS;
+    GNUNET_break (0);
+    return GNUNET_SYSERR;
   }
+  return GNUNET_OK;
+}
 
-  count_dst = (uint8_t *) hash_dst;
 
-  for (i = 0; i < num_strata; i++)
+/**
+ * Called when a client wants to join a consensus session.
+ *
+ * @param cls session of client that sent the message
+ * @param m message sent by the client
+ */
+static void
+handle_client_join (void *cls,
+                    const struct GNUNET_CONSENSUS_JoinMessage *m)
+{
+  struct ConsensusSession *session = cls;
+  struct ConsensusSession *other_session;
+
+  initialize_session_peer_list (session,
+                                m);
+  compute_global_id (session,
+                     &m->session_id);
+
+  /* Check if some local client already owns the session.
+     It is only legal to have a session with an existing global id
+     if all other sessions with this global id are finished.*/
+  for (other_session = sessions_head;
+       NULL != other_session;
+       other_session = other_session->next)
   {
-    memcpy (count_dst, cpi->session->strata[cpi->strata_counter+i]->count, STRATA_IBF_BUCKETS);
-    count_dst += STRATA_IBF_BUCKETS;
+    if ( (other_session != session) &&
+         (0 == GNUNET_CRYPTO_hash_cmp (&session->global_id,
+                                       &other_session->global_id)) )
+      break;
   }
 
-  cpi->strata_counter += num_strata;
+  session->conclude_deadline
+    = GNUNET_TIME_absolute_ntoh (m->deadline);
+  session->conclude_start
+    = GNUNET_TIME_absolute_ntoh (m->start);
+  session->local_peer_idx = get_peer_idx (&my_peer,
+                                          session);
+  GNUNET_assert (-1 != session->local_peer_idx);
+
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Joining consensus session %s containing %u peers as %u with timeout %s\n",
+              GNUNET_h2s (&m->session_id),
+              session->num_peers,
+              session->local_peer_idx,
+              GNUNET_STRINGS_relative_time_to_string
+              (GNUNET_TIME_absolute_get_difference (session->conclude_start,
+                                                    session->conclude_deadline),
+               GNUNET_YES));
+
+  session->set_listener
+    = GNUNET_SET_listen (cfg,
+                         GNUNET_SET_OPERATION_UNION,
+                         &session->global_id,
+                         &set_listen_cb,
+                         session);
+
+  session->setmap = GNUNET_CONTAINER_multihashmap_create (1,
+                                                          GNUNET_NO);
+  session->taskmap = GNUNET_CONTAINER_multihashmap_create (1,
+                                                           GNUNET_NO);
+  session->diffmap = GNUNET_CONTAINER_multihashmap_create (1,
+                                                           GNUNET_NO);
+  session->rfnmap = GNUNET_CONTAINER_multihashmap_create (1,
+                                                          GNUNET_NO);
+
+  {
+    struct SetEntry *client_set;
+
+    client_set = GNUNET_new (struct SetEntry);
+    client_set->h = GNUNET_SET_create (cfg,
+                                       GNUNET_SET_OPERATION_UNION);
+    client_set->key = ((struct SetKey) { SET_KIND_CURRENT, 0, 0 });
+    put_set (session,
+             client_set);
+  }
 
-  cpi->wh = GNUNET_STREAM_write (cpi->socket, strata_msg, msize, GNUNET_TIME_UNIT_FOREVER_REL,
-                                 write_strata, cpi);
+  session->peers_blacklisted = GNUNET_new_array (session->num_peers,
+                                                 int);
 
-  GNUNET_assert (NULL != cpi->wh);
+  /* Just construct the task graph,
+     but don't run anything until the client calls conclude. */
+  construct_task_graph (session);
+  GNUNET_SERVICE_client_continue (session->client);
 }
 
 
-/**
- * Functions of this signature are called whenever writing operations
- * on a stream are executed
- *
- * @param cls the closure from GNUNET_STREAM_write
- * @param status the status of the stream at the time this function is called;
- *          GNUNET_STREAM_OK if writing to stream was completed successfully;
- *          GNUNET_STREAM_TIMEOUT if the given data is not sent successfully
- *          (this doesn't mean that the data is never sent, the receiver may
- *          have read the data but its ACKs may have been lost);
- *          GNUNET_STREAM_SHUTDOWN if the stream is shutdown for writing in the
- *          mean time; GNUNET_STREAM_SYSERR if the stream is broken and cannot
- *          be processed.
- * @param size the number of bytes written
- */
-static void 
-write_ibf (void *cls, enum GNUNET_STREAM_Status status, size_t size)
+static void
+client_insert_done (void *cls)
 {
-  struct ConsensusPeerInformation *cpi;
-
-  cpi = (struct ConsensusPeerInformation *) cls;
+  // FIXME: implement
 }
 
 
 /**
- * Functions of this signature are called whenever writing operations
- * on a stream are executed
+ * Called when a client performs an insert operation.
  *
- * @param cls the closure from GNUNET_STREAM_write
- * @param status the status of the stream at the time this function is called;
- *          GNUNET_STREAM_OK if writing to stream was completed successfully;
- *          GNUNET_STREAM_TIMEOUT if the given data is not sent successfully
- *          (this doesn't mean that the data is never sent, the receiver may
- *          have read the data but its ACKs may have been lost);
- *          GNUNET_STREAM_SHUTDOWN if the stream is shutdown for writing in the
- *          mean time; GNUNET_STREAM_SYSERR if the stream is broken and cannot
- *          be processed.
- * @param size the number of bytes written
+ * @param cls client handle
+ * @param msg message sent by the client
+ * @return #GNUNET_OK (always well-formed)
  */
-static void 
-write_values (void *cls, enum GNUNET_STREAM_Status status, size_t size)
+static int
+check_client_insert (void *cls,
+                      const struct GNUNET_CONSENSUS_ElementMessage *msg)
 {
-  struct ConsensusPeerInformation *cpi;
-
-  cpi = (struct ConsensusPeerInformation *) cls;
+  return GNUNET_OK;
 }
 
 
 /**
- * Called when a client performs the conclude operation.
+ * Called when a client performs an insert operation.
  *
- * @param cls (unused)
- * @param client client handle
- * @param message message sent by the client
+ * @param cls client handle
+ * @param msg message sent by the client
  */
-void
-client_conclude (void *cls,
-             struct GNUNET_SERVER_Client *client,
-             const struct GNUNET_MessageHeader *message)
+static void
+handle_client_insert (void *cls,
+                      const struct GNUNET_CONSENSUS_ElementMessage *msg)
 {
-  struct ConsensusSession *session;
-  int i;
+  struct ConsensusSession *session = cls;
+  ssize_t element_size;
+  struct GNUNET_SET_Handle *initial_set;
+  struct ConsensusElement *ce;
 
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "conclude requested\n");
-
-  session = sessions_head;
-  while ((session != NULL) && (session->client != client))
-    session = session->next;
-  if (NULL == session)
+  if (GNUNET_YES == session->conclude_started)
   {
-    /* client not found */
     GNUNET_break (0);
-    GNUNET_SERVER_client_disconnect (client);
+    GNUNET_SERVICE_client_drop (session->client);
     return;
   }
 
-  if (GNUNET_YES == session->conclude_requested)
+  element_size = ntohs (msg->header.size) - sizeof (struct GNUNET_CONSENSUS_ElementMessage);
+  ce = GNUNET_malloc (sizeof (struct ConsensusElement) + element_size);
+  GNUNET_memcpy (&ce[1], &msg[1], element_size);
+  ce->payload_type = msg->element_type;
+
+  struct GNUNET_SET_Element element = {
+    .element_type = GNUNET_BLOCK_TYPE_CONSENSUS_ELEMENT,
+    .size = sizeof (struct ConsensusElement) + element_size,
+    .data = ce,
+  };
+
   {
-    /* client requested conclude twice */
-    GNUNET_break (0);
-    disconnect_client (client);
-    return;
-  }
+    struct SetKey key = { SET_KIND_CURRENT, 0, 0 };
+    struct SetEntry *entry;
 
-  session->conclude_requested = GNUNET_YES;
+    entry = lookup_set (session,
+                        &key);
+    GNUNET_assert (NULL != entry);
+    initial_set = entry->h;
+  }
 
-  /* FIXME: write to already connected sockets */
+  session->num_client_insert_pending++;
+  GNUNET_SET_add_element (initial_set,
+                          &element,
+                          &client_insert_done,
+                          session);
 
-  for (i = 0; i < session->num_peers; i++)
+#ifdef GNUNET_EXTRA_LOGGING
   {
-    if ( (GNUNET_YES == session->info[i].is_outgoing) &&
-         (GNUNET_YES == session->info[i].hello) )
-    {
-      /* kick off transmitting strata by calling the write continuation */
-      write_strata (&session->info[i], GNUNET_STREAM_OK, 0);
-    }
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "P%u: element %s added\n",
+                session->local_peer_idx,
+                debug_str_element (&element));
   }
-  
-
-  GNUNET_SERVER_receive_done (client, GNUNET_OK);
-  send_next (session);
+#endif
+  GNUNET_free (ce);
+  GNUNET_SERVICE_client_continue (session->client);
 }
 
 
 /**
- * Called when a client sends an ack
+ * Called when a client performs the conclude operation.
  *
- * @param cls (unused)
- * @param client client handle
+ * @param cls client handle
  * @param message message sent by the client
  */
-void
-client_ack (void *cls,
-             struct GNUNET_SERVER_Client *client,
-             const struct GNUNET_MessageHeader *message)
-{
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "client ack received\n");
-}
-
-/**
- * Task that disconnects from core.
- *
- * @param cls core handle
- * @param tc context information (why was this task triggered now)
- */
-static void
-disconnect_core (void *cls,
-                 const struct GNUNET_SCHEDULER_TaskContext *tc)
-{
-  GNUNET_CORE_disconnect (core);
-  core = NULL;
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "disconnected from core\n");
-}
-
-
 static void
-core_startup (void *cls,
-              struct GNUNET_CORE_Handle *core,
-              const struct GNUNET_PeerIdentity *peer)
+handle_client_conclude (void *cls,
+                        const struct GNUNET_MessageHeader *message)
 {
-  struct ConsensusSession *session;
-
-  my_peer = GNUNET_memdup(peer, sizeof (struct GNUNET_PeerIdentity));
-  /* core can't be disconnected directly in the core startup callback, schedule a task to do it! */
-  GNUNET_SCHEDULER_add_now (&disconnect_core, core);
-  GNUNET_log(GNUNET_ERROR_TYPE_INFO, "connected to core\n");
+  struct ConsensusSession *session = cls;
 
-  session = sessions_head;
-  while (NULL != session)
+  if (GNUNET_YES == session->conclude_started)
   {
-    if (NULL != session->join_msg)
-      initialize_session (session);
-    session = session->next;
+    /* conclude started twice */
+    GNUNET_break (0);
+    GNUNET_SERVICE_client_drop (session->client);
+    return;
   }
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "conclude requested\n");
+  session->conclude_started = GNUNET_YES;
+  install_step_timeouts (session);
+  run_ready_steps (session);
+  GNUNET_SERVICE_client_continue (session->client);
 }
 
 
@@ -1365,33 +3283,15 @@ core_startup (void *cls,
  * Called to clean up, after a shutdown has been requested.
  *
  * @param cls closure
- * @param tc context information (why was this task triggered now)
  */
 static void
-shutdown_task (void *cls,
-               const struct GNUNET_SCHEDULER_TaskContext *tc)
+shutdown_task (void *cls)
 {
-  while (NULL != sessions_head)
-  {
-    struct ConsensusSession *session;
-    session = sessions_head;
-    sessions_head = sessions_head->next;
-    GNUNET_free (session);
-  }
-
-  if (NULL != core)
-  {
-    GNUNET_CORE_disconnect (core);
-    core = NULL;
-  }
-
-  if (NULL != listener)
-  {
-    GNUNET_STREAM_listen_close (listener);
-    listener = NULL;
-  } 
-
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "handled shutdown request\n");
+  GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+              "shutting down\n");
+  GNUNET_STATISTICS_destroy (statistics,
+                             GNUNET_NO);
+  statistics = NULL;
 }
 
 
@@ -1399,60 +3299,103 @@ shutdown_task (void *cls,
  * Start processing consensus requests.
  *
  * @param cls closure
- * @param server the initialized server
  * @param c configuration to use
+ * @param service the initialized service
  */
 static void
-run (void *cls, struct GNUNET_SERVER_Handle *server, const struct GNUNET_CONFIGURATION_Handle *c)
+run (void *cls,
+     const struct GNUNET_CONFIGURATION_Handle *c,
+     struct GNUNET_SERVICE_Handle *service)
 {
-  static const struct GNUNET_CORE_MessageHandler core_handlers[] = {
-    {NULL, 0, 0}
-  };
-  static const struct GNUNET_SERVER_MessageHandler server_handlers[] = {
-    {&client_join, NULL, GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_JOIN, 0},
-    {&client_insert, NULL, GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_INSERT, 0},
-    {&client_conclude, NULL, GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_CONCLUDE,
-        sizeof (struct GNUNET_CONSENSUS_ConcludeMessage)},
-    {&client_ack, NULL, GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_ACK,
-        sizeof (struct GNUNET_CONSENSUS_AckMessage)},
-    {NULL, NULL, 0, 0}
-  };
-
   cfg = c;
-  srv = server;
-
-  GNUNET_SERVER_add_handlers (server, server_handlers);
-
-  GNUNET_SCHEDULER_add_delayed (GNUNET_TIME_UNIT_FOREVER_REL, &shutdown_task, NULL);
-
-
-  listener = GNUNET_STREAM_listen (cfg, GNUNET_APPLICATION_TYPE_CONSENSUS,
-                                   listen_cb, NULL,
-                                   GNUNET_STREAM_OPTION_END);
-
+  if (GNUNET_OK !=
+      GNUNET_CRYPTO_get_peer_identity (cfg,
+                                       &my_peer))
+  {
+    GNUNET_log (GNUNET_ERROR_TYPE_ERROR,
+                "Could not retrieve host identity\n");
+    GNUNET_SCHEDULER_shutdown ();
+    return;
+  }
+  statistics = GNUNET_STATISTICS_create ("consensus",
+                                         cfg);
+  GNUNET_SCHEDULER_add_shutdown (&shutdown_task,
+                                 NULL);
+}
 
-  /* we have to wait for the core_startup callback before proceeding with the consensus service startup */
-  core = GNUNET_CORE_connect (c, NULL, &core_startup, NULL, NULL, NULL, GNUNET_NO, NULL, GNUNET_NO, core_handlers);
-  GNUNET_assert (NULL != core);
 
-  GNUNET_log(GNUNET_ERROR_TYPE_INFO, "consensus running\n");
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "strata per msg: %d\n", STRATA_PER_MESSAGE);
+/**
+ * Callback called when a client connects to the service.
+ *
+ * @param cls closure for the service
+ * @param c the new client that connected to the service
+ * @param mq the message queue used to send messages to the client
+ * @return @a c
+ */
+static void *
+client_connect_cb (void *cls,
+                  struct GNUNET_SERVICE_Client *c,
+                  struct GNUNET_MQ_Handle *mq)
+{
+  struct ConsensusSession *session = GNUNET_new (struct ConsensusSession);
+
+  session->client = c;
+  session->client_mq = mq;
+  GNUNET_CONTAINER_DLL_insert (sessions_head,
+                               sessions_tail,
+                               session);
+  return session;
 }
 
 
 /**
- * The main function for the consensus service.
+ * Callback called when a client disconnected from the service
  *
- * @param argc number of arguments from the command line
- * @param argv command line arguments
- * @return 0 ok, 1 on error
+ * @param cls closure for the service
+ * @param c the client that disconnected
+ * @param internal_cls should be equal to @a c
  */
-int
-main (int argc, char *const *argv)
+static void
+client_disconnect_cb (void *cls,
+                     struct GNUNET_SERVICE_Client *c,
+                     void *internal_cls)
 {
-  int ret;
-  ret = GNUNET_SERVICE_run (argc, argv, "consensus", GNUNET_SERVICE_OPTION_NONE, &run, NULL);
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "exit\n");
-  return (GNUNET_OK == ret) ? 0 : 1;
+  struct ConsensusSession *session = internal_cls;
+
+  if (NULL != session->set_listener)
+  {
+    GNUNET_SET_listen_cancel (session->set_listener);
+    session->set_listener = NULL;
+  }
+  GNUNET_CONTAINER_DLL_remove (sessions_head,
+                               sessions_tail,
+                               session);
+  GNUNET_free (session);
 }
 
+
+/**
+ * Define "main" method using service macro.
+ */
+GNUNET_SERVICE_MAIN
+("consensus",
+ GNUNET_SERVICE_OPTION_NONE,
+ &run,
+ &client_connect_cb,
+ &client_disconnect_cb,
+ NULL,
+ GNUNET_MQ_hd_fixed_size (client_conclude,
+                          GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_CONCLUDE,
+                          struct GNUNET_MessageHeader,
+                          NULL),
+ GNUNET_MQ_hd_var_size (client_insert,
+                        GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_INSERT,
+                        struct GNUNET_CONSENSUS_ElementMessage,
+                        NULL),
+ GNUNET_MQ_hd_var_size (client_join,
+                        GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_JOIN,
+                        struct GNUNET_CONSENSUS_JoinMessage,
+                        NULL),
+ GNUNET_MQ_handler_end ());
+
+/* end of gnunet-service-consensus.c */