[mpich-commits] [mpich] MPICH primary repository branch, master, updated. v3.2b1-3-g2e4af0c

Service Account noreply at mpich.org
Mon Mar 16 11:18:32 CDT 2015


This is an automated email from the git hooks/post-receive script. It was
generated because a ref change was pushed to the repository containing
the project "MPICH primary repository".

The branch, master has been updated
       via  2e4af0c162877e1d4e3e314e49efe9491b568237 (commit)
       via  29d32dd778a0814e499690bc2eb4f26002b0f7fa (commit)
       via  694490d89a7b09654f010e66b05eb9381b1f5937 (commit)
      from  2524cea29f887df330259ad53706a16ed83ac869 (commit)

Those revisions listed above that are new to this repository have
not appeared on any other notification email; so we list those
revisions in full, below.

- Log -----------------------------------------------------------------
http://git.mpich.org/mpich.git/commitdiff/2e4af0c162877e1d4e3e314e49efe9491b568237

commit 2e4af0c162877e1d4e3e314e49efe9491b568237
Author: Wesley Bland <wbland at anl.gov>
Date:   Wed Mar 11 11:00:46 2015 -0500

    Remove fixed size variable usage
    
    This code was using uint32_t as a fixed size variable to simplify the
    code, but we don't currently require C99. The patch removes that usage
    and does everything with int's and more math.
    
    Fixes #2245
    
    Signed-off-by: Antonio J. Pena <apenya at mcs.anl.gov>

diff --git a/src/mpid/ch3/src/mpid_comm_get_all_failed_procs.c b/src/mpid/ch3/src/mpid_comm_get_all_failed_procs.c
index 015ddd9..b2cf6bb 100644
--- a/src/mpid/ch3/src/mpid_comm_get_all_failed_procs.c
+++ b/src/mpid/ch3/src/mpid_comm_get_all_failed_procs.c
@@ -12,55 +12,59 @@
 #endif
 
 /* Generates a bitarray based on orig_comm where all procs in group are marked with 1 */
