Merge branch 'master' of ssh://gnunet.org/gnunet
[oweals/gnunet.git] / src / consensus / gnunet-service-consensus.c
index 60bc294edf10a67f850bd44372329c34246e36e2..b934f468fbddad7cb6ea1a635e9f6175c5b147dd 100644 (file)
@@ -1,6 +1,6 @@
 /*
       This file is part of GNUnet
-      Copyright (C) 2012, 2013 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
 
 #include "platform.h"
 #include "gnunet_util_lib.h"
+#include "gnunet_block_lib.h"
 #include "gnunet_protocols.h"
 #include "gnunet_applications.h"
 #include "gnunet_set_service.h"
+#include "gnunet_statistics_service.h"
 #include "gnunet_consensus_service.h"
 #include "consensus_protocol.h"
 #include "consensus.h"
 
 
+enum ReferendumVote
+{
+  /**
+   * Vote that nothing should change.
+   * This option is never voted explicitly.
+   */
+  VOTE_STAY = 0,
+  /**
+   * Vote that an element should be added.
+   */
+  VOTE_ADD = 1,
+  /**
+   * Vote that an element should be removed.
+   */
+  VOTE_REMOVE = 2,
+};
+
+
+enum EarlyStoppingPhase
+{
+  EARLY_STOPPING_NONE = 0,
+  EARLY_STOPPING_ONE_MORE = 1,
+  EARLY_STOPPING_DONE = 2,
+};
+
 
 GNUNET_NETWORK_STRUCT_BEGIN
 
@@ -72,14 +99,6 @@ struct TaskKey {
 };
 
 
-enum ReferendumVote
-{
-  VOTE_NONE = 0,
-  VOTE_ADD = 1,
-  VOTE_REMOVE = 2,
-  VOTE_CONTESTED = 3
-};
-
 
 struct SetKey
 {
@@ -122,12 +141,12 @@ 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,
-  PHASE_KIND_GRADECAST_APPLY_RESULT,
   /**
    * Apply a repetition of the all-to-all
    * gradecast to the current set.
@@ -137,32 +156,14 @@ enum PhaseKind
 };
 
 
-enum TaskKind
-{
-  /**
-   * Do a set reconciliation with another peer (or via looback).
-   */
-  TASK_RECONCILE,
-  /**
-   * Same as reconciliation, but only care about added elements.
-   */
-  TASK_UNION,
-  /**
-   * Apply a referendum with a threshold
-   * to a set and/or a diff.
-   */
-  TASK_EVAL_RFN,
-  /**
-   * Apply a diff to a set.
-   */
-  TASK_APPLY_DIFF,
-  FASK_FINISH,
-};
-
 enum SetKind
 {
   SET_KIND_NONE = 0,
   SET_KIND_CURRENT,
+  /**
+   * Last result set from a gradecast
+   */
+  SET_KIND_LAST_GRADECAST,
   SET_KIND_LEADER_PROPOSAL,
   SET_KIND_ECHO_RESULT,
 };
@@ -194,35 +195,9 @@ struct SetOpCls
 
   int do_not_remove;
 
-  struct GNUNET_SET_OperationHandle *op;
-};
-
-struct EvalRfnCls
-{
-  struct SetKey input_set;
-  struct RfnKey input_rfn;
-  
-  uint16_t threshold;
-
-  struct SetKey output_set;
-  struct DiffKey output_diff;
-};
-
-
-struct ApplyDiffCls
-{
-  struct SetKey input_set;
-  struct DiffKey input_diff;
-  struct SetKey output_set;
-};
-
-
-struct LeaderApplyCls
-{
-  struct DiffKey input_diff_1;
-  struct DiffKey input_diff_2;
+  int transceive_contested;
 
-  struct RfnKey output_rfn;
+  struct GNUNET_SET_OperationHandle *op;
 };
 
 
@@ -238,9 +213,6 @@ struct FinishCls
 union TaskFuncCls
 {
   struct SetOpCls setop;
-  struct EvalRfnCls eval_rfn;
-  struct ApplyDiffCls apply_diff;
-  struct LeaderApplyCls leader_apply;
   struct FinishCls finish;
 };
 
@@ -261,8 +233,6 @@ struct TaskEntry
 
   int is_finished;
 
-  enum TaskKind kind;
-
   TaskFunc start;
   TaskFunc cancel;
 
@@ -286,6 +256,9 @@ struct Step
 
   struct ConsensusSession *session;
 
+  /**
+   * Tasks that this step is composed of.
+   */
   struct TaskEntry **tasks;
   unsigned int tasks_len;
   unsigned int tasks_cap;
@@ -330,6 +303,19 @@ struct Step
    * the task, used for debugging.
    */
   char *debug_name;
+
+  /**
+   * 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.
+   */
+  int early_finishable;
 };
 
 
@@ -338,10 +324,15 @@ struct RfnElementInfo
   const struct GNUNET_SET_Element *element;
 
   /*
-   * Vote (or VOTE_NONE) from every peer
-   * in the session about the element.
+   * GNUNET_YES if the peer votes for the proposal.
    */
   int *votes;
+
+  /**
+   * Proposal for this element,
+   * can only be VOTE_ADD or VOTE_REMOVE.
+   */
+  enum ReferendumVote proposal;
 };
 
 
@@ -357,6 +348,8 @@ struct ReferendumEntry
    */
   struct GNUNET_CONTAINER_MultiHashMap *rfn_elements;
 
+  unsigned int num_peers;
+
   /**
    * Stores, for every peer in the session,
    * whether the peer finished the whole referendum.
@@ -426,7 +419,7 @@ struct ConsensusSession
   /**
    * Array of peers with length 'num_peers'.
    */
-  int *peers_ignored;
+  int *peers_blacklisted;
 
   /*
    * Mapping from (hashed) TaskKey to TaskEntry.
@@ -453,7 +446,7 @@ struct ConsensusSession
   /**
    * Client that inhabits the session
    */
-  struct GNUNET_SERVER_Client *client;
+  struct GNUNET_SERVICE_Client *client;
 
   /**
    * Queued messages to the client.
@@ -489,6 +482,23 @@ struct ConsensusSession
    * Uses the session's global id as app id.
    */
   struct GNUNET_SET_ListenHandle *set_listener;
+
+  /**
+   * State of our early stopping scheme.
+   */
+  int early_stopping;
+
+  /**
+   * Our set size from the first round.
+   */
+  uint64_t first_size;
+
+  uint64_t *first_sizes_received;
+
+  /**
+   * Bounded Eppstein lower bound.
+   */
+  uint64_t lower_bound;
 };
 
 /**
@@ -507,44 +517,37 @@ static struct ConsensusSession *sessions_tail;
 static const struct GNUNET_CONFIGURATION_Handle *cfg;
 
 /**
- * Handle to the server for this service.
+ * Peer that runs this service.
  */
-static struct GNUNET_SERVER_Handle *srv;
+static struct GNUNET_PeerIdentity my_peer;
 
 /**
- * Peer that runs this service.
+ * Statistics handle.
  */
-static struct GNUNET_PeerIdentity my_peer;
+struct GNUNET_STATISTICS_Handle *statistics;
 
 
 static void
 finish_task (struct TaskEntry *task);
 
-static void
-task_start_reconcile (struct TaskEntry *task);
-
-static void
-task_start_eval_rfn (struct TaskEntry *task);
-
-static void
-task_start_apply_diff (struct TaskEntry *task);
 
 static void
 run_ready_steps (struct ConsensusSession *session);
 
+
 static const char *
 phasename (uint16_t phase)
 {
   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_GRADECAST_APPLY_RESULT: return "GRADECAST_APPLY_RESULT";
     case PHASE_KIND_APPLY_REP: return "APPLY_REP";
     default: return "(unknown)";
   }
