]> git.kernelconcepts.de Git - karo-tx-linux.git/commitdiff
Merge git://git.kernel.org/pub/scm/linux/kernel/git/bunk/trivial
authorLinus Torvalds <torvalds@g5.osdl.org>
Sun, 26 Mar 2006 17:41:18 +0000 (09:41 -0800)
committerLinus Torvalds <torvalds@g5.osdl.org>
Sun, 26 Mar 2006 17:41:18 +0000 (09:41 -0800)
* git://git.kernel.org/pub/scm/linux/kernel/git/bunk/trivial:
  drivers/char/ftape/lowlevel/fdc-io.c: Correct a comment
  Kconfig help: MTD_JEDECPROBE already supports Intel
  Remove ugly debugging stuff
  do_mounts.c: Minor ROOT_DEV comment cleanup
  BUG_ON() Conversion in drivers/s390/block/dasd_devmap.c
  BUG_ON() Conversion in mm/mempool.c
  BUG_ON() Conversion in mm/memory.c
  BUG_ON() Conversion in kernel/fork.c
  BUG_ON() Conversion in ipc/sem.c
  BUG_ON() Conversion in fs/ext2/
  BUG_ON() Conversion in fs/hfs/
  BUG_ON() Conversion in fs/dcache.c
  BUG_ON() Conversion in fs/buffer.c
  BUG_ON() Conversion in input/serio/hp_sdc_mlc.c
  BUG_ON() Conversion in md/dm-table.c
  BUG_ON() Conversion in md/dm-path-selector.c
  BUG_ON() Conversion in drivers/isdn
  BUG_ON() Conversion in drivers/char
  BUG_ON() Conversion in drivers/mtd/

26 files changed:
drivers/char/epca.c
drivers/char/ftape/lowlevel/fdc-io.c
drivers/char/tty_io.c
drivers/input/serio/hp_sdc_mlc.c
drivers/isdn/hisax/hisax_fcpcipnp.c
drivers/isdn/hisax/hisax_isac.c
drivers/isdn/hisax/st5481_b.c
drivers/isdn/hisax/st5481_d.c
drivers/isdn/i4l/isdn_ppp.c
drivers/md/dm-path-selector.c
drivers/md/dm-table.c
drivers/mtd/chips/Kconfig
drivers/mtd/maps/dilnetpc.c
drivers/mtd/mtd_blkdevs.c
drivers/mtd/mtdconcat.c
drivers/s390/block/dasd_devmap.c
fs/buffer.c
fs/dcache.c
fs/ext2/dir.c
fs/hfs/bnode.c
fs/hfs/btree.c
init/do_mounts.c
ipc/sem.c
kernel/fork.c
mm/memory.c
mm/mempool.c

index 765c5c108bf4f532619724eab156d3bbf3694bda..9cad8501d62c9fca6a93656c204bb1dea1e09a15 100644 (file)
@@ -486,8 +486,7 @@ static void pc_close(struct tty_struct * tty, struct file * filp)
                } /* End channel is open more than once */
 
                /* Port open only once go ahead with shutdown & reset */
