]> Pileus Git - ~andy/linux/blob - drivers/staging/lustre/lustre/llite/lloop.c
Merge branch 'for-next' of git://git.kernel.org/pub/scm/linux/kernel/git/cooloney...
[~andy/linux] / drivers / staging / lustre / lustre / llite / lloop.c
1 /*
2  * GPL HEADER START
3  *
4  * DO NOT ALTER OR REMOVE COPYRIGHT NOTICES OR THIS FILE HEADER.
5  *
6  * This program is free software; you can redistribute it and/or modify
7  * it under the terms of the GNU General Public License version 2 only,
8  * as published by the Free Software Foundation.
9  *
10  * This program is distributed in the hope that it will be useful, but
11  * WITHOUT ANY WARRANTY; without even the implied warranty of
12  * MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
13  * General Public License version 2 for more details (a copy is included
14  * in the LICENSE file that accompanied this code).
15  *
16  * You should have received a copy of the GNU General Public License
17  * version 2 along with this program; If not, see
18  * http://www.sun.com/software/products/lustre/docs/GPLv2.pdf
19  *
20  * Please contact Sun Microsystems, Inc., 4150 Network Circle, Santa Clara,
21  * CA 95054 USA or visit www.sun.com if you need additional information or
22  * have any questions.
23  *
24  * GPL HEADER END
25  */
26 /*
27  * Copyright (c) 2007, 2010, Oracle and/or its affiliates. All rights reserved.
28  * Use is subject to license terms.
29  *
30  * Copyright (c) 2011, 2012, Intel Corporation.
31  */
32 /*
33  * This file is part of Lustre, http://www.lustre.org/
34  * Lustre is a trademark of Sun Microsystems, Inc.
35  */
36
37 /*
38  *  linux/drivers/block/loop.c
39  *
40  *  Written by Theodore Ts'o, 3/29/93
41  *
42  * Copyright 1993 by Theodore Ts'o.  Redistribution of this file is
43  * permitted under the GNU General Public License.
44  *
45  * Modularized and updated for 1.1.16 kernel - Mitch Dsouza 28th May 1994
46  * Adapted for 1.3.59 kernel - Andries Brouwer, 1 Feb 1996
47  *
48  * Fixed do_loop_request() re-entrancy - Vincent.Renardias@waw.com Mar 20, 1997
49  *
50  * Added devfs support - Richard Gooch <rgooch@atnf.csiro.au> 16-Jan-1998
51  *
52  * Handle sparse backing files correctly - Kenn Humborg, Jun 28, 1998
53  *
54  * Loadable modules and other fixes by AK, 1998
55  *
56  * Maximum number of loop devices now dynamic via max_loop module parameter.
57  * Russell Kroll <rkroll@exploits.org> 19990701
58  *
59  * Maximum number of loop devices when compiled-in now selectable by passing
60  * max_loop=<1-255> to the kernel on boot.
61  * Erik I. Bols?, <eriki@himolde.no>, Oct 31, 1999
62  *
63  * Completely rewrite request handling to be make_request_fn style and
64  * non blocking, pushing work to a helper thread. Lots of fixes from
65  * Al Viro too.
66  * Jens Axboe <axboe@suse.de>, Nov 2000
67  *
68  * Support up to 256 loop devices
69  * Heinz Mauelshagen <mge@sistina.com>, Feb 2002
70  *
71  * Support for falling back on the write file operation when the address space
72  * operations prepare_write and/or commit_write are not available on the
73  * backing filesystem.
74  * Anton Altaparmakov, 16 Feb 2005
75  *
76  * Still To Fix:
77  * - Advisory locking is ignored here.
78  * - Should use an own CAP_* category instead of CAP_SYS_ADMIN
79  *
80  */
81
82 #include <linux/module.h>
83
84 #include <linux/sched.h>
85 #include <linux/fs.h>
86 #include <linux/file.h>
87 #include <linux/stat.h>
88 #include <linux/errno.h>
89 #include <linux/major.h>
90 #include <linux/wait.h>
91 #include <linux/blkdev.h>
92 #include <linux/blkpg.h>
93 #include <linux/init.h>
94 #include <linux/swap.h>
95 #include <linux/slab.h>
96 #include <linux/suspend.h>
97 #include <linux/writeback.h>
98 #include <linux/buffer_head.h>          /* for invalidate_bdev() */
99 #include <linux/completion.h>
100 #include <linux/highmem.h>
101 #include <linux/gfp.h>
102 #include <linux/pagevec.h>
103
104 #include <asm/uaccess.h>
105
106 #include <lustre_lib.h>
107 #include <lustre_lite.h>
108 #include "llite_internal.h"
109
110 #define LLOOP_MAX_SEGMENTS      LNET_MAX_IOV
111
112 /* Possible states of device */
113 enum {
114         LLOOP_UNBOUND,
115         LLOOP_BOUND,
116         LLOOP_RUNDOWN,
117 };
118
119 struct lloop_device {
120         int               lo_number;
121         int               lo_refcnt;
122         loff_t         lo_offset;
123         loff_t         lo_sizelimit;
124         int               lo_flags;
125         int             (*ioctl)(struct lloop_device *, int cmd,
126                                     unsigned long arg);
127
128         struct file      *lo_backing_file;
129         struct block_device *lo_device;
130         unsigned             lo_blocksize;
131
132         int               old_gfp_mask;
133
134         spinlock_t              lo_lock;
135         struct bio              *lo_bio;
136         struct bio              *lo_biotail;
137         int                     lo_state;
138         struct semaphore        lo_sem;
139         struct mutex            lo_ctl_mutex;
140         atomic_t         lo_pending;
141         wait_queue_head_t         lo_bh_wait;
142
143         struct request_queue *lo_queue;
144
145         const struct lu_env *lo_env;
146         struct cl_io     lo_io;
147         struct ll_dio_pages  lo_pvec;
148
149         /* data to handle bio for lustre. */
150         struct lo_request_data {
151                 struct page *lrd_pages[LLOOP_MAX_SEGMENTS];
152                 loff_t       lrd_offsets[LLOOP_MAX_SEGMENTS];
153         } lo_requests[1];
154 };
155
156 /*
157  * Loop flags
158  */
159 enum {
160         LO_FLAGS_READ_ONLY       = 1,
161 };
162
163 static int lloop_major;
164 #define MAX_LOOP_DEFAULT  16
165 static int max_loop = MAX_LOOP_DEFAULT;
166 static struct lloop_device *loop_dev;
167 static struct gendisk **disks;
168 static struct mutex lloop_mutex;
169 static void *ll_iocontrol_magic = NULL;
170
171 static loff_t get_loop_size(struct lloop_device *lo, struct file *file)
172 {
173         loff_t size, offset, loopsize;
174
175         /* Compute loopsize in bytes */
176         size = i_size_read(file->f_mapping->host);
177         offset = lo->lo_offset;
178         loopsize = size - offset;
179         if (lo->lo_sizelimit > 0 && lo->lo_sizelimit < loopsize)
180                 loopsize = lo->lo_sizelimit;
181
182         /*
183          * Unfortunately, if we want to do I/O on the device,
184          * the number of 512-byte sectors has to fit into a sector_t.
185          */
186         return loopsize >> 9;
187 }
188
189 static int do_bio_lustrebacked(struct lloop_device *lo, struct bio *head)
190 {
191         const struct lu_env  *env   = lo->lo_env;
192         struct cl_io     *io    = &lo->lo_io;
193         struct inode     *inode = lo->lo_backing_file->f_dentry->d_inode;
194         struct cl_object     *obj = ll_i2info(inode)->lli_clob;
195         pgoff_t        offset;
196         int                ret;
197         int                i;
198         int                rw;
199         obd_count            page_count = 0;
200         struct bio_vec       *bvec;
201         struct bio         *bio;
202         ssize_t        bytes;
203
204         struct ll_dio_pages  *pvec = &lo->lo_pvec;
205         struct page      **pages = pvec->ldp_pages;
206         loff_t         *offsets = pvec->ldp_offsets;
207
208         truncate_inode_pages(inode->i_mapping, 0);
209
210         /* initialize the IO */
211         memset(io, 0, sizeof(*io));
212         io->ci_obj = obj;
213         ret = cl_io_init(env, io, CIT_MISC, obj);
214         if (ret)
215                 return io->ci_result;
216         io->ci_lockreq = CILR_NEVER;
217
218         LASSERT(head != NULL);
219         rw = head->bi_rw;
220         for (bio = head; bio != NULL; bio = bio->bi_next) {
221                 LASSERT(rw == bio->bi_rw);
222
223                 offset = (pgoff_t)(bio->bi_sector << 9) + lo->lo_offset;
224                 bio_for_each_segment(bvec, bio, i) {
225                         BUG_ON(bvec->bv_offset != 0);
226                         BUG_ON(bvec->bv_len != PAGE_CACHE_SIZE);
227
228                         pages[page_count] = bvec->bv_page;
229                         offsets[page_count] = offset;
230                         page_count++;
231                         offset += bvec->bv_len;
232                 }
233                 LASSERT(page_count <= LLOOP_MAX_SEGMENTS);
234         }
235
236         ll_stats_ops_tally(ll_i2sbi(inode),
237                         (rw == WRITE) ? LPROC_LL_BRW_WRITE : LPROC_LL_BRW_READ,
238                         page_count);
239
240         pvec->ldp_size = page_count << PAGE_CACHE_SHIFT;
241         pvec->ldp_nr = page_count;
242
243         /* FIXME: in ll_direct_rw_pages, it has to allocate many cl_page{}s to
244          * write those pages into OST. Even worse case is that more pages
245          * would be asked to write out to swap space, and then finally get here
246          * again.
247          * Unfortunately this is NOT easy to fix.
248          * Thoughts on solution:
249          * 0. Define a reserved pool for cl_pages, which could be a list of
250          *    pre-allocated cl_pages;
251          * 1. Define a new operation in cl_object_operations{}, says clo_depth,
252          *    which measures how many layers for this lustre object. Generally
253          *    speaking, the depth would be 2, one for llite, and one for lovsub.
254          *    However, for SNS, there will be more since we need additional page
255          *    to store parity;
256          * 2. Reserve the # of (page_count * depth) cl_pages from the reserved
257          *    pool. Afterwards, the clio would allocate the pages from reserved
258          *    pool, this guarantees we neeedn't allocate the cl_pages from
259          *    generic cl_page slab cache.
260          *    Of course, if there is NOT enough pages in the pool, we might
261          *    be asked to write less pages once, this purely depends on
262          *    implementation. Anyway, we should be careful to avoid deadlocking.
263          */
264         mutex_lock(&inode->i_mutex);
265         bytes = ll_direct_rw_pages(env, io, rw, inode, pvec);
266         mutex_unlock(&inode->i_mutex);
267         cl_io_fini(env, io);
268         return (bytes == pvec->ldp_size) ? 0 : (int)bytes;
269 }
270
271 /*
272  * Add bio to back of pending list
273  */
274 static void loop_add_bio(struct lloop_device *lo, struct bio *bio)
275 {
276         unsigned long flags;
277
278         spin_lock_irqsave(&lo->lo_lock, flags);
279         if (lo->lo_biotail) {
280                 lo->lo_biotail->bi_next = bio;
281                 lo->lo_biotail = bio;
282         } else
283                 lo->lo_bio = lo->lo_biotail = bio;
284         spin_unlock_irqrestore(&lo->lo_lock, flags);
285
286         atomic_inc(&lo->lo_pending);
287         if (waitqueue_active(&lo->lo_bh_wait))
288                 wake_up(&lo->lo_bh_wait);
289 }
290
291 /*
292  * Grab first pending buffer
293  */
294 static unsigned int loop_get_bio(struct lloop_device *lo, struct bio **req)
295 {
296         struct bio *first;
297         struct bio **bio;
298         unsigned int count = 0;
299         unsigned int page_count = 0;
300         int rw;
301
302         spin_lock_irq(&lo->lo_lock);
303         first = lo->lo_bio;
304         if (unlikely(first == NULL)) {
305                 spin_unlock_irq(&lo->lo_lock);
306                 return 0;
307         }
308
309         /* TODO: need to split the bio, too bad. */
310         LASSERT(first->bi_vcnt <= LLOOP_MAX_SEGMENTS);
311
312         rw = first->bi_rw;
313         bio = &lo->lo_bio;
314         while (*bio && (*bio)->bi_rw == rw) {
315                 CDEBUG(D_INFO, "bio sector %llu size %u count %u vcnt%u \n",
316                        (unsigned long long)(*bio)->bi_sector, (*bio)->bi_size,
317                        page_count, (*bio)->bi_vcnt);
318                 if (page_count + (*bio)->bi_vcnt > LLOOP_MAX_SEGMENTS)
319                         break;
320
321
322                 page_count += (*bio)->bi_vcnt;
323                 count++;
324                 bio = &(*bio)->bi_next;
325         }
326         if (*bio) {
327                 /* Some of bios can't be mergable. */
328                 lo->lo_bio = *bio;
329                 *bio = NULL;
330         } else {
331                 /* Hit the end of queue */
332                 lo->lo_biotail = NULL;
333                 lo->lo_bio = NULL;
334         }
335         *req = first;
336         spin_unlock_irq(&lo->lo_lock);
337         return count;
338 }
339
340 static void loop_make_request(struct request_queue *q, struct bio *old_bio)
341 {
342         struct lloop_device *lo = q->queuedata;
343         int rw = bio_rw(old_bio);
344         int inactive;
345
346         if (!lo)
347                 goto err;
348
349         CDEBUG(D_INFO, "submit bio sector %llu size %u\n",
350                (unsigned long long)old_bio->bi_sector, old_bio->bi_size);
351
352         spin_lock_irq(&lo->lo_lock);
353         inactive = (lo->lo_state != LLOOP_BOUND);
354         spin_unlock_irq(&lo->lo_lock);
355         if (inactive)
356                 goto err;
357
358         if (rw == WRITE) {
359                 if (lo->lo_flags & LO_FLAGS_READ_ONLY)
360                         goto err;
361         } else if (rw == READA) {
362                 rw = READ;
363         } else if (rw != READ) {
364                 CERROR("lloop: unknown command (%x)\n", rw);
365                 goto err;
366         }
367         loop_add_bio(lo, old_bio);
368         return;
369 err:
370         cfs_bio_io_error(old_bio, old_bio->bi_size);
371 }
372
373
374 static inline void loop_handle_bio(struct lloop_device *lo, struct bio *bio)
375 {
376         int ret;
377         ret = do_bio_lustrebacked(lo, bio);
378         while (bio) {
379                 struct bio *tmp = bio->bi_next;
380                 bio->bi_next = NULL;
381                 cfs_bio_endio(bio, bio->bi_size, ret);
382                 bio = tmp;
383         }
384 }
385
386 static inline int loop_active(struct lloop_device *lo)
387 {
388         return atomic_read(&lo->lo_pending) ||
389                 (lo->lo_state == LLOOP_RUNDOWN);
390 }
391
392 /*
393  * worker thread that handles reads/writes to file backed loop devices,
394  * to avoid blocking in our make_request_fn.
395  */
396 static int loop_thread(void *data)
397 {
398         struct lloop_device *lo = data;
399         struct bio *bio;
400         unsigned int count;
401         unsigned long times = 0;
402         unsigned long total_count = 0;
403
404         struct lu_env *env;
405         int refcheck;
406         int ret = 0;
407
408         set_user_nice(current, -20);
409
410         lo->lo_state = LLOOP_BOUND;
411
412         env = cl_env_get(&refcheck);
413         if (IS_ERR(env))
414                 GOTO(out, ret = PTR_ERR(env));
415
416         lo->lo_env = env;
417         memset(&lo->lo_pvec, 0, sizeof(lo->lo_pvec));
418         lo->lo_pvec.ldp_pages   = lo->lo_requests[0].lrd_pages;
419         lo->lo_pvec.ldp_offsets = lo->lo_requests[0].lrd_offsets;
420
421         /*
422          * up sem, we are running
423          */
424         up(&lo->lo_sem);
425
426         for (;;) {
427                 wait_event(lo->lo_bh_wait, loop_active(lo));
428                 if (!atomic_read(&lo->lo_pending)) {
429                         int exiting = 0;
430                         spin_lock_irq(&lo->lo_lock);
431                         exiting = (lo->lo_state == LLOOP_RUNDOWN);
432                         spin_unlock_irq(&lo->lo_lock);
433                         if (exiting)
434                                 break;
435                 }
436
437                 bio = NULL;
438                 count = loop_get_bio(lo, &bio);
439                 if (!count) {
440                         CWARN("lloop(minor: %d): missing bio\n", lo->lo_number);
441                         continue;
442                 }
443
444                 total_count += count;
445                 if (total_count < count) {     /* overflow */
446                         total_count = count;
447                         times = 1;
448                 } else {
449                         times++;
450                 }
451                 if ((times & 127) == 0) {
452                         CDEBUG(D_INFO, "total: %lu, count: %lu, avg: %lu\n",
453                                total_count, times, total_count / times);
454                 }
455
456                 LASSERT(bio != NULL);
457                 LASSERT(count <= atomic_read(&lo->lo_pending));
458                 loop_handle_bio(lo, bio);
459                 atomic_sub(count, &lo->lo_pending);
460         }
461         cl_env_put(env, &refcheck);
462
463 out:
464         up(&lo->lo_sem);
465         return ret;
466 }
467
468 static int loop_set_fd(struct lloop_device *lo, struct file *unused,
469                        struct block_device *bdev, struct file *file)
470 {
471         struct inode     *inode;
472         struct address_space *mapping;
473         int                lo_flags = 0;
474         int                error;
475         loff_t          size;
476
477         if (!try_module_get(THIS_MODULE))
478                 return -ENODEV;
479
480         error = -EBUSY;
481         if (lo->lo_state != LLOOP_UNBOUND)
482                 goto out;
483
484         mapping = file->f_mapping;
485         inode = mapping->host;
486
487         error = -EINVAL;
488         if (!S_ISREG(inode->i_mode) || inode->i_sb->s_magic != LL_SUPER_MAGIC)
489                 goto out;
490
491         if (!(file->f_mode & FMODE_WRITE))
492                 lo_flags |= LO_FLAGS_READ_ONLY;
493
494         size = get_loop_size(lo, file);
495
496         if ((loff_t)(sector_t)size != size) {
497                 error = -EFBIG;
498                 goto out;
499         }
500
501         /* remove all pages in cache so as dirty pages not to be existent. */
502         truncate_inode_pages(mapping, 0);
503
504         set_device_ro(bdev, (lo_flags & LO_FLAGS_READ_ONLY) != 0);
505
506         lo->lo_blocksize = PAGE_CACHE_SIZE;
507         lo->lo_device = bdev;
508         lo->lo_flags = lo_flags;
509         lo->lo_backing_file = file;
510         lo->ioctl = NULL;
511         lo->lo_sizelimit = 0;
512         lo->old_gfp_mask = mapping_gfp_mask(mapping);
513         mapping_set_gfp_mask(mapping, lo->old_gfp_mask & ~(__GFP_IO|__GFP_FS));
514
515         lo->lo_bio = lo->lo_biotail = NULL;
516
517         /*
518          * set queue make_request_fn, and add limits based on lower level
519          * device
520          */
521         blk_queue_make_request(lo->lo_queue, loop_make_request);
522         lo->lo_queue->queuedata = lo;
523
524         /* queue parameters */
525         CLASSERT(PAGE_CACHE_SIZE < (1 << (sizeof(unsigned short) * 8)));
526         blk_queue_logical_block_size(lo->lo_queue,
527                                      (unsigned short)PAGE_CACHE_SIZE);
528         blk_queue_max_hw_sectors(lo->lo_queue,
529                                  LLOOP_MAX_SEGMENTS << (PAGE_CACHE_SHIFT - 9));
530         blk_queue_max_segments(lo->lo_queue, LLOOP_MAX_SEGMENTS);
531
532         set_capacity(disks[lo->lo_number], size);
533         bd_set_size(bdev, size << 9);
534
535         set_blocksize(bdev, lo->lo_blocksize);
536
537         kthread_run(loop_thread, lo, "lloop%d", lo->lo_number);
538         down(&lo->lo_sem);
539         return 0;
540
541 out:
542         /* This is safe: open() is still holding a reference. */
543         module_put(THIS_MODULE);
544         return error;
545 }
546
547 static int loop_clr_fd(struct lloop_device *lo, struct block_device *bdev,
548                        int count)
549 {
550         struct file *filp = lo->lo_backing_file;
551         int gfp = lo->old_gfp_mask;
552
553         if (lo->lo_state != LLOOP_BOUND)
554                 return -ENXIO;
555
556         if (lo->lo_refcnt > count)      /* we needed one fd for the ioctl */
557                 return -EBUSY;
558
559         if (filp == NULL)
560                 return -EINVAL;
561
562         spin_lock_irq(&lo->lo_lock);
563         lo->lo_state = LLOOP_RUNDOWN;
564         spin_unlock_irq(&lo->lo_lock);
565         wake_up(&lo->lo_bh_wait);
566
567         down(&lo->lo_sem);
568         lo->lo_backing_file = NULL;
569         lo->ioctl = NULL;
570         lo->lo_device = NULL;
571         lo->lo_offset = 0;
572         lo->lo_sizelimit = 0;
573         lo->lo_flags = 0;
574         invalidate_bdev(bdev);
575         set_capacity(disks[lo->lo_number], 0);
576         bd_set_size(bdev, 0);
577         mapping_set_gfp_mask(filp->f_mapping, gfp);
578         lo->lo_state = LLOOP_UNBOUND;
579         fput(filp);
580         /* This is safe: open() is still holding a reference. */
581         module_put(THIS_MODULE);
582         return 0;
583 }
584
585 static int lo_open(struct block_device *bdev, fmode_t mode)
586 {
587         struct lloop_device *lo = bdev->bd_disk->private_data;
588
589         mutex_lock(&lo->lo_ctl_mutex);
590         lo->lo_refcnt++;
591         mutex_unlock(&lo->lo_ctl_mutex);
592
593         return 0;
594 }
595
596 static void lo_release(struct gendisk *disk, fmode_t mode)
597 {
598         struct lloop_device *lo = disk->private_data;
599
600         mutex_lock(&lo->lo_ctl_mutex);
601         --lo->lo_refcnt;
602         mutex_unlock(&lo->lo_ctl_mutex);
603 }
604
605 /* lloop device node's ioctl function. */
606 static int lo_ioctl(struct block_device *bdev, fmode_t mode,
607                     unsigned int cmd, unsigned long arg)
608 {
609         struct lloop_device *lo = bdev->bd_disk->private_data;
610         struct inode *inode = NULL;
611         int err = 0;
612
613         mutex_lock(&lloop_mutex);
614         switch (cmd) {
615         case LL_IOC_LLOOP_DETACH: {
616                 err = loop_clr_fd(lo, bdev, 2);
617                 if (err == 0)
618                         blkdev_put(bdev, 0); /* grabbed in LLOOP_ATTACH */
619                 break;
620         }
621
622         case LL_IOC_LLOOP_INFO: {
623                 struct lu_fid fid;
624
625                 LASSERT(lo->lo_backing_file != NULL);
626                 if (inode == NULL)
627                         inode = lo->lo_backing_file->f_dentry->d_inode;
628                 if (lo->lo_state == LLOOP_BOUND)
629                         fid = ll_i2info(inode)->lli_fid;
630                 else
631                         fid_zero(&fid);
632
633                 if (copy_to_user((struct lu_fid *)arg, &fid, sizeof(fid)))
634                         err = -EFAULT;
635                 break;
636         }
637
638         default:
639                 err = -EINVAL;
640                 break;
641         }
642         mutex_unlock(&lloop_mutex);
643
644         return err;
645 }
646
647 static struct block_device_operations lo_fops = {
648         .owner =        THIS_MODULE,
649         .open =  lo_open,
650         .release =      lo_release,
651         .ioctl =        lo_ioctl,
652 };
653
654 /* dynamic iocontrol callback.
655  * This callback is registered in lloop_init and will be called by
656  * ll_iocontrol_call.
657  *
658  * This is a llite regular file ioctl function. It takes the responsibility
659  * of attaching or detaching a file by a lloop's device numner.
660  */
661 static enum llioc_iter lloop_ioctl(struct inode *unused, struct file *file,
662                                    unsigned int cmd, unsigned long arg,
663                                    void *magic, int *rcp)
664 {
665         struct lloop_device *lo = NULL;
666         struct block_device *bdev = NULL;
667         int err = 0;
668         dev_t dev;
669
670         if (magic != ll_iocontrol_magic)
671                 return LLIOC_CONT;
672
673         if (disks == NULL)
674                 GOTO(out1, err = -ENODEV);
675
676         CWARN("Enter llop_ioctl\n");
677
678         mutex_lock(&lloop_mutex);
679         switch (cmd) {
680         case LL_IOC_LLOOP_ATTACH: {
681                 struct lloop_device *lo_free = NULL;
682                 int i;
683
684                 for (i = 0; i < max_loop; i++, lo = NULL) {
685                         lo = &loop_dev[i];
686                         if (lo->lo_state == LLOOP_UNBOUND) {
687                                 if (!lo_free)
688                                         lo_free = lo;
689                                 continue;
690                         }
691                         if (lo->lo_backing_file->f_dentry->d_inode ==
692                             file->f_dentry->d_inode)
693                                 break;
694                 }
695                 if (lo || !lo_free)
696                         GOTO(out, err = -EBUSY);
697
698                 lo = lo_free;
699                 dev = MKDEV(lloop_major, lo->lo_number);
700
701                 /* quit if the used pointer is writable */
702                 if (put_user((long)old_encode_dev(dev), (long*)arg))
703                         GOTO(out, err = -EFAULT);
704
705                 bdev = blkdev_get_by_dev(dev, file->f_mode, NULL);
706                 if (IS_ERR(bdev))
707                         GOTO(out, err = PTR_ERR(bdev));
708
709                 get_file(file);
710                 err = loop_set_fd(lo, NULL, bdev, file);
711                 if (err) {
712                         fput(file);
713                         blkdev_put(bdev, 0);
714                 }
715
716                 break;
717         }
718
719         case LL_IOC_LLOOP_DETACH_BYDEV: {
720                 int minor;
721
722                 dev = old_decode_dev(arg);
723                 if (MAJOR(dev) != lloop_major)
724                         GOTO(out, err = -EINVAL);
725
726                 minor = MINOR(dev);
727                 if (minor > max_loop - 1)
728                         GOTO(out, err = -EINVAL);
729
730                 lo = &loop_dev[minor];
731                 if (lo->lo_state != LLOOP_BOUND)
732                         GOTO(out, err = -EINVAL);
733
734                 bdev = lo->lo_device;
735                 err = loop_clr_fd(lo, bdev, 1);
736                 if (err == 0)
737                         blkdev_put(bdev, 0); /* grabbed in LLOOP_ATTACH */
738
739                 break;
740         }
741
742         default:
743                 err = -EINVAL;
744                 break;
745         }
746
747 out:
748         mutex_unlock(&lloop_mutex);
749 out1:
750         if (rcp)
751                 *rcp = err;
752         return LLIOC_STOP;
753 }
754
755 static int __init lloop_init(void)
756 {
757         int     i;
758         unsigned int cmdlist[] = {
759                 LL_IOC_LLOOP_ATTACH,
760                 LL_IOC_LLOOP_DETACH_BYDEV,
761         };
762
763         if (max_loop < 1 || max_loop > 256) {
764                 max_loop = MAX_LOOP_DEFAULT;
765                 CWARN("lloop: invalid max_loop (must be between"
766                       " 1 and 256), using default (%u)\n", max_loop);
767         }
768
769         lloop_major = register_blkdev(0, "lloop");
770         if (lloop_major < 0)
771                 return -EIO;
772
773         CDEBUG(D_CONFIG, "registered lloop major %d with %u minors\n",
774                lloop_major, max_loop);
775
776         ll_iocontrol_magic = ll_iocontrol_register(lloop_ioctl, 2, cmdlist);
777         if (ll_iocontrol_magic == NULL)
778                 goto out_mem1;
779
780         OBD_ALLOC_WAIT(loop_dev, max_loop * sizeof(*loop_dev));
781         if (!loop_dev)
782                 goto out_mem1;
783
784         OBD_ALLOC_WAIT(disks, max_loop * sizeof(*disks));
785         if (!disks)
786                 goto out_mem2;
787
788         for (i = 0; i < max_loop; i++) {
789                 disks[i] = alloc_disk(1);
790                 if (!disks[i])
791                         goto out_mem3;
792         }
793
794         mutex_init(&lloop_mutex);
795
796         for (i = 0; i < max_loop; i++) {
797                 struct lloop_device *lo = &loop_dev[i];
798                 struct gendisk *disk = disks[i];
799
800                 lo->lo_queue = blk_alloc_queue(GFP_KERNEL);
801                 if (!lo->lo_queue)
802                         goto out_mem4;
803
804                 mutex_init(&lo->lo_ctl_mutex);
805                 sema_init(&lo->lo_sem, 0);
806                 init_waitqueue_head(&lo->lo_bh_wait);
807                 lo->lo_number = i;
808                 spin_lock_init(&lo->lo_lock);
809                 disk->major = lloop_major;
810                 disk->first_minor = i;
811                 disk->fops = &lo_fops;
812                 sprintf(disk->disk_name, "lloop%d", i);
813                 disk->private_data = lo;
814                 disk->queue = lo->lo_queue;
815         }
816
817         /* We cannot fail after we call this, so another loop!*/
818         for (i = 0; i < max_loop; i++)
819                 add_disk(disks[i]);
820         return 0;
821
822 out_mem4:
823         while (i--)
824                 blk_cleanup_queue(loop_dev[i].lo_queue);
825         i = max_loop;
826 out_mem3:
827         while (i--)
828                 put_disk(disks[i]);
829         OBD_FREE(disks, max_loop * sizeof(*disks));
830 out_mem2:
831         OBD_FREE(loop_dev, max_loop * sizeof(*loop_dev));
832 out_mem1:
833         unregister_blkdev(lloop_major, "lloop");
834         ll_iocontrol_unregister(ll_iocontrol_magic);
835         CERROR("lloop: ran out of memory\n");
836         return -ENOMEM;
837 }
838
839 static void lloop_exit(void)
840 {
841         int i;
842
843         ll_iocontrol_unregister(ll_iocontrol_magic);
844         for (i = 0; i < max_loop; i++) {
845                 del_gendisk(disks[i]);
846                 blk_cleanup_queue(loop_dev[i].lo_queue);
847                 put_disk(disks[i]);
848         }
849
850         unregister_blkdev(lloop_major, "lloop");
851
852         OBD_FREE(disks, max_loop * sizeof(*disks));
853         OBD_FREE(loop_dev, max_loop * sizeof(*loop_dev));
854 }
855
856 module_init(lloop_init);
857 module_exit(lloop_exit);
858
859 module_param(max_loop, int, 0444);
860 MODULE_PARM_DESC(max_loop, "maximum of lloop_device");
861 MODULE_AUTHOR("Sun Microsystems, Inc. <http://www.lustre.org/>");
862 MODULE_DESCRIPTION("Lustre virtual block device");
863 MODULE_LICENSE("GPL");