@@ -627,7 +630,7 @@ debug_str_diff_key (struct DiffKey *dk)
 }
 
 static const char *
-debug_str_set_key (struct SetKey *sk)
+debug_str_set_key (const struct SetKey *sk)
 {
   static char buf[256];
 
@@ -640,7 +643,7 @@ debug_str_set_key (struct SetKey *sk)
 
 
 static const char *
-debug_str_rfn_key (struct RfnKey *rk)
+debug_str_rfn_key (const struct RfnKey *rk)
 {
   static char buf[256];
 
@@ -654,36 +657,6 @@ debug_str_rfn_key (struct RfnKey *rk)
 #endif /* GNUNET_EXTRA_LOGGING */
 
 
-/**
- * Destroy a session, free all resources associated with it.
- *
- * @param session the session to destroy
- */
-static void
-destroy_session (struct ConsensusSession *session)
-{
-  GNUNET_CONTAINER_DLL_remove (sessions_head, sessions_tail, session);
-  if (NULL != session->set_listener)
-  {
-    GNUNET_SET_listen_cancel (session->set_listener);
-    session->set_listener = NULL;
-  }
-  if (NULL != session->client_mq)
-  {
-    GNUNET_MQ_destroy (session->client_mq);
-    session->client_mq = NULL;
-    /* The MQ cleanup will also disconnect the underlying client. */
-    session->client = NULL;
-  }
-  if (NULL != session->client)
-  {
-    GNUNET_SERVER_client_disconnect (session->client);
-    session->client = NULL;
-  }
-  GNUNET_free (session);
-}
-
-
 /**
  * Send the final result set of the consensus to the client, element by
  * element.
@@ -704,16 +677,25 @@ send_to_client_iter (void *cls,
   if (NULL != element)
   {
     struct GNUNET_CONSENSUS_ElementMessage *m;
+    const struct ConsensusElement *ce;
+
+    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);
+
+    if (0 != ce->marker)
+      return GNUNET_YES;
 
     GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
                 "P%d: sending element %s to client\n",
                 session->local_peer_idx,
                 debug_str_element (element));
 
-    ev = GNUNET_MQ_msg_extra (m, element->size,
+    ev = GNUNET_MQ_msg_extra (m, element->size - sizeof (struct ConsensusElement),
                               GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_RECEIVED_ELEMENT);
-    m->element_type = htons (element->element_type);
-    memcpy (&m[1], element->data, element->size);
+    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
@@ -814,40 +796,76 @@ diff_insert (struct DiffEntry *diff,
 }
 
 
+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,
-          uint16_t num_peers,
-          int vote,
+          enum ReferendumVote vote,
           const struct GNUNET_SET_Element *element)
 {
   struct RfnElementInfo *ri;
   struct GNUNET_HashCode hash;
 
-  GNUNET_assert (voting_peer < num_peers);
+  GNUNET_assert (voting_peer < rfn->num_peers);
 
-  rfn->peer_commited[voting_peer] = GNUNET_YES;
+  /* 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 (num_peers, int);
+    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] = vote;
+  ri->votes[voting_peer] = GNUNET_YES;
+  ri->proposal = vote;
 }
 
 
-uint16_t
+static uint16_t
 task_other_peer (struct TaskEntry *task)
 {
   uint16_t me = task->step->session->local_peer_idx;
@@ -857,17 +875,33 @@ task_other_peer (struct TaskEntry *task)
 }
 
 
+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;
+}
+
+
 /**
  * Callback for set operation results. Called for each element
  * in the result set.
  *
  * @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
 set_result_cb (void *cls,
                const struct GNUNET_SET_Element *element,
+               uint64_t current_size,
                enum GNUNET_SET_Status status)
 {
   struct TaskEntry *task = cls;
@@ -877,10 +911,22 @@ set_result_cb (void *cls,
   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,
@@ -899,15 +945,7 @@ set_result_cb (void *cls,
     return;
   }
 
-  if (task->key.peer1 == session->local_peer_idx)
-    other_idx = task->key.peer2;
-  else if (task->key.peer2 == session->local_peer_idx)
-    other_idx = task->key.peer1;
-  else
-  {
-    /* error in task graph construction */
-    GNUNET_assert (0);
-  }
+  other_idx = task_other_peer (task);
 
   if (SET_KIND_NONE != setop->output_set.set_kind)
   {
@@ -927,17 +965,63 @@ set_result_cb (void *cls,
     GNUNET_assert (NULL != output_rfn);
   }
 
-  if (GNUNET_YES == session->peers_ignored[other_idx])
+  if (GNUNET_YES == session->peers_blacklisted[other_idx])
   {
-    /* We should have never started or commited to an operation
-       with an ignored peer. */
-    GNUNET_break (0);
+    /* 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) )
+  {
+    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) )
+    {
+      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;
+    }
+
     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));
@@ -971,7 +1055,7 @@ set_result_cb (void *cls,
       }
       if (NULL != output_rfn)
       {
-        rfn_vote (output_rfn, task_other_peer (task), session->num_peers, VOTE_ADD, element);
+        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",
@@ -984,8 +1068,11 @@ set_result_cb (void *cls,
       // 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));
@@ -1019,7 +1106,7 @@ set_result_cb (void *cls,
       }
       if (NULL != output_rfn)
       {
-        rfn_vote (output_rfn, task_other_peer (task), session->num_peers, VOTE_REMOVE, element);
+        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",
@@ -1033,15 +1120,23 @@ set_result_cb (void *cls,
     case GNUNET_SET_STATUS_DONE:
       // XXX: check first if any changes to the underlying
       // set are still pending
-      // XXX: commit other peer in referendum
       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 (0);
+      GNUNET_break_op (0);
+      finish_task (task);
       return;
     default:
       /* not reached */
@@ -1051,26 +1146,69 @@ set_result_cb (void *cls,
 
 #ifdef EVIL
 
-enum Evilness
+enum EvilnessType
 {
   EVILNESS_NONE,
-  EVILNESS_CRAM,
+  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;
+}
+
+
 static void
-get_evilness (struct ConsensusSession *session, enum Evilness *ret_type, unsigned int *ret_num)
+get_evilness (struct ConsensusSession *session, struct Evilness *evil)
 {
   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);
-    *ret_type = EVILNESS_NONE;
+    evil->type = EVILNESS_NONE;
     return;
   }
   GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
@@ -1086,30 +1224,58 @@ get_evilness (struct ConsensusSession *session, enum Evilness *ret_type, unsigne
     int ret;
 
     evil_type_str = NULL;
+    evil_subtype_str = NULL;
 
-    ret = sscanf (field, "%u;%m[a-z];%u", &peer_num, &evil_type_str, &evil_num);
+    ret = sscanf (field, "%u;%m[a-z-];%m[a-z-];%u", &peer_num, &evil_type_str, &evil_subtype_str, &evil_num);
 
-    if (ret != 3)
+    if (ret != 4)
     {
-      GNUNET_log (GNUNET_ERROR_TYPE_ERROR, "Malformed field '%s' in EVIL_SPEC, behaving like a good peer.\n",
-                  field); 
+      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))
-        *ret_type = EVILNESS_SLACK;
-      else if (0 == strcmp ("cram", evil_type_str))
       {
-        *ret_type = EVILNESS_CRAM;
-        *ret_num = evil_num;
+        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"); 
+        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;
@@ -1117,13 +1283,18 @@ get_evilness (struct ConsensusSession *session, enum Evilness *ret_type, unsigne
     /* No GNUNET_free since memory was allocated by libc */
     free (evil_type_str);
     evil_type_str = NULL;
+    evil_subtype_str = NULL;
   }
 not_evil:
-  *ret_type = EVILNESS_NONE;
+  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
@@ -1144,16 +1315,50 @@ commit_set (struct ConsensusSession *session,
   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);
+  }
+
+  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);
+  }
+
 #ifdef EVIL
   {
     unsigned int i;
-    unsigned int evil_num;
-    enum Evilness evilness;
+    struct Evilness evil;
 
-    get_evilness (session, &evilness, &evil_num);
-    switch (evilness)
+    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:
+      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
@@ -1163,15 +1368,39 @@ commit_set (struct ConsensusSession *session,
           GNUNET_SET_commit (setop->op, set->h);
           break;
         }
-        for (i = 0; i < evil_num; i++)
+        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_HashCode hash;
           struct GNUNET_SET_Element element;
-          element.data = &hash;
-          element.size = sizeof (struct GNUNET_HashCode);
-          element.element_type = 0;
-
-          GNUNET_CRYPTO_hash_create_random (GNUNET_CRYPTO_QUALITY_STRONG, &hash);
+          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,
@@ -1182,14 +1411,30 @@ commit_set (struct ConsensusSession *session,
                       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",
-                    session->local_peer_idx,
-                    evil_num);
+                    (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);
@@ -1197,7 +1442,17 @@ commit_set (struct ConsensusSession *session,
     }
   }
 #else
-  GNUNET_SET_commit (setop->op, set->h);
+  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
 }
 