-               if (ch->count < 0)
-                       BUG();
+               BUG_ON(ch->count < 0);
 
                /* ---------------------------------------------------------------
                        Let the rest of the driver know the channel is being closed.
index b2e0928e84288b6a392e7951fd3724649a54fd27..093fdf98b19a999dddc9b8ebe1dfe87dd4a2ad15 100644 (file)
@@ -607,7 +607,7 @@ void fdc_reset(void)
 
        fdc_mode = fdc_idle;
 
-       /*  maybe the cli()/sti() pair is not necessary, BUT:
+       /*  maybe the spin_lock_irq* pair is not necessary, BUT:
         *  the following line MUST be here. Otherwise fdc_interrupt_wait()
         *  won't wait. Note that fdc_reset() is called from 
         *  ftape_dumb_stop() when the fdc is busy transferring data. In this
index 48d795bb8c4b7a33ec4d4a3bd81ea3537aa6cec9..811dadb9ce3ed1204437126742a3b170cabfcaa9 100644 (file)
@@ -543,14 +543,12 @@ void tty_ldisc_put(int disc)
        struct tty_ldisc *ld;
        unsigned long flags;
        
-       if (disc < N_TTY || disc >= NR_LDISCS)
-               BUG();
+       BUG_ON(disc < N_TTY || disc >= NR_LDISCS);
                
        spin_lock_irqsave(&tty_ldisc_lock, flags);
        ld = &tty_ldiscs[disc];
-       if(ld->refcount == 0)
-               BUG();
-       ld->refcount --;
+       BUG_ON(ld->refcount == 0);
+       ld->refcount--;
        module_put(ld->owner);
        spin_unlock_irqrestore(&tty_ldisc_lock, flags);
 }
@@ -645,8 +643,7 @@ void tty_ldisc_deref(struct tty_ldisc *ld)
 {
        unsigned long flags;
 
-       if(ld == NULL)
-               BUG();
+       BUG_ON(ld == NULL);
                
        spin_lock_irqsave(&tty_ldisc_lock, flags);
        if(ld->refcount == 0)
index 1c9426fd5205665ff0ac45ba9ef35321489d2680..aa4a8a4ccfdbed17d4c9ce5c4c58ba32cb45f3cc 100644 (file)
@@ -270,9 +270,10 @@ static void hp_sdc_mlc_out (hil_mlc *mlc) {
 
  do_control:
        priv->emtestmode = mlc->opacket & HIL_CTRL_TEST;
-       if ((mlc->opacket & (HIL_CTRL_APE | HIL_CTRL_IPF)) == HIL_CTRL_APE) {
-               BUG(); /* we cannot emulate this, it should not be used. */
-       }
+       
+       /* we cannot emulate this, it should not be used. */
+       BUG_ON((mlc->opacket & (HIL_CTRL_APE | HIL_CTRL_IPF)) == HIL_CTRL_APE);
+       
        if ((mlc->opacket & HIL_CTRL_ONLY) == HIL_CTRL_ONLY) goto control_only;
        if (mlc->opacket & HIL_CTRL_APE) { 
                BUG(); /* Should not send command/data after engaging APE */
index dc7ef957e89708903b5620d175b8a110119091de..dbcca287ee2c5b7dcffddd4684385918ac47361b 100644 (file)
@@ -387,8 +387,7 @@ static void hdlc_fill_fifo(struct fritz_bcs *bcs)
 
        DBG(0x40, "hdlc_fill_fifo");
 
-       if (skb->len == 0)
-               BUG();
+       BUG_ON(skb->len == 0);
 
        bcs->ctrl.sr.cmd &= ~HDLC_CMD_XME;
        if (bcs->tx_skb->len > bcs->fifo_size) {
@@ -630,9 +629,7 @@ static void fritz_b_l2l1(struct hisax_if *ifc, int pr, void *arg)
 
        switch (pr) {
        case PH_DATA | REQUEST:
-               if (bcs->tx_skb)
-                       BUG();
-               
+               BUG_ON(bcs->tx_skb);
                bcs->tx_skb = skb;
                DBG_SKB(1, skb);
                hdlc_fill_fifo(bcs);
index f4972f6c1f5d29da36e98b34d8511194f8bdb140..81eac344bb0325fcf615a5808e52fb87401eb640 100644 (file)
@@ -476,12 +476,10 @@ static void isac_fill_fifo(struct isac *isac)
        unsigned char cmd;
        u_char *ptr;
 
-       if (!isac->tx_skb)
-               BUG();
+       BUG_ON(!isac->tx_skb);
 
        count = isac->tx_skb->len;
-       if (count <= 0)
-               BUG();
+       BUG_ON(count <= 0);
 
        DBG(DBG_IRQ, "count %d", count);
 
@@ -859,8 +857,7 @@ void isac_d_l2l1(struct hisax_if *hisax_d_if, int pr, void *arg)
                        dev_kfree_skb(skb);
                        break;
                }
-               if (isac->tx_skb)
-                       BUG();
+               BUG_ON(isac->tx_skb);
 
                isac->tx_skb = skb;
                isac_fill_fifo(isac);
index 657817a591fe03af6364a68adef40732731a7bea..22fd5db18d48c613ab92245ec469408256a8120d 100644 (file)
@@ -356,9 +356,7 @@ void st5481_b_l2l1(struct hisax_if *ifc, int pr, void *arg)
 
        switch (pr) {
        case PH_DATA | REQUEST:
-               if (bcs->b_out.tx_skb)
-                       BUG();
-               
+               BUG_ON(bcs->b_out.tx_skb);
                bcs->b_out.tx_skb = skb;
                break;
        case PH_ACTIVATE | REQUEST:
index 941f7022ada1c52f7b32eac2326b0dd11a966f57..493dc94992e568cc9f96627ebd3dd20a86931fa5 100644 (file)
@@ -596,9 +596,7 @@ void st5481_d_l2l1(struct hisax_if *hisax_d_if, int pr, void *arg)
                break;
        case PH_DATA | REQUEST:
                DBG(2, "PH_DATA REQUEST len %d", skb->len);
-               if (adapter->d_out.tx_skb)
-                       BUG();
-
+               BUG_ON(adapter->d_out.tx_skb);
                adapter->d_out.tx_skb = skb;
                FsmEvent(&adapter->d_out.fsm, EV_DOUT_START_XMIT, NULL);
                break;
index b9fed8a3bcc650036e170719ac9d0320a602e4ac..a0927d1b7a0c994f96cd213b0a0c4040901268f2 100644 (file)
@@ -974,8 +974,7 @@ void isdn_ppp_receive(isdn_net_dev * net_dev, isdn_net_local * lp, struct sk_buf
        int slot;
        int proto;
 
-       if (net_dev->local->master)
-               BUG(); // we're called with the master device always
+       BUG_ON(net_dev->local->master); // we're called with the master device always
 
        slot = lp->ppp_slot;
        if (slot < 0 || slot >= ISDN_MAX_CHANNELS) {
@@ -2527,8 +2526,7 @@ static struct sk_buff *isdn_ppp_decompress(struct sk_buff *skb,struct ippp_struc
                printk(KERN_DEBUG "ippp: no decompressor defined!\n");
                return skb;
        }
-       if (!stat) // if we have a compressor, stat has been set as well
-               BUG();
+       BUG_ON(!stat); // if we have a compressor, stat has been set as well
 
        if((master && *proto == PPP_COMP) || (!master && *proto == PPP_COMPFRAG) ) {
                // compressed packets are compressed by their protocol type
index a28c1c2b4ef5c703d2d5ce4f5c67bb2858483542..f10a0c89b3f4e542b3901790504a212d612741ef 100644 (file)
@@ -86,8 +86,7 @@ void dm_put_path_selector(struct path_selector_type *pst)
        if (--psi->use == 0)
                module_put(psi->pst.module);
 
-       if (psi->use < 0)
-               BUG();
+       BUG_ON(psi->use < 0);
 
 out:
        up_read(&_ps_lock);
index 9b1e2f5ca63049dbb1dd2dad9e642382374fbbf5..907b08ddb783c845c1b8b0d3631070c38fb37225 100644 (file)
@@ -352,8 +352,7 @@ static int open_dev(struct dm_dev *d, dev_t dev)
 
        int r;
 
-       if (d->bdev)
-               BUG();
+       BUG_ON(d->bdev);
 
        bdev = open_by_devnum(dev, d->mode);
        if (IS_ERR(bdev))
@@ -427,8 +426,7 @@ static int __table_get_device(struct dm_table *t, struct dm_target *ti,
        struct dm_dev *dd;
        unsigned int major, minor;
 
-       if (!t)
-               BUG();
+       BUG_ON(!t);
 
        if (sscanf(path, "%u:%u", &major, &minor) == 2) {
                /* Extract the major/minor numbers */
index 205bb708333502153faacef488cb0fd9da96017c..0f6bb2e625d8487574bccba7f0c89140a1108d51 100644 (file)
@@ -25,9 +25,8 @@ config MTD_JEDECPROBE
          compatible with the Common Flash Interface, but will use the common
          CFI-targetted flash drivers for any chips which are identified which
          are in fact compatible in all but the probe method. This actually
-         covers most AMD/Fujitsu-compatible chips, and will shortly cover also
-         non-CFI Intel chips (that code is in MTD CVS and should shortly be sent
-         for inclusion in Linus' tree)
+         covers most AMD/Fujitsu-compatible chips and also non-CFI
+         Intel chips.
 
 config MTD_GEN_PROBE
        tristate
index b51c757817d819c3cc4352ed773df591a905222d..efb221692641e6ff0ae03ab444cc1d4803ef73e5 100644 (file)
@@ -218,8 +218,8 @@ static void dnp_set_vpp(struct map_info *not_used, int on)
        {
                if(--vpp_counter == 0)
                        setcsc(CSC_RBWR, getcsc(CSC_RBWR) | 0x4);
-               else if(vpp_counter < 0)
-                       BUG();
+               else
+                       BUG_ON(vpp_counter < 0);
        }
        spin_unlock_irq(&dnpc_spin);
 }
@@ -240,8 +240,8 @@ static void adnp_set_vpp(struct map_info *not_used, int on)
        {
                if(--vpp_counter == 0)
                        setcsc(CSC_RBWR, getcsc(CSC_RBWR) | 0x8);
-               else if(vpp_counter < 0)
-                       BUG();
+               else
+                       BUG_ON(vpp_counter < 0);
        }
        spin_unlock_irq(&dnpc_spin);
 }
index 7f3ff500b68e37e3d5028bac85e4c22b9312db40..840dd66ce2dc63c84f4daf13240afe50d40b7d72 100644 (file)
@@ -450,8 +450,7 @@ int deregister_mtd_blktrans(struct mtd_blktrans_ops *tr)
 
        kfree(tr->blkcore_priv);
 
-       if (!list_empty(&tr->devs))
-               BUG();
+       BUG_ON(!list_empty(&tr->devs));
        return 0;
 }
 
index b1bf8c411de78e6c7685d7cd8928e642dd1afeb5..9af840364a74ff849c2aa283b25c0dc6038565a1 100644 (file)
@@ -477,8 +477,7 @@ static int concat_erase(struct mtd_info *mtd, struct erase_info *instr)
        }
 
        /* must never happen since size limit has been verified above */
-       if (i >= concat->num_subdev)
-               BUG();
+       BUG_ON(i >= concat->num_subdev);
 
        /* now do the erase: */
        err = 0;
@@ -500,8 +499,7 @@ static int concat_erase(struct mtd_info *mtd, struct erase_info *instr)
                if ((err = concat_dev_erase(subdev, erase))) {
                        /* sanity check: should never happen since
                         * block alignment has been checked above */
-                       if (err == -EINVAL)
-                               BUG();
+                       BUG_ON(err == -EINVAL);
                        if (erase->fail_addr != 0xffffffff)
                                instr->fail_addr = erase->fail_addr + offset;
                        break;
index 2f720108a7e07da24632a68fe3d6ac88a0773139..c1c6f138115002d3f7fb0f5606e7ecec691c9be9 100644 (file)
@@ -437,8 +437,7 @@ dasd_forget_ranges(void)
        spin_lock(&dasd_devmap_lock);
        for (i = 0; i < 256; i++) {
                list_for_each_entry_safe(devmap, n, &dasd_hashlists[i], list) {
-                       if (devmap->device != NULL)
-                               BUG();
+                       BUG_ON(devmap->device != NULL);
                        list_del(&devmap->list);
                        kfree(devmap);
                }
@@ -547,8 +546,7 @@ dasd_delete_device(struct dasd_device *device)
 
        /* First remove device pointer from devmap. */
        devmap = dasd_find_busid(device->cdev->dev.bus_id);
-       if (IS_ERR(devmap))
-               BUG();
+       BUG_ON(IS_ERR(devmap));
        spin_lock(&dasd_devmap_lock);
        if (devmap->device != device) {
                spin_unlock(&dasd_devmap_lock);
index a507b58550f1a9a2182f2b67bdb4288ef3652c2c..d597758dd129acb66e7b011db47ea983faf52ce3 100644 (file)
@@ -798,8 +798,7 @@ void mark_buffer_dirty_inode(struct buffer_head *bh, struct inode *inode)
        if (!mapping->assoc_mapping) {
                mapping->assoc_mapping = buffer_mapping;
        } else {
-               if (mapping->assoc_mapping != buffer_mapping)
-                       BUG();
+               BUG_ON(mapping->assoc_mapping != buffer_mapping);
        }
        if (list_empty(&bh->b_assoc_buffers)) {
                spin_lock(&buffer_mapping->private_lock);
@@ -1116,8 +1115,7 @@ grow_dev_page(struct block_device *bdev, sector_t block,
        if (!page)
                return NULL;
 
-       if (!PageLocked(page))
-               BUG();
+       BUG_ON(!PageLocked(page));
 
        if (page_has_buffers(page)) {
                bh = page_buffers(page);
@@ -1524,8 +1522,7 @@ void set_bh_page(struct buffer_head *bh,
                struct page *page, unsigned long offset)
 {
        bh->b_page = page;
-       if (offset >= PAGE_SIZE)
-               BUG();
+       BUG_ON(offset >= PAGE_SIZE);
        if (PageHighMem(page))
                /*
                 * This catches illegal uses and preserves the offset:
index aaca5e7970bc0a6e8fbf9cf0bfc94ac594c4b0e2..19458d3995024123c226e4de7a950ff71319462b 100644 (file)
@@ -34,7 +34,6 @@
 #include <linux/swap.h>
 #include <linux/bootmem.h>
 
-/* #define DCACHE_DEBUG 1 */
 
 int sysctl_vfs_cache_pressure __read_mostly = 100;
 EXPORT_SYMBOL_GPL(sysctl_vfs_cache_pressure);
@@ -603,10 +602,6 @@ resume:
                 */
                if (!list_empty(&dentry->d_subdirs)) {
                        this_parent = dentry;
-#ifdef DCACHE_DEBUG
-printk(KERN_DEBUG "select_parent: descending to %s/%s, found=%d\n",
-dentry->d_parent->d_name.name, dentry->d_name.name, found);
-#endif
                        goto repeat;
                }
        }
@@ -616,10 +611,6 @@ dentry->d_parent->d_name.name, dentry->d_name.name, found);
        if (this_parent != parent) {
                next = this_parent->d_u.d_child.next;
                this_parent = this_parent->d_parent;
-#ifdef DCACHE_DEBUG
-printk(KERN_DEBUG "select_parent: ascending to %s/%s, found=%d\n",
-this_parent->d_parent->d_name.name, this_parent->d_name.name, found);
-#endif
                goto resume;
        }
 out:
@@ -798,7 +789,7 @@ struct dentry *d_alloc_name(struct dentry *parent, const char *name)
  
 void d_instantiate(struct dentry *entry, struct inode * inode)
 {
-       if (!list_empty(&entry->d_alias)) BUG();
+       BUG_ON(!list_empty(&entry->d_alias));
        spin_lock(&dcache_lock);
        if (inode)
                list_add(&entry->d_alias, &inode->i_dentry);
index b3dbd716cd3a19b537c87b88048cd54ee43d7e50..0165388c425cce5625d4265ee40136ae9a988d25 100644 (file)
@@ -416,8 +416,7 @@ void ext2_set_link(struct inode *dir, struct ext2_dir_entry_2 *de,
 
        lock_page(page);
        err = page->mapping->a_ops->prepare_write(NULL, page, from, to);
-       if (err)
-               BUG();
+       BUG_ON(err);
        de->inode = cpu_to_le32(inode->i_ino);
        ext2_set_de_type (de, inode);
        err = ext2_commit_chunk(page, from, to);
@@ -554,8 +553,7 @@ int ext2_delete_entry (struct ext2_dir_entry_2 * dir, struct page * page )
                from = (char*)pde - (char*)page_address(page);
        lock_page(page);
        err = mapping->a_ops->prepare_write(NULL, page, from, to);
-       if (err)
-               BUG();
+       BUG_ON(err);
        if (pde)
                pde->rec_len = cpu_to_le16(to-from);
        dir->inode = 0;
index a7a7d77f3fd3d61e8762f2394117f937f03438e8..1e44dcfe49c4971315fd39d3d33772b0dfbd8a9c 100644 (file)
@@ -306,8 +306,7 @@ void hfs_bnode_unhash(struct hfs_bnode *node)
        for (p = &node->tree->node_hash[hfs_bnode_hash(node->this)];
             *p && *p != node; p = &(*p)->next_hash)
                ;
-       if (!*p)
-               BUG();
+       BUG_ON(!*p);
        *p = node->next_hash;
        node->tree->node_hash_cnt--;
 }
@@ -415,8 +414,7 @@ struct hfs_bnode *hfs_bnode_create(struct hfs_btree *tree, u32 num)
        spin_lock(&tree->hash_lock);
        node = hfs_bnode_findhash(tree, num);
        spin_unlock(&tree->hash_lock);
-       if (node)
-               BUG();
+       BUG_ON(node);
        node = __hfs_bnode_create(tree, num);
        if (!node)
                return ERR_PTR(-ENOMEM);
@@ -459,8 +457,7 @@ void hfs_bnode_put(struct hfs_bnode *node)
 
                dprint(DBG_BNODE_REFS, "put_node(%d:%d): %d\n",
                       node->tree->cnid, node->this, atomic_read(&node->refcnt));
-               if (!atomic_read(&node->refcnt))
-                       BUG();
+               BUG_ON(!atomic_read(&node->refcnt));
                if (!atomic_dec_and_lock(&node->refcnt, &tree->hash_lock))
                        return;
                for (i = 0; i < tree->pages_per_bnode; i++) {
index 7bb11edd148891694586da25a7e7926b21973a1b..d20131ce4b959a3260fc6cebcf29d1bd4825cb20 100644 (file)
@@ -36,8 +36,7 @@ struct hfs_btree *hfs_btree_open(struct super_block *sb, u32 id, btree_keycmp ke
        tree->inode = iget_locked(sb, id);
        if (!tree->inode)
                goto free_tree;
-       if (!(tree->inode->i_state & I_NEW))
-               BUG();
+       BUG_ON(!(tree->inode->i_state & I_NEW));
        {
        struct hfs_mdb *mdb = HFS_SB(sb)->mdb;
        HFS_I(tree->inode)->flags = 0;
index 8b671fe68afac1de0176f6b0f0b383b251d39c55..adb7cad3e6eec17165efdf88acf1f0f936fc4c9d 100644 (file)
@@ -23,7 +23,6 @@ int root_mountflags = MS_RDONLY | MS_SILENT;
 char * __initdata root_device_name;
 static char __initdata saved_root_name[64];
 
-/* this is initialized in init/main.c */
 dev_t ROOT_DEV;
 
 static int __init load_ramdisk(char *str)
index 48a54f66a246b2f55b3af8485c14d1aab9a48da4..642659cd596b82f5aa3974e61925708cdc62f9dd 100644 (file)
--- a/ipc/sem.c
+++ b/ipc/sem.c
@@ -229,8 +229,7 @@ asmlinkage long sys_semget (key_t key, int nsems, int semflg)
                err = -EEXIST;
        } else {
                sma = sem_lock(id);
-               if(sma==NULL)
-                       BUG();
+               BUG_ON(sma==NULL);
                if (nsems > sma->sem_nsems)
                        err = -EINVAL;
                else if (ipcperms(&sma->sem_perm, semflg))
@@ -1183,8 +1182,7 @@ retry_undos:
 
        sma = sem_lock(semid);
        if(sma==NULL) {
-               if(queue.prev != NULL)
-                       BUG();
+               BUG_ON(queue.prev != NULL);
                error = -EIDRM;
                goto out_free;
        }
index 4bd6486aa67d825157b255900c9eed9f5bc8fda1..e0a2b449dea64ea1b0d79bdc7124a74cb5c4cbdf 100644 (file)
@@ -769,8 +769,7 @@ int unshare_files(void)
        struct files_struct *files  = current->files;
        int rc;
 
-       if(!files)
-               BUG();
+       BUG_ON(!files);
 
        /* This can race but the race causes us to copy when we don't
           need to and drop the copy */
index 67686048f09496b42d387d9c6e0a37c13aad53fb..8d8f52569f328ab35d6ac9e68abe94c348434062 100644 (file)
@@ -2354,10 +2354,8 @@ int make_pages_present(unsigned long addr, unsigned long end)
        if (!vma)
                return -1;
        write = (vma->vm_flags & VM_WRITE) != 0;
-       if (addr >= end)
-               BUG();
-       if (end > vma->vm_end)
-               BUG();
+       BUG_ON(addr >= end);
+       BUG_ON(end > vma->vm_end);
        len = (end+PAGE_SIZE-1)/PAGE_SIZE-addr/PAGE_SIZE;
        ret = get_user_pages(current, current->mm, addr,
                        len, write, 0, NULL, NULL);
index 7bf064e6a345e898a5eafc616cd691b50fbedcec..fe6e05289cc5b5b7b30f036980fb7ea3835892e0 100644 (file)
@@ -183,8 +183,8 @@ EXPORT_SYMBOL(mempool_resize);
  */
 void mempool_destroy(mempool_t *pool)
 {
-       if (pool->curr_nr != pool->min_nr)
-               BUG();          /* There were outstanding elements */
+       /* Check for outstanding elements */
+       BUG_ON(pool->curr_nr != pool->min_nr);
        free_pool(pool);
 }
 EXPORT_SYMBOL(mempool_destroy);