-static int *group_to_bitarray(MPID_Group *group, MPID_Comm *orig_comm) {
-    uint32_t *bitarray, mask;
-    int bitarray_size = (orig_comm->local_size / 8) + (orig_comm->local_size % 8 ? 1 : 0);
+static void group_to_bitarray(MPID_Group *group, MPID_Comm *orig_comm, int **bitarray, int *bitarray_size) {
+    int mask;
     int *group_ranks, *comm_ranks, i, index;
 
-    bitarray = (int *) MPIU_Malloc(sizeof(int) * bitarray_size);
+    /* Calculate the bitarray size in ints and allocate space */
+    *bitarray_size = (orig_comm->local_size / (8 * sizeof(int)) + (orig_comm->local_size % (8 * sizeof(int)) ? 1 : 0));
+    *bitarray = (int *) MPIU_Malloc(sizeof(int) * *bitarray_size);
 
+    /* If the group is empty, return an empty bitarray. */
     if (group == MPID_Group_empty) {
-        for (i = 0; i < bitarray_size; i++) bitarray[i] = 0;
-        return bitarray;
+        for (i = 0; i < *bitarray_size; i++) *bitarray[i] = 0;
+        return;
     }
 
+    /* Get the ranks of group in orig_comm */
     group_ranks = (int *) MPIU_Malloc(sizeof(int) * group->size);
     comm_ranks = (int *) MPIU_Malloc(sizeof(int) * group->size);
 
     for (i = 0; i < group->size; i++) group_ranks[i] = i;
-    for (i = 0; i < bitarray_size; i++) bitarray[i] = 0;
+    for (i = 0; i < *bitarray_size; i++) *bitarray[i] = 0;
 
     MPIR_Group_translate_ranks_impl(group, group->size, group_ranks,
                                     orig_comm->local_group, comm_ranks);
 
+    /* For each process in the group, shift a bit to the correct location and
+     * add it to the bitarray. */
     for (i = 0; i < group->size ; i++) {
         if (comm_ranks[i] == MPI_UNDEFINED) continue;
-        index = comm_ranks[i] / 32;
-        mask = 0x80000000 >> comm_ranks[i] % 32;
-        bitarray[index] |= mask;
+        index = comm_ranks[i] / (sizeof(int) * 8);
+        mask = 0x1 << comm_ranks[i] % (sizeof(int) * 8);
+        *bitarray[index] |= mask;
     }
 
     MPIU_Free(group_ranks);
     MPIU_Free(comm_ranks);
-
-    return bitarray;
 }
 
 /* Generates an MPID_Group from a bitarray */
-static MPID_Group *bitarray_to_group(MPID_Comm *comm_ptr, uint32_t *bitarray)
+static MPID_Group *bitarray_to_group(MPID_Comm *comm_ptr, int *bitarray)
 {
     MPID_Group *ret_group;
     MPID_Group *comm_group;
     UT_array *ranks_array;
     int i, found = 0;
 
+    /* Create a utarray to make storing the ranks easier */
     utarray_new(ranks_array, &ut_int_icd);
 
     MPIR_Comm_group_impl(comm_ptr, &comm_group);
 
     /* Converts the bitarray into a utarray */
     for (i = 0; i < comm_ptr->local_size; i++) {
-        if (bitarray[i/32] & (0x80000000 >> (i % 32))) {
+        if (bitarray[i / (sizeof(int) * 8)] & (0x1 << (i % (sizeof(int) * 8)))) {
             utarray_push_back(ranks_array, &i);
             found++;
         }
@@ -87,7 +91,7 @@ int MPID_Comm_get_all_failed_procs(MPID_Comm *comm_ptr, MPID_Group **failed_grou
     int mpi_errno = MPI_SUCCESS, ret_errno;
     mpir_errflag_t errflag = MPIR_ERR_NONE;
     int i, j, bitarray_size;
-    uint32_t *bitarray, *remote_bitarray;
+    int *bitarray, *remote_bitarray;
     MPID_Group *local_fail;
     MPIDI_STATE_DECL(MPID_STATE_MPID_COMM_GET_ALL_FAILED_PROCS);
 
@@ -104,9 +108,8 @@ int MPID_Comm_get_all_failed_procs(MPID_Comm *comm_ptr, MPID_Group **failed_grou
     if (mpi_errno) MPIU_ERR_POP(mpi_errno);
 
     /* Generate a bitarray based on the list of failed procs */
-    bitarray = group_to_bitarray(local_fail, comm_ptr);
-    bitarray_size = (comm_ptr->local_size / 8) + (comm_ptr->local_size % 8 ? 1 : 0);
-    remote_bitarray = MPIU_Malloc(sizeof(uint32_t) * bitarray_size);
+    group_to_bitarray(local_fail, comm_ptr, &bitarray, &bitarray_size);
+    remote_bitarray = MPIU_Malloc(sizeof(int) * bitarray_size);
     if (local_fail != MPID_Group_empty)
         MPIR_Group_release(local_fail);
 
@@ -115,7 +118,7 @@ int MPID_Comm_get_all_failed_procs(MPID_Comm *comm_ptr, MPID_Group **failed_grou
     if (comm_ptr->rank == 0) {
         for (i = 1; i < comm_ptr->local_size; i++) {
             /* Get everyone's list of failed processes to aggregate */
-            ret_errno = MPIC_Recv(remote_bitarray, bitarray_size, MPI_UINT32_T,
+            ret_errno = MPIC_Recv(remote_bitarray, bitarray_size, MPI_INT,
                 i, tag, comm_ptr, MPI_STATUS_IGNORE, &errflag);
             if (ret_errno) continue;
 
@@ -129,7 +132,7 @@ int MPID_Comm_get_all_failed_procs(MPID_Comm *comm_ptr, MPID_Group **failed_grou
 
         for (i = 1; i < comm_ptr->local_size; i++) {
             /* Send the list to each rank to be processed locally */
-            ret_errno = MPIC_Send(bitarray, bitarray_size, MPI_UINT32_T, i,
+            ret_errno = MPIC_Send(bitarray, bitarray_size, MPI_INT, i,
                 tag, comm_ptr, &errflag);
             if (ret_errno) continue;
         }
@@ -138,11 +141,11 @@ int MPID_Comm_get_all_failed_procs(MPID_Comm *comm_ptr, MPID_Group **failed_grou
         *failed_group = bitarray_to_group(comm_ptr, bitarray);
     } else {
         /* Send my bitarray to rank 0 */
-        mpi_errno = MPIC_Send(bitarray, bitarray_size, MPI_UINT32_T, 0,
+        mpi_errno = MPIC_Send(bitarray, bitarray_size, MPI_INT, 0,
             tag, comm_ptr, &errflag);
 
         /* Get the resulting bitarray back from rank 0 */
-        mpi_errno = MPIC_Recv(remote_bitarray, bitarray_size, MPI_UINT32_T, 0,
+        mpi_errno = MPIC_Recv(remote_bitarray, bitarray_size, MPI_INT, 0,
             tag, comm_ptr, MPI_STATUS_IGNORE, &errflag);
 
         /* Convert the bitarray into a group */

http://git.mpich.org/mpich.git/commitdiff/29d32dd778a0814e499690bc2eb4f26002b0f7fa

commit 29d32dd778a0814e499690bc2eb4f26002b0f7fa
Author: Wesley Bland <wbland at anl.gov>
Date:   Wed Mar 11 10:52:41 2015 -0500

    Remove MPID_Comm_failed_bitarray
    
    This is another function that is no longer used as it was replaced by a
    static function instead. This also removes an internal test that is no
    longer useful for this code.
    
    Signed-off-by: Antonio J. Pena <apenya at mcs.anl.gov>

diff --git a/src/include/mpiimpl.h b/src/include/mpiimpl.h
index 070d19b..1e18a17 100644
--- a/src/include/mpiimpl.h
+++ b/src/include/mpiimpl.h
@@ -2803,21 +2803,6 @@ int MPID_Comm_failure_ack(MPID_Comm *comm);
 int MPID_Comm_failure_get_acked(MPID_Comm *comm, MPID_Group **failed_group_ptr);
 
 /*@
-  MPID_Comm_failed_bitarray - MPID function to get the bitarray including all of the failed processes
-
-  Input Parameters:
-. comm - communicator
-. acked - true if bitarray should contain only acked procs
-
-  Output Parameter:
-. bitarray - Bit array containing all of the failed processes in comm
-
-  Return Value:
-  'MPI_SUCCESS' or a valid MPI error code.
-@*/
-int MPID_Comm_failed_bitarray(MPID_Comm *comm, uint32_t **bitarray, int acked);
-
-/*@
   MPID_Comm_get_all_failed_procs - Constructs a group of failed processes that it uniform over a communicator
 
   Input Parameters:
diff --git a/src/mpid/ch3/src/mpid_comm_failure_ack.c b/src/mpid/ch3/src/mpid_comm_failure_ack.c
index 377a831..e1938e1 100644
--- a/src/mpid/ch3/src/mpid_comm_failure_ack.c
+++ b/src/mpid/ch3/src/mpid_comm_failure_ack.c
@@ -74,81 +74,6 @@ fn_fail:
 }
 
 #undef FUNCNAME
-#define FUNCNAME MPID_Comm_failed_bitarray
-#undef FCNAME
-#define FCNAME MPIU_QUOTE(FUNCNAME)
-int MPID_Comm_failed_bitarray(MPID_Comm *comm_ptr, uint32_t **bitarray, int acked)
-{
-    int mpi_errno = MPI_SUCCESS;
-    int size, i;
-    uint32_t bit;
-    int *failed_procs, *group_procs;
-    MPID_Group *failed_group, *comm_group;
-    MPIU_CHKLMEM_DECL(2);
-    MPIDI_STATE_DECL(MPID_STATE_COMM_FAILED_BITARRAY);
-
-    MPIDI_FUNC_ENTER(MPID_STATE_COMM_FAILED_BITARRAY);
-
-    /* TODO - Fix this for intercommunicators */
-    size = comm_ptr->local_size;
-
-    /* We can fit sizeof(uint32_t) * 8 ranks in one uint64_t so divide the
-     * size by that */
-    /* This buffer will be handed back to the calling function so we use a
-     * "real" malloc here and expect the caller to free the buffer later. The
-     * other buffers in this function are temporary and will be automatically
-     * cleaned up at the end of the function. */
-    *bitarray = (uint32_t *) MPIU_Malloc(sizeof(uint32_t) * (size / (sizeof(uint32_t) * 8)+1));
-    if (!(*bitarray)) {
-        fprintf(stderr, "Could not allocate space for bitarray\n");
-        PMPI_Abort(MPI_COMM_WORLD, 1);
-    }
-    for (i = 0; i <= size/(sizeof(uint32_t)*8); i++) *bitarray[i] = 0;
-
-    mpi_errno = MPIDI_CH3U_Check_for_failed_procs();
-    if (mpi_errno) MPIU_ERR_POP(mpi_errno);
-
-    if (acked)
-        MPIDI_CH3U_Get_failed_group(comm_ptr->dev.last_ack_rank, &failed_group);
-    else
-        MPIDI_CH3U_Get_failed_group(-2, &failed_group);
-
-    if (failed_group == MPID_Group_empty) goto fn_exit;
-
-
-    MPIU_CHKLMEM_MALLOC(group_procs, int *, sizeof(int)*failed_group->size, mpi_errno, "group_procs");
-    for (i = 0; i < failed_group->size; i++) group_procs[i] = i;
-    MPIU_CHKLMEM_MALLOC(failed_procs, int *, sizeof(int)*failed_group->size, mpi_errno, "failed_procs");
-
-    MPIR_Comm_group_impl(comm_ptr, &comm_group);
-
-    MPIR_Group_translate_ranks_impl(failed_group, failed_group->size, group_procs, comm_group, failed_procs);
-
-    /* The bits will actually be ordered in decending order rather than
-     * ascending. This is purely for readability since it makes no practical
-     * difference. So if the bits look like this:
-     *
-     * 10001100 01001000 00000000 00000001
-     *
-     * Then processes 1, 5, 6, 9, 12, and 32 have failed. */
-    for (i = 0; i < failed_group->size; i++) {
-        bit = 0x80000000;
-        bit >>= failed_procs[i] % (sizeof(uint32_t) * 8);
-
-        *bitarray[failed_procs[i] / (sizeof(uint32_t) * 8)] |= bit;
-    }
-
-    MPIR_Group_free_impl(comm_group);
-
-  fn_exit:
-    MPIU_CHKLMEM_FREEALL();
-    MPIDI_FUNC_EXIT(MPID_STATE_COMM_FAILED_BITARRAY);
-    return mpi_errno;
-  fn_fail:
-    goto fn_exit;
-}
-
-#undef FUNCNAME
 #define FUNCNAME MPID_Comm_AS_enabled
 #undef FCNAME
 #define FCNAME MPIU_QUOTE(FUNCNAME)
diff --git a/test/mpid/ch3/failed_bitmask.c b/test/mpid/ch3/failed_bitmask.c
deleted file mode 100644
index 51518f8..0000000
--- a/test/mpid/ch3/failed_bitmask.c
+++ /dev/null
@@ -1,59 +0,0 @@
-
-/* -*- Mode: C; c-basic-offset:4 ; indent-tabs-mode:nil ; -*- */
-/*
- *  (C) 2001 by Argonne National Laboratory.
- *      See COPYRIGHT in top-level directory.
- */
-
-#include <stdio.h>
-
-#include "mpidimpl.h"
-
-int main(int argc, char **argv)
-{
-    int rc, size, rank, ec;
-    MPID_Comm *comm_ptr;
-    uint32_t *mask;
-
-    MPI_Init(&argc, &argv);
-
-    MPI_Comm_size(MPI_COMM_WORLD, &size);
-    MPI_Comm_rank(MPI_COMM_WORLD, &rank);
-
-    MPI_Comm_set_errhandler(MPI_COMM_WORLD, MPI_ERRORS_RETURN);
-
-    if (size != 16) {
-        fprintf(stderr, "Requires 16 ranks\n");
-        exit(1);
-    }
-
-    if (rank == 1  ||
-        rank == 5  ||
-        rank == 6  ||
-        rank == 9  ||
-        rank == 12)
-        exit(1);
-
-    rc = MPI_Barrier(MPI_COMM_WORLD);
-    ec = MPI_Error_class(rc, &ec);
-    if (MPI_SUCCESS == rc) {
-        fprintf(stderr, "[%d] ERROR CLASS: %d\n", rank, rc);
-    }
-
-    MPID_Comm_get_ptr(MPI_COMM_WORLD, comm_ptr);
-
-    MPID_Comm_failed_bitarray(comm_ptr, &mask, 0);
-
-    if (mask[0] != (uint32_t) 0x46480000) {
-        fprintf(stderr, "[%d] Unexpected failure bitmask: 0x%x\n", rank, mask[0]);
-        exit(1);
-    } else {
-        fprintf(stdout, " No errors\n");
-    }
-
-    MPIU_Free(mask);
-
-    MPI_Finalize();
-
-    return 0;
-}

http://git.mpich.org/mpich.git/commitdiff/694490d89a7b09654f010e66b05eb9381b1f5937

commit 694490d89a7b09654f010e66b05eb9381b1f5937
Author: Wesley Bland <wbland at anl.gov>
Date:   Wed Mar 11 10:45:17 2015 -0500

    Remove unused version of MPID_Comm_agree
    
    Originally this function was implemented in the CH3 layer, but it was
    moved up to the MPI layer as an MPIR function. The old MPID version
    doesn't need to exist anymore.
    
    Signed-off-by: Antonio J. Pena <apenya at mcs.anl.gov>

diff --git a/src/include/mpiimpl.h b/src/include/mpiimpl.h
index cc1a457..070d19b 100644
--- a/src/include/mpiimpl.h
+++ b/src/include/mpiimpl.h
@@ -2845,23 +2845,6 @@ int MPID_Comm_get_all_failed_procs(MPID_Comm *comm_ptr, MPID_Group **failed_grou
 int MPID_Comm_revoke(MPID_Comm *comm, int is_remote);
 
 /*@
-  MPID_Comm_agree - MPID implementation of the last phase of the agreement
-
-  Input Parameters:
-. comm - communicator
-. bitarray - Bit array of all of the failures that have been discovered in comm
-. flag - flag input for agree from MPIX_Comm_agree
-. new_fail - If there is a new failure that we need to propagate, this should be true
-
-  Output Parameters:
-. flag - Bitwise AND of all of the flag input values
-
-  Return Value:
-  'MPI_SUCCESS' or a valid MPI error code.
-@*/
-int MPID_Comm_agree(MPID_Comm *comm, uint32_t *bitarray, int *flag, mpir_errflag_t new_fail);
-
-/*@
   MPID_Send - MPID entry point for MPI_Send
 
   Notes:
diff --git a/src/mpid/ch3/src/Makefile.mk b/src/mpid/ch3/src/Makefile.mk
index fd576c9..71e8d6d 100644
--- a/src/mpid/ch3/src/Makefile.mk
+++ b/src/mpid/ch3/src/Makefile.mk
@@ -35,7 +35,6 @@ mpi_core_sources +=                          \
     src/mpid/ch3/src/mpid_comm_failure_ack.c               \
     src/mpid/ch3/src/mpid_comm_get_all_failed_procs.c      \
     src/mpid/ch3/src/mpid_comm_revoke.c                    \
-    src/mpid/ch3/src/mpid_comm_agree.c                     \
     src/mpid/ch3/src/mpid_finalize.c                       \
     src/mpid/ch3/src/mpid_get_universe_size.c              \
     src/mpid/ch3/src/mpid_getpname.c                       \
diff --git a/src/mpid/ch3/src/mpid_comm_agree.c b/src/mpid/ch3/src/mpid_comm_agree.c
deleted file mode 100644
index ca0273e..0000000
--- a/src/mpid/ch3/src/mpid_comm_agree.c
+++ /dev/null
@@ -1,120 +0,0 @@
-/* -*- Mode: C; c-basic-offset:4 ; indent-tabs-mode:nil ; -*- */
-/*
- *  (C) 2011 by Argonne National Laboratory.
- *      See COPYRIGHT in top-level directory.
- */
-
-#include "mpidimpl.h"
-
-static int get_parent(int rank, uint32_t *bitarray)
-{
-    int parent = -1;
-    int failed = 1;
-    uint32_t mask;
-
-    while (failed) {
-        mask = 0x80000000;
-        parent = rank == 0 ? -1: (rank - 1) / 2;
-
-        /* Check whether the process is in the failed group */
-        if (parent != -1) {
-            mask >>= parent % (sizeof(uint32_t) * 8);
-            failed = bitarray[parent / (sizeof(uint32_t) * 8)] & mask;
-            if (failed) {
-                rank = parent;
-            }
-        } else failed = 0;
-    }
-
-    return parent;
-}
-
-static void get_children(int rank, int size, uint32_t *bitarray, int *children, int *nchildren)
-{
-    int i;
-    int child;
-
-    for (i = 1; i <= 2; i++) {
-        /* Calculate the child */
-        child = 2 * rank + i;
-        if (child >= size) child = -1;
-
-        /* Check if the child is alive. If not, call get_children on the child
-         * to inherit its children */
-        if (child != -1) {
-            if (bitarray[child / (sizeof(uint32_t) * 8)] & (0x80000000 >> (child % (sizeof(uint32_t) * 8)))) {
-                get_children(child, size, bitarray, children, nchildren);
-            } else {
-                children[*nchildren] = child;
-                (*nchildren)++;
-            }
-        }
-    }
-}
-
-#undef FUNCNAME
-#define FUNCNAME MPID_Comm_agree
-#undef FCNAME
-#define FCNAME MPIU_QUOTE(FUNCNAME)
-int MPID_Comm_agree(MPID_Comm *comm_ptr, uint32_t *bitarray, int *flag, mpir_errflag_t new_fail)
-{
-    int mpi_errno = MPI_SUCCESS;
-    int *children, nchildren = 0, parent;
-    int i;
-    mpir_errflag_t errflag = new_fail;
-    int tmp_flag;
-
-    MPIDI_STATE_DECL(MPID_STATE_MPID_COMM_AGREE);
-    MPIDI_FUNC_ENTER(MPID_STATE_MPID_COMM_AGREE);
-
-    children = (int *) MPIU_Malloc(sizeof(int) * ((comm_ptr->local_size) / 2));
-
-    /* Calculate my parent and children */
-    parent = get_parent(comm_ptr->rank, bitarray);
-    get_children(comm_ptr->rank, comm_ptr->local_size, bitarray, children, &nchildren);
-
-    /* Get a flag value from each of my children */
-    for (i = 0; i < nchildren; i++) {
-        if (children[i] == -1) continue;
-        mpi_errno = MPIC_Recv(&tmp_flag, 1, MPI_INT, children[i], MPIR_AGREE_TAG,
-                comm_ptr, MPI_STATUS_IGNORE, &errflag);
-        if (mpi_errno) return mpi_errno;
-        if (errflag) new_fail = 1;
-
-        *flag &= tmp_flag;
-    }
-
-    /* If I'm not the root */
-    if (-1 != parent) {
-        /* Send my message to my parent */
-        mpi_errno = MPIC_Send(flag, 1, MPI_INT, parent, MPIR_AGREE_TAG,
-                comm_ptr, &errflag);
-        if (mpi_errno) return mpi_errno;
-
-        /* Receive the result from my parent */
-        mpi_errno = MPIC_Recv(flag, 1, MPI_INT, parent, MPIR_AGREE_TAG,
-                comm_ptr, MPI_STATUS_IGNORE, &errflag);
-        if (mpi_errno) return mpi_errno;
-        if (errflag) new_fail = 1;
-    }
-
-    /* Send my flag value to my children */
-    for (i = 0; i < nchildren; i++) {
-        if (children[i] == -1) continue;
-        mpi_errno = MPIC_Send(flag, 1, MPI_INT, children[i], MPIR_AGREE_TAG,
-                comm_ptr, &errflag);
-        if (mpi_errno) return mpi_errno;
-    }
-
-    MPIU_DBG_MSG_D(CH3_OTHER, VERBOSE, "New failure: %d", new_fail);
-
-    MPIU_ERR_CHKANDJUMP1(new_fail, mpi_errno, MPIX_ERR_PROC_FAILED, "**mpix_comm_agree", "**mpix_comm_agree %C", comm_ptr);
-
-    MPIU_Free(children);
-
-  fn_exit:
-    MPIDI_FUNC_EXIT(MPID_STATE_MPID_COMM_AGREE);
-    return mpi_errno;
-  fn_fail:
-    goto fn_exit;
-}
diff --git a/src/mpid/pamid/src/misc/mpid_unimpl.c b/src/mpid/pamid/src/misc/mpid_unimpl.c
index 155b700..63c4c7c 100644
--- a/src/mpid/pamid/src/misc/mpid_unimpl.c
+++ b/src/mpid/pamid/src/misc/mpid_unimpl.c
@@ -84,12 +84,6 @@ int MPID_Comm_failure_get_acked(MPID_Comm *comm_ptr, MPID_Group **failed_group_p
   return 0;
 }
 
-int MPID_Comm_agree(MPID_Comm *comm_ptr, uint32_t *bitarray, int *flag, mpir_errflag_t new_fail)
-{
-  MPID_abort();
-  return 0;
-}
-
 int MPID_Comm_get_all_failed_procs(MPID_Comm *comm_ptr, MPID_Group **failed_group, int tag)
 {
   MPID_abort();

-----------------------------------------------------------------------

Summary of changes:
 src/include/mpiimpl.h                             |   32 ------
 src/mpid/ch3/src/Makefile.mk                      |    1 -
 src/mpid/ch3/src/mpid_comm_agree.c                |  120 ---------------------
 src/mpid/ch3/src/mpid_comm_failure_ack.c          |   75 -------------
 src/mpid/ch3/src/mpid_comm_get_all_failed_procs.c |   47 +++++----
 src/mpid/pamid/src/misc/mpid_unimpl.c             |    6 -
 test/mpid/ch3/failed_bitmask.c                    |   59 ----------
 7 files changed, 25 insertions(+), 315 deletions(-)
 delete mode 100644 src/mpid/ch3/src/mpid_comm_agree.c
 delete mode 100644 test/mpid/ch3/failed_bitmask.c


hooks/post-receive
-- 
MPICH primary repository


More information about the commits mailing list