@@ -1229,9 +1484,9 @@ put_set (struct ConsensusSession *session,
               debug_str_set_key (&set->key));
 
   GNUNET_CRYPTO_hash (&set->key, sizeof (struct SetKey), &hash);
-  GNUNET_assert (GNUNET_OK ==
+  GNUNET_assert (GNUNET_SYSERR !=
                  GNUNET_CONTAINER_multihashmap_put (session->setmap, &hash, set,
-                                                    GNUNET_CONTAINER_MULTIHASHMAPOPTION_UNIQUE_ONLY));
+                                                    GNUNET_CONTAINER_MULTIHASHMAPOPTION_REPLACE));
 }
 
 
@@ -1249,25 +1504,6 @@ put_rfn (struct ConsensusSession *session,
 
 
 
-static void
-output_cloned_cb (void *cls, struct GNUNET_SET_Handle *copy)
-{
-  struct TaskEntry *task = (struct TaskEntry *) cls;
-  struct SetOpCls *setop = &task->cls.setop;
-  struct ConsensusSession *session = task->step->session;
-  struct SetEntry *set = GNUNET_new (struct SetEntry);
-
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-              "P%u: Received lazy copy, storing output set %s\n",
-              session->local_peer_idx, debug_str_set_key (&setop->output_set));
-
-  set->key = setop->output_set;
-  set->h = copy;
-  put_set (task->step->session, set);
-  task_start_reconcile (task);
-}
-
-
 static void
 task_cancel_reconcile (struct TaskEntry *task)
 {
@@ -1287,15 +1523,18 @@ apply_diff_to_rfn (struct DiffEntry *diff,
 
   iter = GNUNET_CONTAINER_multihashmap_iterator_create (diff->changes);
 
-  while (GNUNET_YES == GNUNET_CONTAINER_multihashmap_iterator_next (iter, NULL, (const void **) &di))
+  while (GNUNET_YES ==
+         GNUNET_CONTAINER_multihashmap_iterator_next (iter,
+                                                      NULL,
+                                                      (const void **) &di))
   {
     if (di->weight > 0)
     {
-      rfn_vote (rfn, voting_peer, num_peers, VOTE_ADD, di->element);
+      rfn_vote (rfn, voting_peer, VOTE_ADD, di->element);
     }
     if (di->weight < 0)
     {
-      rfn_vote (rfn, voting_peer, num_peers, VOTE_REMOVE, di->element);
+      rfn_vote (rfn, voting_peer, VOTE_REMOVE, di->element);
     }
   }
 
@@ -1309,7 +1548,7 @@ diff_create ()
   struct DiffEntry *d = GNUNET_new (struct DiffEntry);
 
   d->changes = GNUNET_CONTAINER_multihashmap_create (8, GNUNET_NO);
-  
+
   return d;
 }
 
@@ -1321,7 +1560,7 @@ diff_compose (struct DiffEntry *diff_1,
   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);
@@ -1350,61 +1589,452 @@ rfn_create (uint16_t size)
   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
-task_start_leader_apply (struct TaskEntry *task)
+rfn_majority (const struct ReferendumEntry *rfn,
+              const struct RfnElementInfo *ri,
+              uint16_t *ret_majority,
+              enum ReferendumVote *ret_vote)
 {
-  struct LeaderApplyCls *lacls = &task->cls.leader_apply;
-  struct ConsensusSession *session = task->step->session;
-  struct DiffEntry *diff_1;
-  struct DiffEntry *diff_2;
-  struct DiffEntry *diff_combined;
-  struct ReferendumEntry *rfn;
+  uint16_t votes_yes = 0;
+  uint16_t num_commited = 0;
+  uint16_t i;
 
-  diff_1 = lookup_diff (session, &lacls->input_diff_1);
-  GNUNET_assert (NULL != diff_1);
+  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));
 
-  diff_2 = lookup_diff (session, &lacls->input_diff_2);
-  GNUNET_assert (NULL != diff_2);
+  for (i = 0; i < rfn->num_peers; i++)
+  {
+    if (GNUNET_NO == rfn->peer_commited[i])
+      continue;
+    num_commited++;
 
-  rfn = lookup_rfn (session, &lacls->output_rfn);
+    if (GNUNET_YES == ri->votes[i])
+      votes_yes++;
+  }
 
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-              "looked up everything\n");
-  
-  if (NULL == rfn)
+  if (votes_yes > (num_commited) / 2)
+  {
+    *ret_vote = ri->proposal;
+    *ret_majority = votes_yes;
+  }
+  else
   {
-    rfn = rfn_create (session->num_peers);
-    rfn->key = lacls->output_rfn;
-    put_rfn (session, rfn);
+    *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,
-              "ensured rfn\n");
+              "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;
 
-  diff_combined = diff_compose (diff_1, diff_2);
+  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,
-              "composed diffs\n");
+              "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;
 
-  apply_diff_to_rfn (diff_combined, rfn, task->key.leader, session->num_peers);
+  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,
-              "applied diffs to rfns\n");
+              "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;
 
-  diff_destroy (diff_combined);
+    // 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);
 }
@@ -1432,12 +2062,7 @@ task_start_reconcile (struct TaskEntry *task)
        we clone the input set. */
     if (NULL == lookup_set (session, &setop->output_set))
     {
-      GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-                  "Output set missing, copying from input set\n");
-      /* Since the cloning is asynchronous,
-         we'll retry the current function once the copy
-         has been provided by the SET service. */
-      GNUNET_SET_copy_lazy (input->h, output_cloned_cb, task);
+      create_set_copy_for_task (task, &setop->input_set, &setop->output_set);
       return;
     }
   }
@@ -1500,21 +2125,22 @@ task_start_reconcile (struct TaskEntry *task)
     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);
 
-    if (GNUNET_OK != GNUNET_SET_commit (setop->op, input->h))
-    {
-      GNUNET_break (0);
-      /* XXX: cleanup? */
-      return;
-    }
+    commit_set (session, task);
   }
   else if (task->key.peer2 == session->local_peer_idx)
   {
@@ -1525,404 +2151,118 @@ task_start_reconcile (struct TaskEntry *task)
     if (NULL != setop->op)
     {
       commit_set (session, task);
-    }
-  }
-  else
-  {
-    /* We made an error while constructing the task graph. */
-    GNUNET_assert (0);
-  }
-}
-
-
-static int
-rfn_majority (uint16_t num_peers,
-              struct ReferendumEntry *rfn,
-              struct RfnElementInfo *ri,
-              uint16_t threshold)
-{
-  unsigned int votes_add = 0;
-  unsigned int votes_remove = 0;
-  unsigned int num_commited = 0;
-  unsigned int maj_thresh;
-  unsigned int nv;
-  unsigned int tv;
-  unsigned int 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 < num_peers; i++)
-  {
-    if (GNUNET_NO == rfn->peer_commited[i])
-      continue;
-    num_commited++;
-    if (ri->votes[i] == VOTE_ADD)
-      votes_add++;
-    if (ri->votes[i] == VOTE_REMOVE)
-      votes_remove++;
-  }
-
-  /* Threshold to reach a majority among
-     submitted votes, may not be enough for the
-     global threshold. */
-  maj_thresh = (num_commited + 1) / 2;
-  /* Vote are relative to our local set, so it can only be
-     either all add or all remove */
-  GNUNET_assert ( (0 == votes_add) || (0 == votes_remove) );
-
-  if (votes_add > 0)
-  {
-    nv = votes_add;
-    tv = VOTE_ADD;
-  }
-  else if (votes_remove > 0)
-  {
-    nv = votes_remove;
-    tv = VOTE_REMOVE;
-  }
-  else
-  {
-    nv = 0;
-    tv = VOTE_NONE;
-  }
-
-  if ( (nv >= maj_thresh) && (nv >= threshold) )
-    return tv;
-
-  if ( ((num_commited - nv) >= maj_thresh) && ((num_commited - nv) >= threshold) )
-    return VOTE_NONE;
-
-  return VOTE_CONTESTED;
-}
-
-
-struct SetChangeProgressCls
-{
-  int num_pending;
-  struct TaskEntry *task;
-};
-
-
-static void
-eval_rfn_done (struct TaskEntry *task)
-{
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-              "P%u: EVAL_REFERENDUM done for task {%s}\n",
-              task->step->session->local_peer_idx, debug_str_task_key (&task->key));
-
-  finish_task (task);
-}
-
-
-static void
-eval_rfn_progress (void *cls)
-{
-  struct SetChangeProgressCls *erc = cls;
-
-  GNUNET_assert (erc->num_pending > 0);
-
-  erc->num_pending--;
-
-  if (0 == erc->num_pending)
-  {
-    struct TaskEntry *task = erc->task;
-    GNUNET_free (erc);
-    eval_rfn_done (task);
-  }
-}
-
-
-static void
-eval_rfn_copy_cb (void *cls, struct GNUNET_SET_Handle *copy)
-{
-  struct TaskEntry *task = (struct TaskEntry *) cls;
-  struct ConsensusSession *session = task->step->session;
-  struct SetEntry *set;
-
-  set = GNUNET_new (struct SetEntry);
-  set->h = copy;
-  set->key = task->cls.eval_rfn.output_set;
-
-  put_set (session, set);
-
-  task_start_eval_rfn (task);
-}
-
-
-/**
- * Take an input set and an input referendum, 
- * apply the referendum with a threshold to the input
- * set and store the result in the output set and/or output diff.
- */
-static void
-task_start_eval_rfn (struct TaskEntry *task)
-{
-  struct GNUNET_CONTAINER_MultiHashMapIterator *iter;
-  struct ReferendumEntry *input_rfn;
-  struct RfnElementInfo *ri;
-  struct SetEntry *output_set = NULL;
-  struct DiffEntry *output_diff = NULL;
-  struct SetChangeProgressCls *progress_cls;
-  struct EvalRfnCls *rcls = &task->cls.eval_rfn;
-  struct ConsensusSession *session = task->step->session;
-
-  /* Have at least one output */
-  GNUNET_assert ( (rcls->output_set.set_kind != SET_KIND_NONE) ||
-                  (rcls->output_diff.diff_kind != DIFF_KIND_NONE));
-
-  if (SET_KIND_NONE != rcls->output_set.set_kind)
-  {
-    /* We have a set output, thus the output set must
-       exist or copy it from the input set */
-    output_set = lookup_set (session, &rcls->output_set);
-    if (NULL == output_set)
-    {
-      struct SetEntry *input_set;
-
-      input_set = lookup_set (session, &rcls->input_set);
-      GNUNET_assert (NULL != input_set);
-      GNUNET_SET_copy_lazy (input_set->h,
-                            eval_rfn_copy_cb,
-                            task);
-      /* We'll be called again, this time with the
-         set ready. */
-      return;
-    }
-  }
-
-  if (DIFF_KIND_NONE != rcls->output_diff.diff_kind)
-  {
-    output_diff = lookup_diff (session, &rcls->output_diff);
-    if (NULL == output_diff)
-    {
-      output_diff = diff_create ();
-      output_diff->key = rcls->output_diff;
-      put_diff (session, output_diff);
-    }
-  }
-
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-              "Evaluating referendum in Task {%s}\n",
-              debug_str_task_key (&task->key));
-
-
-  progress_cls = GNUNET_new (struct SetChangeProgressCls);
-  progress_cls->task = task;
-
-  input_rfn = lookup_rfn (session, &rcls->input_rfn);
-
-  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))
-  {
-    int majority_vote = rfn_majority (session->num_peers, input_rfn, ri, rcls->threshold);
-    switch (majority_vote)
-    {
-      case VOTE_ADD:
-#ifdef GNUNET_EXTRA_LOGGING
-          GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-                      "P%u: referendum vote result: VOTE_ADD for element %s in task {%s} with"
-                      "output set {%s} and output diff {%s}\n",
-                      session->local_peer_idx,
-                      debug_str_element (ri->element),
-                      debug_str_task_key (&task->key),
-                      debug_str_set_key (&rcls->output_set),
-                      debug_str_diff_key (&rcls->output_diff));
-#endif
-        if (NULL != output_set)
-        {
-          progress_cls->num_pending++;
-          GNUNET_assert (GNUNET_OK ==
-                         GNUNET_SET_add_element (output_set->h,
-                                                 ri->element,
-                                                 eval_rfn_progress,
-                                                 progress_cls));
-        }
-        if (NULL != output_diff)
-        {
-          diff_insert (output_diff, 1, ri->element);
-        }
-        break;
-      case VOTE_CONTESTED:
-        if (NULL != output_set)
-          output_set->is_contested = GNUNET_YES;
-#ifdef GNUNET_EXTRA_LOGGING
-        GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-                    "P%u: referendum vote result: VOTE_CONTESTED for element %s in task {%s} with"
-                    "output set {%s} and output diff {%s}\n",
-                    session->local_peer_idx,
-                    debug_str_element (ri->element),
-                    debug_str_task_key (&task->key),
-                    debug_str_set_key (&rcls->output_set),
-                    debug_str_diff_key (&rcls->output_diff));
-#endif
-        /* fallthrough */
-      case VOTE_REMOVE:
-#ifdef GNUNET_EXTRA_LOGGING
-        if (VOTE_REMOVE == majority_vote)
-          GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-                      "P%u: referendum vote result: VOTE_REMOVE for element %s in task {%s} with"
-                      "output set {%s} and output diff {%s}\n",
-                      session->local_peer_idx,
-                      debug_str_element (ri->element),
-                      debug_str_task_key (&task->key),
-                      debug_str_set_key (&rcls->output_set),
-                      debug_str_diff_key (&rcls->output_diff));
-#endif
-        if (NULL != output_set)
-        {
-          progress_cls->num_pending++;
-          GNUNET_assert (GNUNET_OK ==
-                         GNUNET_SET_remove_element (output_set->h,
-                                                    ri->element,
-                                                    eval_rfn_progress,
-                                                    progress_cls));
-        }
-        if (NULL != output_diff)
-        {
-          diff_insert (output_diff, -1, ri->element);
-        }
-        break;
-      case VOTE_NONE:
-        GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-                    "referendum vote result: VOTE_NONE\n");
-        /* Nothing to do. */
-        break;
-      default:
-        /* not reached */
-        GNUNET_assert (0);
-    }
-  }
-  GNUNET_CONTAINER_multihashmap_iterator_destroy (iter);
-
-  if (progress_cls->num_pending == 0)
-  {
-    // call closure right now, no pending ops
-    GNUNET_free (progress_cls);
-    eval_rfn_done (task);
-  }
-}
-
-
-static void
-apply_diff_copy_cb (void *cls, struct GNUNET_SET_Handle *copy)
-{
-  struct TaskEntry *task = (struct TaskEntry *) cls;
-  struct ConsensusSession *session = task->step->session;
-  struct SetEntry *set;
-  struct ApplyDiffCls *diffop = &task->cls.apply_diff;
-
-  set = GNUNET_new (struct SetEntry);
-  set->h = copy;
-  set->key = diffop->output_set;
-
-  put_set (session, set);
-
-  task_start_apply_diff (task);
-}
-
-
-static void
-apply_diff_done (struct TaskEntry *task)
-{
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
-              "P%u: APPLY_DIFF done for task {%s}\n",
-              task->step->session->local_peer_idx, debug_str_task_key (&task->key));
-  finish_task (task);
-}
-
-
-static void
-apply_diff_progress (void *cls)
-{
-  struct SetChangeProgressCls *erc = cls;
-
-  GNUNET_assert (erc->num_pending > 0);
-
-  erc->num_pending--;
-
-  if (0 == erc->num_pending)
+    }
+  }
+  else
   {
-    struct TaskEntry *task = erc->task;
-    GNUNET_free (erc);
-    apply_diff_done (task);
+    /* We made an error while constructing the task graph. */
+    GNUNET_assert (0);
   }
 }
 
 
 static void
-task_start_apply_diff (struct TaskEntry *task)
+task_start_eval_echo (struct TaskEntry *task)
 {
-  struct SetEntry *output_set;
-  struct DiffEntry *input_diff;
   struct GNUNET_CONTAINER_MultiHashMapIterator *iter;
-  struct DiffElementInfo *di;
-  struct SetChangeProgressCls *progress_cls;
-  struct ApplyDiffCls *diffop = &task->cls.apply_diff;
+  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;
 
-  GNUNET_assert (diffop->output_set.set_kind != SET_KIND_NONE);
-  GNUNET_assert (diffop->input_diff.diff_kind != DIFF_KIND_NONE);
+  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;
+  }
 
-  input_diff = lookup_diff (session, &diffop->input_diff);
 
-  GNUNET_assert (NULL != input_diff);
+  {
+    // 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);
+  }
 
-  output_set = lookup_set (session, &diffop->output_set);
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "Evaluating referendum in Task {%s}\n",
+              debug_str_task_key (&task->key));
 
-  if (NULL == output_set)
-  {
-      struct SetEntry *input_set;
+  progress_cls = GNUNET_new (struct SetMutationProgressCls);
+  progress_cls->task = task;
 
-      input_set = lookup_set (session, &diffop->input_set);
-      GNUNET_assert (NULL != input_set);
-      GNUNET_SET_copy_lazy (input_set->h,
-                            apply_diff_copy_cb,
-                            task);
-      /* We'll be called again, this time with the
-         set ready. */
-      return;
-  }
+  rk_in = (struct RfnKey) { RFN_KIND_ECHO, task->key.repetition, task->key.leader };
+  input_rfn = lookup_rfn (session, &rk_in);
 
-  progress_cls = GNUNET_new (struct SetChangeProgressCls);
+  GNUNET_assert (NULL != input_rfn);
 
-  iter = GNUNET_CONTAINER_multihashmap_iterator_create (input_diff->changes);
+  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 **) &di))
+  while (GNUNET_YES ==
+         GNUNET_CONTAINER_multihashmap_iterator_next (iter,
+                                                      NULL,
+                                                      (const void **) &ri))
   {
-    if (di->weight > 0)
+    enum ReferendumVote majority_vote;
+    uint16_t majority_num;
+
+    rfn_majority (input_rfn, ri, &majority_num, &majority_vote);
+
+    if (majority_num < session->num_peers / 3)
     {
-      progress_cls->num_pending++;
-      GNUNET_assert (GNUNET_OK ==
-                     GNUNET_SET_remove_element (output_set->h,
-                                 di->element,
-                                 apply_diff_progress,
-                                 progress_cls));
+      /* 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;
     }
-    else if (di->weight < 0)
+
+    switch (majority_vote)
     {
-      progress_cls->num_pending++;
-      GNUNET_assert (GNUNET_OK ==
-                     GNUNET_SET_add_element (output_set->h,
-                                 di->element,
-                                 apply_diff_progress,
-                                 progress_cls));
+      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 (progress_cls->num_pending == 0)
+  if (0 == progress_cls->num_pending)
   {
     // call closure right now, no pending ops
     GNUNET_free (progress_cls);
-    apply_diff_done (task);
+    finish_task (task);
   }
 }
 
@@ -1958,39 +2298,6 @@ start_task (struct ConsensusSession *session, struct TaskEntry *task)
 }
 
 
-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",
-                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);
-}
 
 
 /*
@@ -2006,7 +2313,7 @@ run_ready_steps (struct ConsensusSession *session)
 
   while (NULL != step)
   {
-    if ( (GNUNET_NO == step->is_running) && (0 == step->pending_prereq) )
+    if ( (GNUNET_NO == step->is_running) && (0 == step->pending_prereq) && (GNUNET_NO == step->is_finished) )
     {
       size_t i;
 
@@ -2114,45 +2421,48 @@ peer_id_cmp (const void *h1, const void *h2)
 /**
  * Create the sorted list of peers for the session,
  * add the local peer if not in the join message.
+ *
+ * @param session session to initialize
+ * @param join_msg join message with the list of peers participating at the end
  */
 static void
 initialize_session_peer_list (struct ConsensusSession *session,
-                              struct GNUNET_CONSENSUS_JoinMessage *join_msg)
+                              const struct GNUNET_CONSENSUS_JoinMessage *join_msg)
 {
-  unsigned int local_peer_in_list;
-  uint32_t listed_peers;
-  const struct GNUNET_PeerIdentity *msg_peers;
-  unsigned int i;
-
-  GNUNET_assert (NULL != join_msg);
-
-  /* peers in the join message, may or may not include the local peer */
-  listed_peers = ntohl (join_msg->num_peers);
+  const struct GNUNET_PeerIdentity *msg_peers
+    = (const struct GNUNET_PeerIdentity *) &join_msg[1];
+  int local_peer_in_list;
 
-  session->num_peers = listed_peers;
-
-  msg_peers = (struct GNUNET_PeerIdentity *) &join_msg[1];
+  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 (i = 0; i < listed_peers; i++)
+  for (unsigned int i = 0; i < session->num_peers; i++)
   {
-    if (0 == memcmp (&msg_peers[i], &my_peer, sizeof (struct GNUNET_PeerIdentity)))
+    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++;
 
-  session->peers = GNUNET_malloc (session->num_peers * sizeof (struct GNUNET_PeerIdentity));
-
+  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;
 
-  memcpy (session->peers, msg_peers, listed_peers * sizeof (struct GNUNET_PeerIdentity));
-  qsort (session->peers, session->num_peers, sizeof (struct GNUNET_PeerIdentity), &peer_id_cmp);
+  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);
 }
 
 
@@ -2251,12 +2561,18 @@ set_listen_cb (void *cls,
   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, 
+
+  /* If the task hasn't been started yet,
      we wait for that until we commit. */
 
   if (GNUNET_YES == task->is_started)
@@ -2311,6 +2627,8 @@ install_step_timeouts (struct ConsensusSession *session)
   /* Given the fully constructed task graph
      with rounds for tasks, we can give the tasks timeouts. */
 
+  // unsigned int max_round;
+
   /* XXX: implement! */
 }
 
@@ -2355,7 +2673,7 @@ arrange_peers (uint16_t *p1, uint16_t *p2, uint16_t n)
 
 
 /**
- * Record @a dep as a dependency of @step.
+ * Record @a dep as a dependency of @step.
  */
 static void
 step_depend_on (struct Step *step, struct Step *dep)
@@ -2365,7 +2683,6 @@ step_depend_on (struct Step *step, struct Step *dep)
   GNUNET_assert (step != dep);
   GNUNET_assert (NULL != step);
   GNUNET_assert (NULL != dep);
-  // XXX: make rounds work
   GNUNET_assert (dep->round <= step->round);
 
 #ifdef GNUNET_EXTRA_LOGGING
@@ -2398,12 +2715,13 @@ step_depend_on (struct Step *step, struct Step *dep)
 
 
 static struct Step *
-create_step (struct ConsensusSession *session, int round)
+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);
@@ -2423,8 +2741,6 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
                                 struct Step *step_after)
 {
   uint16_t n = session->num_peers;
-  uint16_t t = n / 3;
-
   uint16_t me = session->local_peer_idx;
 
   uint16_t p1;
@@ -2444,15 +2760,13 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
 
   /* gcast step 1: leader disseminates */
 
-  step = create_step (session, round);
+  step = create_step (session, round, GNUNET_YES);
 
 #ifdef GNUNET_EXTRA_LOGGING
   GNUNET_asprintf (&step->debug_name, "disseminate leader %u rep %u", lead, rep);
 #endif
   step_depend_on (step, step_before);
 
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "P%d: Considering leader %d\n", session->local_peer_idx, lead);
-
   if (lead == me)
   {
     for (k = 0; k < n; k++)
@@ -2462,7 +2776,6 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
       p1 = me;
       p2 = k;
       arrange_peers (&p1, &p2, n);
-      GNUNET_log (GNUNET_ERROR_TYPE_INFO, "P%d: GC LEADER(1): %d %d %d %d\n", session->local_peer_idx, p1, p2, rep, lead);
       task = ((struct TaskEntry) {
         .step = step,
         .start = task_start_reconcile,
@@ -2492,10 +2805,9 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
     p1 = me;
     p2 = lead;
     arrange_peers (&p1, &p2, n);
-    GNUNET_log (GNUNET_ERROR_TYPE_INFO, "P%d: GC LEADER(2): %d %d %d %d\n", session->local_peer_idx, p1, p2, rep, lead);
     task = ((struct TaskEntry) {
       .step = step,
-      .key = (struct TaskKey) { PHASE_KIND_GRADECAST_LEADER, p1, p2, rep, lead},
+      .key = (struct TaskKey) { PHASE_KIND_GRADECAST_LEADER, p1, p2, rep, lead },
       .start = task_start_reconcile,
       .cancel = task_cancel_reconcile,
     });
@@ -2508,7 +2820,7 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
   /* gcast phase 2: echo */
   prev_step = step;
   round += 1;
-  step = create_step (session, round);
+  step = create_step (session, round, GNUNET_YES);
 #ifdef GNUNET_EXTRA_LOGGING
   GNUNET_asprintf (&step->debug_name, "echo leader %u rep %u", lead, rep);
 #endif
@@ -2532,7 +2844,7 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
 
   prev_step = step;
   /* Same round, since step only has local tasks */
-  step = create_step (session, round);
+  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
@@ -2542,17 +2854,13 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
   task = ((struct TaskEntry) {
     .key = (struct TaskKey) { PHASE_KIND_GRADECAST_ECHO_GRADE, -1, -1, rep, lead },
     .step = step,
-    .start = task_start_eval_rfn
+    .start = task_start_eval_echo
   });
-  task.cls.eval_rfn.input_set = (struct SetKey) { SET_KIND_LEADER_PROPOSAL, rep, lead },
-  task.cls.eval_rfn.input_rfn = (struct RfnKey) { RFN_KIND_ECHO, rep, lead },
-  task.cls.eval_rfn.output_set = (struct SetKey) { SET_KIND_ECHO_RESULT, rep, lead },
-  task.cls.eval_rfn.threshold = n - t,
   put_task (session->taskmap, &task);
 
   prev_step = step;
   round += 1;
-  step = create_step (session, round);
+  step = create_step (session, round, GNUNET_YES);
 #ifdef GNUNET_EXTRA_LOGGING
   GNUNET_asprintf (&step->debug_name, "confirm leader %u rep %u", lead, rep);
 #endif
@@ -2572,46 +2880,27 @@ construct_task_graph_gradecast (struct ConsensusSession *session,
     });
     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);
   }
 
   prev_step = step;
   /* Same round, since step only has local tasks */
-  step = create_step (session, round);
+  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);
 
-  // evaluate ConfirmationReferendum and
-  // apply it to the LeaderReferendum
-  // XXX: the diff should contain grading information
   task = ((struct TaskEntry) {
     .step = step,
     .key = (struct TaskKey) { PHASE_KIND_GRADECAST_CONFIRM_GRADE, -1, -1, rep, lead },
-    .start = task_start_eval_rfn,
-  });
-  task.cls.eval_rfn.input_rfn = (struct RfnKey) { RFN_KIND_ECHO, rep, lead };
-  task.cls.eval_rfn.output_diff = (struct DiffKey) { DIFF_KIND_LEADER_CONSENSUS, rep, lead };
-  put_task (session->taskmap, &task);
-
-
-  prev_step = step;
-  /* Same round, since step only has local tasks */
-  step = create_step (session, round);
-#ifdef GNUNET_EXTRA_LOGGING
-  GNUNET_asprintf (&step->debug_name, "gc apply, lead %u rep %u", lead, rep);
-#endif
-  step_depend_on (step, prev_step);
-
-  task = ((struct TaskEntry) {
-    .step = step,
-    .key = (struct TaskKey) { PHASE_KIND_GRADECAST_APPLY_RESULT, -1, -1, rep, lead },
-    .start = task_start_leader_apply,
+    .start = task_start_grade,
   });
-  task.cls.leader_apply.input_diff_1 = (struct DiffKey) { DIFF_KIND_LEADER_PROPOSAL, rep, lead };
-  task.cls.leader_apply.input_diff_2 = (struct DiffKey) { DIFF_KIND_LEADER_CONSENSUS, rep, lead };
-  task.cls.leader_apply.output_rfn = (struct RfnKey) { RFN_KIND_GRADECAST_RESULT, rep };
   put_task (session->taskmap, &task);
 
   step_depend_on (step_after, step);
@@ -2626,9 +2915,6 @@ construct_task_graph (struct ConsensusSession *session)
 
   uint16_t me = session->local_peer_idx;
 
-  uint16_t p1;
-  uint16_t p2;
-
   /* The task we're currently setting up. */
   struct TaskEntry task;
 
@@ -2645,14 +2931,14 @@ construct_task_graph (struct ConsensusSession *session)
   // XXX: introduce first step,
   // where we wait for all insert acks
   // from the set service
-  
+
   /* faster but brittle all-to-all */
 
   // XXX: Not implemented yet
 
   /* all-to-all step */
 
-  step = create_step (session, round);
+  step = create_step (session, round, GNUNET_NO);
 
 #ifdef GNUNET_EXTRA_LOGGING
   step->debug_name = GNUNET_strdup ("all to all");
@@ -2660,6 +2946,9 @@ construct_task_graph (struct ConsensusSession *session)
 
   for (i = 0; i < n; i++)
   {
+    uint16_t p1;
+    uint16_t p2;
+
     p1 = me;
     p2 = i;
     arrange_peers (&p1, &p2, n);
@@ -2675,11 +2964,42 @@ construct_task_graph (struct ConsensusSession *session)
     put_task (session->taskmap, &task);
   }
 
+  round += 1;
   prev_step = step;
-  step = NULL;
+  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);
+
+
+  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_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);
+  }
 
   round += 1;
 
+  prev_step = step;
+  step = NULL;
+
+
+
   /* Byzantine union */
 
   /* sequential repetitions of the gradecasts */
@@ -2689,7 +3009,7 @@ construct_task_graph (struct ConsensusSession *session)
     struct Step *step_rep_end;
 
     /* Every repetition is in a separate round. */
-    step_rep_start = create_step (session, 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
@@ -2698,7 +3018,7 @@ construct_task_graph (struct ConsensusSession *session)
 
     /* gradecast has three rounds */
     round += 3;
-    step_rep_end = create_step (session, round);
+    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
@@ -2707,16 +3027,11 @@ construct_task_graph (struct ConsensusSession *session)
     for (lead = 0; lead < n; lead++)
       construct_task_graph_gradecast (session, i, lead, step_rep_start, step_rep_end);
 
-    // TODO: add peers to ignore list, either here or
-    // already in the gradecast.
     task = ((struct TaskEntry) {
       .step = step_rep_end,
       .key = (struct TaskKey) { PHASE_KIND_APPLY_REP, -1, -1, i, -1},
-      .start = task_start_eval_rfn,
+      .start = task_start_apply_round,
     });
-    task.cls.eval_rfn.input_set = (struct SetKey) { SET_KIND_CURRENT, i };
-    task.cls.eval_rfn.input_rfn = (struct RfnKey) { RFN_KIND_GRADECAST_RESULT, i };
-    task.cls.eval_rfn.output_set = (struct SetKey) { SET_KIND_CURRENT, i + 1 };
     put_task (session->taskmap, &task);
 
     prev_step = step_rep_end;
@@ -2725,7 +3040,7 @@ construct_task_graph (struct ConsensusSession *session)
  /* 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);
+  step = create_step (session, round, GNUNET_NO);
 #ifdef GNUNET_EXTRA_LOGGING
   GNUNET_asprintf (&step->debug_name, "finish");
 #endif
@@ -2736,256 +3051,231 @@ construct_task_graph (struct ConsensusSession *session)
     .key = (struct TaskKey) { PHASE_KIND_FINISH, -1, -1, -1, -1 },
     .start = task_start_finish,
   });
-  task.cls.finish.input_set = (struct SetKey) { SET_KIND_CURRENT, t + 1 };
+  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))
+  {
+    GNUNET_break (0);
+    return GNUNET_SYSERR;
+  }
+  return GNUNET_OK;
+}
+
+
 /**
- * Initialize the session, continue receiving messages from the owning client
+ * Called when a client wants to join a consensus session.
  *
- * @param session the session to initialize
- * @param join_msg the join message from the client
+ * @param cls session of client that sent the message
+ * @param m message sent by the client
  */
 static void
-initialize_session (struct ConsensusSession *session,
-                    struct GNUNET_CONSENSUS_JoinMessage *join_msg)
+handle_client_join (void *cls,
+                    const struct GNUNET_CONSENSUS_JoinMessage *m)
 {
+  struct ConsensusSession *session = cls;
   struct ConsensusSession *other_session;
 
-  initialize_session_peer_list (session, join_msg);
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "session with %u peers\n", session->num_peers);
-  compute_global_id (session, &join_msg->session_id);
+  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.*/
-  other_session = sessions_head;
-  while (NULL != other_session)
+  for (other_session = sessions_head;
+       NULL != other_session;
+       other_session = other_session->next)
   {
-    if ((other_session != session) &&
-        (0 == GNUNET_CRYPTO_hash_cmp (&session->global_id, &other_session->global_id)))
-    {
-      //if (CONSENSUS_ROUND_FINISH != other_session->current_round)
-      //{
-      //  GNUNET_break (0);
-      //  destroy_session (session);
-      //  return;
-      //}
+    if ( (other_session != session) &&
+         (0 == GNUNET_CRYPTO_hash_cmp (&session->global_id,
+                                       &other_session->global_id)) )
       break;
-    }
-    other_session = other_session->next;
   }
 
-  session->conclude_deadline = GNUNET_TIME_absolute_ntoh (join_msg->deadline);
-  session->conclude_start = GNUNET_TIME_absolute_ntoh (join_msg->start);
-
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "consensus with timeout %ums created\n",
-              (GNUNET_TIME_absolute_get_difference (session->conclude_start, session->conclude_deadline)).rel_value_us / 1000);
-
-  session->local_peer_idx = get_peer_idx (&my_peer, session);
+  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);
-  session->set_listener = GNUNET_SET_listen (cfg, GNUNET_SET_OPERATION_UNION,
-                                             &session->global_id,
-                                             set_listen_cb, session);
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "%d is the local peer\n", session->local_peer_idx);
 
-  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);
+  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->h = GNUNET_SET_create (cfg,
+                                       GNUNET_SET_OPERATION_UNION);
     client_set->key = ((struct SetKey) { SET_KIND_CURRENT, 0, 0 });
-    put_set (session, client_set);
+    put_set (session,
+             client_set);
   }
 
-  session->peers_ignored = GNUNET_new_array (session->num_peers, int);
+  session->peers_blacklisted = GNUNET_new_array (session->num_peers,
+                                                 int);
 
   /* Just construct the task graph,
      but don't run anything until the client calls conclude. */
   construct_task_graph (session);
-
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "session %s initialized\n", GNUNET_h2s (&session->global_id));
+  GNUNET_SERVICE_client_continue (session->client);
 }
 
 
-static struct ConsensusSession *
-get_session_by_client (struct GNUNET_SERVER_Client *client)
+static void
+client_insert_done (void *cls)
 {
-  struct ConsensusSession *session;
-
-  session = sessions_head;
-  while (NULL != session)
-  {
-    if (session->client == client)
-      return session;
-    session = session->next;
-  }
-  return NULL;
+  // FIXME: implement
 }
 
 
 /**
- * Called when a client wants to join a consensus session.
+ * Called when a client performs an insert operation.
  *
- * @param cls unused
- * @param client client that sent the message
- * @param m message sent by the client
+ * @param cls client handle
+ * @param msg message sent by the client
+ * @return #GNUNET_OK (always well-formed)
  */
-static void
-client_join (void *cls,
-             struct GNUNET_SERVER_Client *client,
-             const struct GNUNET_MessageHeader *m)
-{
-  struct ConsensusSession *session;
-
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "join message sent by client\n");
-
-  session = get_session_by_client (client);
-  if (NULL != session)
-  {
-    GNUNET_break (0);
-    GNUNET_SERVER_receive_done (client, GNUNET_SYSERR);
-    return;
-  }
-  session = GNUNET_new (struct ConsensusSession);
-  session->client = client;
-  session->client_mq = GNUNET_MQ_queue_for_server_client (client);
-  GNUNET_CONTAINER_DLL_insert (sessions_head, sessions_tail, session);
-  initialize_session (session, (struct GNUNET_CONSENSUS_JoinMessage *) m);
-  GNUNET_SERVER_receive_done (client, GNUNET_OK);
-
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "join done\n");
-}
-
-
-static void
-client_insert_done (void *cls)
+static int
+check_client_insert (void *cls,
+                      const struct GNUNET_CONSENSUS_ElementMessage *msg)
 {
-  // FIXME: implement
+  return GNUNET_OK;
 }
 
 
 /**
  * Called when a client performs an insert operation.
  *
- * @param cls (unused)
- * @param client client handle
- * @param m message sent by the client
+ * @param cls client handle
+ * @param msg message sent by the client
  */
-void
-client_insert (void *cls,
-               struct GNUNET_SERVER_Client *client,
-               const struct GNUNET_MessageHeader *m)
+static void
+handle_client_insert (void *cls,
+                      const struct GNUNET_CONSENSUS_ElementMessage *msg)
 {
-  struct ConsensusSession *session;
-  struct GNUNET_CONSENSUS_ElementMessage *msg;
-  struct GNUNET_SET_Element *element;
+  struct ConsensusSession *session = cls;
   ssize_t element_size;
   struct GNUNET_SET_Handle *initial_set;
-
-  session = get_session_by_client (client);
-
-  if (NULL == session)
-  {
-    GNUNET_break (0);
-    GNUNET_SERVER_client_disconnect (client);
-    return;
-  }
+  struct ConsensusElement *ce;
 
   if (GNUNET_YES == session->conclude_started)
   {
     GNUNET_break (0);
-    GNUNET_SERVER_client_disconnect (client);
+    GNUNET_SERVICE_client_drop (session->client);
     return;
   }
 
-  msg = (struct GNUNET_CONSENSUS_ElementMessage *) m;
   element_size = ntohs (msg->header.size) - sizeof (struct GNUNET_CONSENSUS_ElementMessage);
-  if (element_size < 0)
-  {
-    GNUNET_break (0);
-    return;
-  }
+  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,
+  };
 
-  element = GNUNET_malloc (sizeof (struct GNUNET_SET_Element) + element_size);
-  element->element_type = msg->element_type;
-  element->size = element_size;
-  memcpy (&element[1], &msg[1], element_size);
-  element->data = &element[1];
   {
     struct SetKey key = { SET_KIND_CURRENT, 0, 0 };
     struct SetEntry *entry;
-    entry = lookup_set (session, &key);
+
+    entry = lookup_set (session,
+                        &key);
     GNUNET_assert (NULL != entry);
     initial_set = entry->h;
   }
+
   session->num_client_insert_pending++;
-  GNUNET_SET_add_element (initial_set, element, client_insert_done, session);
+  GNUNET_SET_add_element (initial_set,
+                          &element,
+                          &client_insert_done,
+                          session);
 
 #ifdef GNUNET_EXTRA_LOGGING
   {
-    struct GNUNET_HashCode hash;
-
-    GNUNET_SET_element_hash (element, &hash);
-
-    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "P%u: element %s added\n",
+    GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+                "P%u: element %s added\n",
                 session->local_peer_idx,
-                GNUNET_h2s (&hash));
+                debug_str_element (&element));
   }
 #endif
-
-  GNUNET_free (element);
-  GNUNET_SERVER_receive_done (client, GNUNET_OK);
+  GNUNET_free (ce);
+  GNUNET_SERVICE_client_continue (session->client);
 }
 
 
 /**
  * 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
  */
 static void
-client_conclude (void *cls,
-                 struct GNUNET_SERVER_Client *client,
-                 const struct GNUNET_MessageHeader *message)
+handle_client_conclude (void *cls,
+                        const struct GNUNET_MessageHeader *message)
 {
-  struct ConsensusSession *session;
-
-  session = get_session_by_client (client);
-  if (NULL == session)
-  {
-    /* client not found */
-    GNUNET_break (0);
-    GNUNET_SERVER_client_disconnect (client);
-    return;
-  }
+  struct ConsensusSession *session = cls;
 
   if (GNUNET_YES == session->conclude_started)
   {
     /* conclude started twice */
     GNUNET_break (0);
-    GNUNET_SERVER_client_disconnect (client);
-    destroy_session (session);
+    GNUNET_SERVICE_client_drop (session->client);
     return;
   }
-
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "conclude requested\n");
-
+  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG,
+              "conclude requested\n");
   session->conclude_started = GNUNET_YES;
-
   install_step_timeouts (session);
   run_ready_steps (session);
-
-
-  GNUNET_SERVER_receive_done (client, GNUNET_OK);
+  GNUNET_SERVICE_client_continue (session->client);
 }
 
 
@@ -2993,87 +3283,119 @@ client_conclude (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)
-{
-  while (NULL != sessions_head)
-    destroy_session (sessions_head);
-
-  GNUNET_log (GNUNET_ERROR_TYPE_DEBUG, "handled shutdown request\n");
-}
-
-
-/**
- * Clean up after a client after it is
- * disconnected (either by us or by itself)
- *
- * @param cls closure, unused
- * @param client the client to clean up after
- */
-void
-handle_client_disconnect (void *cls, struct GNUNET_SERVER_Client *client)
+shutdown_task (void *cls)
 {
-  struct ConsensusSession *session;
-
-  session = get_session_by_client (client);
-  if (NULL == session)
-    return;
-  // FIXME: destroy if we can
+  GNUNET_log (GNUNET_ERROR_TYPE_INFO,
+              "shutting down\n");
+  GNUNET_STATISTICS_destroy (statistics,
+                             GNUNET_NO);
+  statistics = NULL;
 }
 
 
-
 /**
  * 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)
-{
-  static const struct GNUNET_SERVER_MessageHandler server_handlers[] = {
-    {&client_conclude, NULL, GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_CONCLUDE,
-        sizeof (struct GNUNET_MessageHeader)},
-    {&client_insert, NULL, GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_INSERT, 0},
-    {&client_join, NULL, GNUNET_MESSAGE_TYPE_CONSENSUS_CLIENT_JOIN, 0},
-    {NULL, NULL, 0, 0}
-  };
-
+run (void *cls,
+     const struct GNUNET_CONFIGURATION_Handle *c,
+     struct GNUNET_SERVICE_Handle *service)
+{
   cfg = c;
-  srv = server;
-  if (GNUNET_OK != GNUNET_CRYPTO_get_peer_identity (cfg, &my_peer))
+  if (GNUNET_OK !=
+      GNUNET_CRYPTO_get_peer_identity (cfg,
+                                       &my_peer))
   {
-    GNUNET_log (GNUNET_ERROR_TYPE_ERROR, "could not retrieve host identity\n");
-    GNUNET_break (0);
+    GNUNET_log (GNUNET_ERROR_TYPE_ERROR,
+                "Could not retrieve host identity\n");
     GNUNET_SCHEDULER_shutdown ();
     return;
   }
-  GNUNET_SERVER_add_handlers (server, server_handlers);
-  GNUNET_SCHEDULER_add_delayed (GNUNET_TIME_UNIT_FOREVER_REL, &shutdown_task, NULL);
-  GNUNET_SERVER_disconnect_notify (server, handle_client_disconnect, NULL);
-  GNUNET_log (GNUNET_ERROR_TYPE_INFO, "consensus running\n");
+  statistics = GNUNET_STATISTICS_create ("consensus",
+                                         cfg);
+  GNUNET_SCHEDULER_add_shutdown (&shutdown_task,
+                                 NULL);
+}
+
+
+/**
+ * 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 (%d)\n", GNUNET_OK != ret);
-  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 */