block: bump BLK_DEF_MAX_SECTORS to 2560
[cascardo/linux.git] / include / linux / blkdev.h
1 #ifndef _LINUX_BLKDEV_H
2 #define _LINUX_BLKDEV_H
3
4 #include <linux/sched.h>
5
6 #ifdef CONFIG_BLOCK
7
8 #include <linux/major.h>
9 #include <linux/genhd.h>
10 #include <linux/list.h>
11 #include <linux/llist.h>
12 #include <linux/timer.h>
13 #include <linux/workqueue.h>
14 #include <linux/pagemap.h>
15 #include <linux/backing-dev-defs.h>
16 #include <linux/wait.h>
17 #include <linux/mempool.h>
18 #include <linux/bio.h>
19 #include <linux/stringify.h>
20 #include <linux/gfp.h>
21 #include <linux/bsg.h>
22 #include <linux/smp.h>
23 #include <linux/rcupdate.h>
24 #include <linux/percpu-refcount.h>
25 #include <linux/scatterlist.h>
26
27 struct module;
28 struct scsi_ioctl_command;
29
30 struct request_queue;
31 struct elevator_queue;
32 struct blk_trace;
33 struct request;
34 struct sg_io_hdr;
35 struct bsg_job;
36 struct blkcg_gq;
37 struct blk_flush_queue;
38
39 #define BLKDEV_MIN_RQ   4
40 #define BLKDEV_MAX_RQ   128     /* Default maximum */
41
42 /*
43  * Maximum number of blkcg policies allowed to be registered concurrently.
44  * Defined here to simplify include dependency.
45  */
46 #define BLKCG_MAX_POLS          2
47
48 struct request;
49 typedef void (rq_end_io_fn)(struct request *, int);
50
51 #define BLK_RL_SYNCFULL         (1U << 0)
52 #define BLK_RL_ASYNCFULL        (1U << 1)
53
54 struct request_list {
55         struct request_queue    *q;     /* the queue this rl belongs to */
56 #ifdef CONFIG_BLK_CGROUP
57         struct blkcg_gq         *blkg;  /* blkg this request pool belongs to */
58 #endif
59         /*
60          * count[], starved[], and wait[] are indexed by
61          * BLK_RW_SYNC/BLK_RW_ASYNC
62          */
63         int                     count[2];
64         int                     starved[2];
65         mempool_t               *rq_pool;
66         wait_queue_head_t       wait[2];
67         unsigned int            flags;
68 };
69
70 /*
71  * request command types
72  */
73 enum rq_cmd_type_bits {
74         REQ_TYPE_FS             = 1,    /* fs request */
75         REQ_TYPE_BLOCK_PC,              /* scsi command */
76         REQ_TYPE_DRV_PRIV,              /* driver defined types from here */
77 };
78
79 #define BLK_MAX_CDB     16
80
81 /*
82  * Try to put the fields that are referenced together in the same cacheline.
83  *
84  * If you modify this structure, make sure to update blk_rq_init() and
85  * especially blk_mq_rq_ctx_init() to take care of the added fields.
86  */
87 struct request {
88         struct list_head queuelist;
89         union {
90                 struct call_single_data csd;
91                 unsigned long fifo_time;
92         };
93
94         struct request_queue *q;
95         struct blk_mq_ctx *mq_ctx;
96
97         u64 cmd_flags;
98         unsigned cmd_type;
99         unsigned long atomic_flags;
100
101         int cpu;
102
103         /* the following two fields are internal, NEVER access directly */
104         unsigned int __data_len;        /* total data len */
105         sector_t __sector;              /* sector cursor */
106
107         struct bio *bio;
108         struct bio *biotail;
109
110         /*
111          * The hash is used inside the scheduler, and killed once the
112          * request reaches the dispatch list. The ipi_list is only used
113          * to queue the request for softirq completion, which is long
114          * after the request has been unhashed (and even removed from
115          * the dispatch list).
116          */
117         union {
118                 struct hlist_node hash; /* merge hash */
119                 struct list_head ipi_list;
120         };
121
122         /*
123          * The rb_node is only used inside the io scheduler, requests
124          * are pruned when moved to the dispatch queue. So let the
125          * completion_data share space with the rb_node.
126          */
127         union {
128                 struct rb_node rb_node; /* sort/lookup */
129                 void *completion_data;
130         };
131
132         /*
133          * Three pointers are available for the IO schedulers, if they need
134          * more they have to dynamically allocate it.  Flush requests are
135          * never put on the IO scheduler. So let the flush fields share
136          * space with the elevator data.
137          */
138         union {
139                 struct {
140                         struct io_cq            *icq;
141                         void                    *priv[2];
142                 } elv;
143
144                 struct {
145                         unsigned int            seq;
146                         struct list_head        list;
147                         rq_end_io_fn            *saved_end_io;
148                 } flush;
149         };
150
151         struct gendisk *rq_disk;
152         struct hd_struct *part;
153         unsigned long start_time;
154 #ifdef CONFIG_BLK_CGROUP
155         struct request_list *rl;                /* rl this rq is alloced from */
156         unsigned long long start_time_ns;
157         unsigned long long io_start_time_ns;    /* when passed to hardware */
158 #endif
159         /* Number of scatter-gather DMA addr+len pairs after
160          * physical address coalescing is performed.
161          */
162         unsigned short nr_phys_segments;
163 #if defined(CONFIG_BLK_DEV_INTEGRITY)
164         unsigned short nr_integrity_segments;
165 #endif
166
167         unsigned short ioprio;
168
169         void *special;          /* opaque pointer available for LLD use */
170
171         int tag;
172         int errors;
173
174         /*
175          * when request is used as a packet command carrier
176          */
177         unsigned char __cmd[BLK_MAX_CDB];
178         unsigned char *cmd;
179         unsigned short cmd_len;
180
181         unsigned int extra_len; /* length of alignment and padding */
182         unsigned int sense_len;
183         unsigned int resid_len; /* residual count */
184         void *sense;
185
186         unsigned long deadline;
187         struct list_head timeout_list;
188         unsigned int timeout;
189         int retries;
190
191         /*
192          * completion callback.
193          */
194         rq_end_io_fn *end_io;
195         void *end_io_data;
196
197         /* for bidi */
198         struct request *next_rq;
199 };
200
201 static inline unsigned short req_get_ioprio(struct request *req)
202 {
203         return req->ioprio;
204 }
205
206 #include <linux/elevator.h>
207
208 struct blk_queue_ctx;
209
210 typedef void (request_fn_proc) (struct request_queue *q);
211 typedef void (make_request_fn) (struct request_queue *q, struct bio *bio);
212 typedef int (prep_rq_fn) (struct request_queue *, struct request *);
213 typedef void (unprep_rq_fn) (struct request_queue *, struct request *);
214
215 struct bio_vec;
216 typedef void (softirq_done_fn)(struct request *);
217 typedef int (dma_drain_needed_fn)(struct request *);
218 typedef int (lld_busy_fn) (struct request_queue *q);
219 typedef int (bsg_job_fn) (struct bsg_job *);
220
221 enum blk_eh_timer_return {
222         BLK_EH_NOT_HANDLED,
223         BLK_EH_HANDLED,
224         BLK_EH_RESET_TIMER,
225 };
226
227 typedef enum blk_eh_timer_return (rq_timed_out_fn)(struct request *);
228
229 enum blk_queue_state {
230         Queue_down,
231         Queue_up,
232 };
233
234 struct blk_queue_tag {
235         struct request **tag_index;     /* map of busy tags */
236         unsigned long *tag_map;         /* bit map of free/busy tags */
237         int busy;                       /* current depth */
238         int max_depth;                  /* what we will send to device */
239         int real_max_depth;             /* what the array can hold */
240         atomic_t refcnt;                /* map can be shared */
241         int alloc_policy;               /* tag allocation policy */
242         int next_tag;                   /* next tag */
243 };
244 #define BLK_TAG_ALLOC_FIFO 0 /* allocate starting from 0 */
245 #define BLK_TAG_ALLOC_RR 1 /* allocate starting from last allocated tag */
246
247 #define BLK_SCSI_MAX_CMDS       (256)
248 #define BLK_SCSI_CMD_PER_LONG   (BLK_SCSI_MAX_CMDS / (sizeof(long) * 8))
249
250 struct queue_limits {
251         unsigned long           bounce_pfn;
252         unsigned long           seg_boundary_mask;
253
254         unsigned int            max_hw_sectors;
255         unsigned int            chunk_sectors;
256         unsigned int            max_sectors;
257         unsigned int            max_segment_size;
258         unsigned int            physical_block_size;
259         unsigned int            alignment_offset;
260         unsigned int            io_min;
261         unsigned int            io_opt;
262         unsigned int            max_discard_sectors;
263         unsigned int            max_hw_discard_sectors;
264         unsigned int            max_write_same_sectors;
265         unsigned int            discard_granularity;
266         unsigned int            discard_alignment;
267
268         unsigned short          logical_block_size;
269         unsigned short          max_segments;
270         unsigned short          max_integrity_segments;
271
272         unsigned char           misaligned;
273         unsigned char           discard_misaligned;
274         unsigned char           cluster;
275         unsigned char           discard_zeroes_data;
276         unsigned char           raid_partial_stripes_expensive;
277 };
278
279 struct request_queue {
280         /*
281          * Together with queue_head for cacheline sharing
282          */
283         struct list_head        queue_head;
284         struct request          *last_merge;
285         struct elevator_queue   *elevator;
286         int                     nr_rqs[2];      /* # allocated [a]sync rqs */
287         int                     nr_rqs_elvpriv; /* # allocated rqs w/ elvpriv */
288
289         /*
290          * If blkcg is not used, @q->root_rl serves all requests.  If blkcg
291          * is used, root blkg allocates from @q->root_rl and all other
292          * blkgs from their own blkg->rl.  Which one to use should be
293          * determined using bio_request_list().
294          */
295         struct request_list     root_rl;
296
297         request_fn_proc         *request_fn;
298         make_request_fn         *make_request_fn;
299         prep_rq_fn              *prep_rq_fn;
300         unprep_rq_fn            *unprep_rq_fn;
301         softirq_done_fn         *softirq_done_fn;
302         rq_timed_out_fn         *rq_timed_out_fn;
303         dma_drain_needed_fn     *dma_drain_needed;
304         lld_busy_fn             *lld_busy_fn;
305
306         struct blk_mq_ops       *mq_ops;
307
308         unsigned int            *mq_map;
309
310         /* sw queues */
311         struct blk_mq_ctx __percpu      *queue_ctx;
312         unsigned int            nr_queues;
313
314         /* hw dispatch queues */
315         struct blk_mq_hw_ctx    **queue_hw_ctx;
316         unsigned int            nr_hw_queues;
317
318         /*
319          * Dispatch queue sorting
320          */
321         sector_t                end_sector;
322         struct request          *boundary_rq;
323
324         /*
325          * Delayed queue handling
326          */
327         struct delayed_work     delay_work;
328
329         struct backing_dev_info backing_dev_info;
330
331         /*
332          * The queue owner gets to use this for whatever they like.
333          * ll_rw_blk doesn't touch it.
334          */
335         void                    *queuedata;
336
337         /*
338          * various queue flags, see QUEUE_* below
339          */
340         unsigned long           queue_flags;
341
342         /*
343          * ida allocated id for this queue.  Used to index queues from
344          * ioctx.
345          */
346         int                     id;
347
348         /*
349          * queue needs bounce pages for pages above this limit
350          */
351         gfp_t                   bounce_gfp;
352
353         /*
354          * protects queue structures from reentrancy. ->__queue_lock should
355          * _never_ be used directly, it is queue private. always use
356          * ->queue_lock.
357          */
358         spinlock_t              __queue_lock;
359         spinlock_t              *queue_lock;
360
361         /*
362          * queue kobject
363          */
364         struct kobject kobj;
365
366         /*
367          * mq queue kobject
368          */
369         struct kobject mq_kobj;
370
371 #ifdef CONFIG_PM
372         struct device           *dev;
373         int                     rpm_status;
374         unsigned int            nr_pending;
375 #endif
376
377         /*
378          * queue settings
379          */
380         unsigned long           nr_requests;    /* Max # of requests */
381         unsigned int            nr_congestion_on;
382         unsigned int            nr_congestion_off;
383         unsigned int            nr_batching;
384
385         unsigned int            dma_drain_size;
386         void                    *dma_drain_buffer;
387         unsigned int            dma_pad_mask;
388         unsigned int            dma_alignment;
389
390         struct blk_queue_tag    *queue_tags;
391         struct list_head        tag_busy_list;
392
393         unsigned int            nr_sorted;
394         unsigned int            in_flight[2];
395         /*
396          * Number of active block driver functions for which blk_drain_queue()
397          * must wait. Must be incremented around functions that unlock the
398          * queue_lock internally, e.g. scsi_request_fn().
399          */
400         unsigned int            request_fn_active;
401
402         unsigned int            rq_timeout;
403         struct timer_list       timeout;
404         struct list_head        timeout_list;
405
406         struct list_head        icq_list;
407 #ifdef CONFIG_BLK_CGROUP
408         DECLARE_BITMAP          (blkcg_pols, BLKCG_MAX_POLS);
409         struct blkcg_gq         *root_blkg;
410         struct list_head        blkg_list;
411 #endif
412
413         struct queue_limits     limits;
414
415         /*
416          * sg stuff
417          */
418         unsigned int            sg_timeout;
419         unsigned int            sg_reserved_size;
420         int                     node;
421 #ifdef CONFIG_BLK_DEV_IO_TRACE
422         struct blk_trace        *blk_trace;
423 #endif
424         /*
425          * for flush operations
426          */
427         unsigned int            flush_flags;
428         unsigned int            flush_not_queueable:1;
429         struct blk_flush_queue  *fq;
430
431         struct list_head        requeue_list;
432         spinlock_t              requeue_lock;
433         struct work_struct      requeue_work;
434
435         struct mutex            sysfs_lock;
436
437         int                     bypass_depth;
438         atomic_t                mq_freeze_depth;
439
440 #if defined(CONFIG_BLK_DEV_BSG)
441         bsg_job_fn              *bsg_job_fn;
442         int                     bsg_job_size;
443         struct bsg_class_device bsg_dev;
444 #endif
445
446 #ifdef CONFIG_BLK_DEV_THROTTLING
447         /* Throttle data */
448         struct throtl_data *td;
449 #endif
450         struct rcu_head         rcu_head;
451         wait_queue_head_t       mq_freeze_wq;
452         struct percpu_ref       mq_usage_counter;
453         struct list_head        all_q_node;
454
455         struct blk_mq_tag_set   *tag_set;
456         struct list_head        tag_set_list;
457         struct bio_set          *bio_split;
458 };
459
460 #define QUEUE_FLAG_QUEUED       1       /* uses generic tag queueing */
461 #define QUEUE_FLAG_STOPPED      2       /* queue is stopped */
462 #define QUEUE_FLAG_SYNCFULL     3       /* read queue has been filled */
463 #define QUEUE_FLAG_ASYNCFULL    4       /* write queue has been filled */
464 #define QUEUE_FLAG_DYING        5       /* queue being torn down */
465 #define QUEUE_FLAG_BYPASS       6       /* act as dumb FIFO queue */
466 #define QUEUE_FLAG_BIDI         7       /* queue supports bidi requests */
467 #define QUEUE_FLAG_NOMERGES     8       /* disable merge attempts */
468 #define QUEUE_FLAG_SAME_COMP    9       /* complete on same CPU-group */
469 #define QUEUE_FLAG_FAIL_IO     10       /* fake timeout */
470 #define QUEUE_FLAG_STACKABLE   11       /* supports request stacking */
471 #define QUEUE_FLAG_NONROT      12       /* non-rotational device (SSD) */
472 #define QUEUE_FLAG_VIRT        QUEUE_FLAG_NONROT /* paravirt device */
473 #define QUEUE_FLAG_IO_STAT     13       /* do IO stats */
474 #define QUEUE_FLAG_DISCARD     14       /* supports DISCARD */
475 #define QUEUE_FLAG_NOXMERGES   15       /* No extended merges */
476 #define QUEUE_FLAG_ADD_RANDOM  16       /* Contributes to random pool */
477 #define QUEUE_FLAG_SECDISCARD  17       /* supports SECDISCARD */
478 #define QUEUE_FLAG_SAME_FORCE  18       /* force complete on same CPU */
479 #define QUEUE_FLAG_DEAD        19       /* queue tear-down finished */
480 #define QUEUE_FLAG_INIT_DONE   20       /* queue is initialized */
481 #define QUEUE_FLAG_NO_SG_MERGE 21       /* don't attempt to merge SG segments*/
482 #define QUEUE_FLAG_SG_GAPS     22       /* queue doesn't support SG gaps */
483
484 #define QUEUE_FLAG_DEFAULT      ((1 << QUEUE_FLAG_IO_STAT) |            \
485                                  (1 << QUEUE_FLAG_STACKABLE)    |       \
486                                  (1 << QUEUE_FLAG_SAME_COMP)    |       \
487                                  (1 << QUEUE_FLAG_ADD_RANDOM))
488
489 #define QUEUE_FLAG_MQ_DEFAULT   ((1 << QUEUE_FLAG_IO_STAT) |            \
490                                  (1 << QUEUE_FLAG_STACKABLE)    |       \
491                                  (1 << QUEUE_FLAG_SAME_COMP))
492
493 static inline void queue_lockdep_assert_held(struct request_queue *q)
494 {
495         if (q->queue_lock)
496                 lockdep_assert_held(q->queue_lock);
497 }
498
499 static inline void queue_flag_set_unlocked(unsigned int flag,
500                                            struct request_queue *q)
501 {
502         __set_bit(flag, &q->queue_flags);
503 }
504
505 static inline int queue_flag_test_and_clear(unsigned int flag,
506                                             struct request_queue *q)
507 {
508         queue_lockdep_assert_held(q);
509
510         if (test_bit(flag, &q->queue_flags)) {
511                 __clear_bit(flag, &q->queue_flags);
512                 return 1;
513         }
514
515         return 0;
516 }
517
518 static inline int queue_flag_test_and_set(unsigned int flag,
519                                           struct request_queue *q)
520 {
521         queue_lockdep_assert_held(q);
522
523         if (!test_bit(flag, &q->queue_flags)) {
524                 __set_bit(flag, &q->queue_flags);
525                 return 0;
526         }
527
528         return 1;
529 }
530
531 static inline void queue_flag_set(unsigned int flag, struct request_queue *q)
532 {
533         queue_lockdep_assert_held(q);
534         __set_bit(flag, &q->queue_flags);
535 }
536
537 static inline void queue_flag_clear_unlocked(unsigned int flag,
538                                              struct request_queue *q)
539 {
540         __clear_bit(flag, &q->queue_flags);
541 }
542
543 static inline int queue_in_flight(struct request_queue *q)
544 {
545         return q->in_flight[0] + q->in_flight[1];
546 }
547
548 static inline void queue_flag_clear(unsigned int flag, struct request_queue *q)
549 {
550         queue_lockdep_assert_held(q);
551         __clear_bit(flag, &q->queue_flags);
552 }
553
554 #define blk_queue_tagged(q)     test_bit(QUEUE_FLAG_QUEUED, &(q)->queue_flags)
555 #define blk_queue_stopped(q)    test_bit(QUEUE_FLAG_STOPPED, &(q)->queue_flags)
556 #define blk_queue_dying(q)      test_bit(QUEUE_FLAG_DYING, &(q)->queue_flags)
557 #define blk_queue_dead(q)       test_bit(QUEUE_FLAG_DEAD, &(q)->queue_flags)
558 #define blk_queue_bypass(q)     test_bit(QUEUE_FLAG_BYPASS, &(q)->queue_flags)
559 #define blk_queue_init_done(q)  test_bit(QUEUE_FLAG_INIT_DONE, &(q)->queue_flags)
560 #define blk_queue_nomerges(q)   test_bit(QUEUE_FLAG_NOMERGES, &(q)->queue_flags)
561 #define blk_queue_noxmerges(q)  \
562         test_bit(QUEUE_FLAG_NOXMERGES, &(q)->queue_flags)
563 #define blk_queue_nonrot(q)     test_bit(QUEUE_FLAG_NONROT, &(q)->queue_flags)
564 #define blk_queue_io_stat(q)    test_bit(QUEUE_FLAG_IO_STAT, &(q)->queue_flags)
565 #define blk_queue_add_random(q) test_bit(QUEUE_FLAG_ADD_RANDOM, &(q)->queue_flags)
566 #define blk_queue_stackable(q)  \
567         test_bit(QUEUE_FLAG_STACKABLE, &(q)->queue_flags)
568 #define blk_queue_discard(q)    test_bit(QUEUE_FLAG_DISCARD, &(q)->queue_flags)
569 #define blk_queue_secdiscard(q) (blk_queue_discard(q) && \
570         test_bit(QUEUE_FLAG_SECDISCARD, &(q)->queue_flags))
571
572 #define blk_noretry_request(rq) \
573         ((rq)->cmd_flags & (REQ_FAILFAST_DEV|REQ_FAILFAST_TRANSPORT| \
574                              REQ_FAILFAST_DRIVER))
575
576 #define blk_account_rq(rq) \
577         (((rq)->cmd_flags & REQ_STARTED) && \
578          ((rq)->cmd_type == REQ_TYPE_FS))
579
580 #define blk_rq_cpu_valid(rq)    ((rq)->cpu != -1)
581 #define blk_bidi_rq(rq)         ((rq)->next_rq != NULL)
582 /* rq->queuelist of dequeued request must be list_empty() */
583 #define blk_queued_rq(rq)       (!list_empty(&(rq)->queuelist))
584
585 #define list_entry_rq(ptr)      list_entry((ptr), struct request, queuelist)
586
587 #define rq_data_dir(rq)         (((rq)->cmd_flags & 1) != 0)
588
589 /*
590  * Driver can handle struct request, if it either has an old style
591  * request_fn defined, or is blk-mq based.
592  */
593 static inline bool queue_is_rq_based(struct request_queue *q)
594 {
595         return q->request_fn || q->mq_ops;
596 }
597
598 static inline unsigned int blk_queue_cluster(struct request_queue *q)
599 {
600         return q->limits.cluster;
601 }
602
603 /*
604  * We regard a request as sync, if either a read or a sync write
605  */
606 static inline bool rw_is_sync(unsigned int rw_flags)
607 {
608         return !(rw_flags & REQ_WRITE) || (rw_flags & REQ_SYNC);
609 }
610
611 static inline bool rq_is_sync(struct request *rq)
612 {
613         return rw_is_sync(rq->cmd_flags);
614 }
615
616 static inline bool blk_rl_full(struct request_list *rl, bool sync)
617 {
618         unsigned int flag = sync ? BLK_RL_SYNCFULL : BLK_RL_ASYNCFULL;
619
620         return rl->flags & flag;
621 }
622
623 static inline void blk_set_rl_full(struct request_list *rl, bool sync)
624 {
625         unsigned int flag = sync ? BLK_RL_SYNCFULL : BLK_RL_ASYNCFULL;
626
627         rl->flags |= flag;
628 }
629
630 static inline void blk_clear_rl_full(struct request_list *rl, bool sync)
631 {
632         unsigned int flag = sync ? BLK_RL_SYNCFULL : BLK_RL_ASYNCFULL;
633
634         rl->flags &= ~flag;
635 }
636
637 static inline bool rq_mergeable(struct request *rq)
638 {
639         if (rq->cmd_type != REQ_TYPE_FS)
640                 return false;
641
642         if (rq->cmd_flags & REQ_NOMERGE_FLAGS)
643                 return false;
644
645         return true;
646 }
647
648 static inline bool blk_check_merge_flags(unsigned int flags1,
649                                          unsigned int flags2)
650 {
651         if ((flags1 & REQ_DISCARD) != (flags2 & REQ_DISCARD))
652                 return false;
653
654         if ((flags1 & REQ_SECURE) != (flags2 & REQ_SECURE))
655                 return false;
656
657         if ((flags1 & REQ_WRITE_SAME) != (flags2 & REQ_WRITE_SAME))
658                 return false;
659
660         return true;
661 }
662
663 static inline bool blk_write_same_mergeable(struct bio *a, struct bio *b)
664 {
665         if (bio_data(a) == bio_data(b))
666                 return true;
667
668         return false;
669 }
670
671 /*
672  * q->prep_rq_fn return values
673  */
674 #define BLKPREP_OK              0       /* serve it */
675 #define BLKPREP_KILL            1       /* fatal error, kill */
676 #define BLKPREP_DEFER           2       /* leave on queue */
677
678 extern unsigned long blk_max_low_pfn, blk_max_pfn;
679
680 /*
681  * standard bounce addresses:
682  *
683  * BLK_BOUNCE_HIGH      : bounce all highmem pages
684  * BLK_BOUNCE_ANY       : don't bounce anything
685  * BLK_BOUNCE_ISA       : bounce pages above ISA DMA boundary
686  */
687
688 #if BITS_PER_LONG == 32
689 #define BLK_BOUNCE_HIGH         ((u64)blk_max_low_pfn << PAGE_SHIFT)
690 #else
691 #define BLK_BOUNCE_HIGH         -1ULL
692 #endif
693 #define BLK_BOUNCE_ANY          (-1ULL)
694 #define BLK_BOUNCE_ISA          (DMA_BIT_MASK(24))
695
696 /*
697  * default timeout for SG_IO if none specified
698  */
699 #define BLK_DEFAULT_SG_TIMEOUT  (60 * HZ)
700 #define BLK_MIN_SG_TIMEOUT      (7 * HZ)
701
702 #ifdef CONFIG_BOUNCE
703 extern int init_emergency_isa_pool(void);
704 extern void blk_queue_bounce(struct request_queue *q, struct bio **bio);
705 #else
706 static inline int init_emergency_isa_pool(void)
707 {
708         return 0;
709 }
710 static inline void blk_queue_bounce(struct request_queue *q, struct bio **bio)
711 {
712 }
713 #endif /* CONFIG_MMU */
714
715 struct rq_map_data {
716         struct page **pages;
717         int page_order;
718         int nr_entries;
719         unsigned long offset;
720         int null_mapped;
721         int from_user;
722 };
723
724 struct req_iterator {
725         struct bvec_iter iter;
726         struct bio *bio;
727 };
728
729 /* This should not be used directly - use rq_for_each_segment */
730 #define for_each_bio(_bio)              \
731         for (; _bio; _bio = _bio->bi_next)
732 #define __rq_for_each_bio(_bio, rq)     \
733         if ((rq->bio))                  \
734                 for (_bio = (rq)->bio; _bio; _bio = _bio->bi_next)
735
736 #define rq_for_each_segment(bvl, _rq, _iter)                    \
737         __rq_for_each_bio(_iter.bio, _rq)                       \
738                 bio_for_each_segment(bvl, _iter.bio, _iter.iter)
739
740 #define rq_iter_last(bvec, _iter)                               \
741                 (_iter.bio->bi_next == NULL &&                  \
742                  bio_iter_last(bvec, _iter.iter))
743
744 #ifndef ARCH_IMPLEMENTS_FLUSH_DCACHE_PAGE
745 # error "You should define ARCH_IMPLEMENTS_FLUSH_DCACHE_PAGE for your platform"
746 #endif
747 #if ARCH_IMPLEMENTS_FLUSH_DCACHE_PAGE
748 extern void rq_flush_dcache_pages(struct request *rq);
749 #else
750 static inline void rq_flush_dcache_pages(struct request *rq)
751 {
752 }
753 #endif
754
755 extern int blk_register_queue(struct gendisk *disk);
756 extern void blk_unregister_queue(struct gendisk *disk);
757 extern void generic_make_request(struct bio *bio);
758 extern void blk_rq_init(struct request_queue *q, struct request *rq);
759 extern void blk_put_request(struct request *);
760 extern void __blk_put_request(struct request_queue *, struct request *);
761 extern struct request *blk_get_request(struct request_queue *, int, gfp_t);
762 extern struct request *blk_make_request(struct request_queue *, struct bio *,
763                                         gfp_t);
764 extern void blk_rq_set_block_pc(struct request *);
765 extern void blk_requeue_request(struct request_queue *, struct request *);
766 extern void blk_add_request_payload(struct request *rq, struct page *page,
767                 unsigned int len);
768 extern int blk_rq_check_limits(struct request_queue *q, struct request *rq);
769 extern int blk_lld_busy(struct request_queue *q);
770 extern int blk_rq_prep_clone(struct request *rq, struct request *rq_src,
771                              struct bio_set *bs, gfp_t gfp_mask,
772                              int (*bio_ctr)(struct bio *, struct bio *, void *),
773                              void *data);
774 extern void blk_rq_unprep_clone(struct request *rq);
775 extern int blk_insert_cloned_request(struct request_queue *q,
776                                      struct request *rq);
777 extern void blk_delay_queue(struct request_queue *, unsigned long);
778 extern void blk_queue_split(struct request_queue *, struct bio **,
779                             struct bio_set *);
780 extern void blk_recount_segments(struct request_queue *, struct bio *);
781 extern int scsi_verify_blk_ioctl(struct block_device *, unsigned int);
782 extern int scsi_cmd_blk_ioctl(struct block_device *, fmode_t,
783                               unsigned int, void __user *);
784 extern int scsi_cmd_ioctl(struct request_queue *, struct gendisk *, fmode_t,
785                           unsigned int, void __user *);
786 extern int sg_scsi_ioctl(struct request_queue *, struct gendisk *, fmode_t,
787                          struct scsi_ioctl_command __user *);
788
789 extern void blk_start_queue(struct request_queue *q);
790 extern void blk_stop_queue(struct request_queue *q);
791 extern void blk_sync_queue(struct request_queue *q);
792 extern void __blk_stop_queue(struct request_queue *q);
793 extern void __blk_run_queue(struct request_queue *q);
794 extern void __blk_run_queue_uncond(struct request_queue *q);
795 extern void blk_run_queue(struct request_queue *);
796 extern void blk_run_queue_async(struct request_queue *q);
797 extern int blk_rq_map_user(struct request_queue *, struct request *,
798                            struct rq_map_data *, void __user *, unsigned long,
799                            gfp_t);
800 extern int blk_rq_unmap_user(struct bio *);
801 extern int blk_rq_map_kern(struct request_queue *, struct request *, void *, unsigned int, gfp_t);
802 extern int blk_rq_map_user_iov(struct request_queue *, struct request *,
803                                struct rq_map_data *, const struct iov_iter *,
804                                gfp_t);
805 extern int blk_execute_rq(struct request_queue *, struct gendisk *,
806                           struct request *, int);
807 extern void blk_execute_rq_nowait(struct request_queue *, struct gendisk *,
808                                   struct request *, int, rq_end_io_fn *);
809
810 static inline struct request_queue *bdev_get_queue(struct block_device *bdev)
811 {
812         return bdev->bd_disk->queue;    /* this is never NULL */
813 }
814
815 /*
816  * blk_rq_pos()                 : the current sector
817  * blk_rq_bytes()               : bytes left in the entire request
818  * blk_rq_cur_bytes()           : bytes left in the current segment
819  * blk_rq_err_bytes()           : bytes left till the next error boundary
820  * blk_rq_sectors()             : sectors left in the entire request
821  * blk_rq_cur_sectors()         : sectors left in the current segment
822  */
823 static inline sector_t blk_rq_pos(const struct request *rq)
824 {
825         return rq->__sector;
826 }
827
828 static inline unsigned int blk_rq_bytes(const struct request *rq)
829 {
830         return rq->__data_len;
831 }
832
833 static inline int blk_rq_cur_bytes(const struct request *rq)
834 {
835         return rq->bio ? bio_cur_bytes(rq->bio) : 0;
836 }
837
838 extern unsigned int blk_rq_err_bytes(const struct request *rq);
839
840 static inline unsigned int blk_rq_sectors(const struct request *rq)
841 {
842         return blk_rq_bytes(rq) >> 9;
843 }
844
845 static inline unsigned int blk_rq_cur_sectors(const struct request *rq)
846 {
847         return blk_rq_cur_bytes(rq) >> 9;
848 }
849
850 static inline unsigned int blk_queue_get_max_sectors(struct request_queue *q,
851                                                      unsigned int cmd_flags)
852 {
853         if (unlikely(cmd_flags & REQ_DISCARD))
854                 return min(q->limits.max_discard_sectors, UINT_MAX >> 9);
855
856         if (unlikely(cmd_flags & REQ_WRITE_SAME))
857                 return q->limits.max_write_same_sectors;
858
859         return q->limits.max_sectors;
860 }
861
862 /*
863  * Return maximum size of a request at given offset. Only valid for
864  * file system requests.
865  */
866 static inline unsigned int blk_max_size_offset(struct request_queue *q,
867                                                sector_t offset)
868 {
869         if (!q->limits.chunk_sectors)
870                 return q->limits.max_sectors;
871
872         return q->limits.chunk_sectors -
873                         (offset & (q->limits.chunk_sectors - 1));
874 }
875
876 static inline unsigned int blk_rq_get_max_sectors(struct request *rq)
877 {
878         struct request_queue *q = rq->q;
879
880         if (unlikely(rq->cmd_type == REQ_TYPE_BLOCK_PC))
881                 return q->limits.max_hw_sectors;
882
883         if (!q->limits.chunk_sectors || (rq->cmd_flags & REQ_DISCARD))
884                 return blk_queue_get_max_sectors(q, rq->cmd_flags);
885
886         return min(blk_max_size_offset(q, blk_rq_pos(rq)),
887                         blk_queue_get_max_sectors(q, rq->cmd_flags));
888 }
889
890 static inline unsigned int blk_rq_count_bios(struct request *rq)
891 {
892         unsigned int nr_bios = 0;
893         struct bio *bio;
894
895         __rq_for_each_bio(bio, rq)
896                 nr_bios++;
897
898         return nr_bios;
899 }
900
901 /*
902  * Request issue related functions.
903  */
904 extern struct request *blk_peek_request(struct request_queue *q);
905 extern void blk_start_request(struct request *rq);
906 extern struct request *blk_fetch_request(struct request_queue *q);
907
908 /*
909  * Request completion related functions.
910  *
911  * blk_update_request() completes given number of bytes and updates
912  * the request without completing it.
913  *
914  * blk_end_request() and friends.  __blk_end_request() must be called
915  * with the request queue spinlock acquired.
916  *
917  * Several drivers define their own end_request and call
918  * blk_end_request() for parts of the original function.
919  * This prevents code duplication in drivers.
920  */
921 extern bool blk_update_request(struct request *rq, int error,
922                                unsigned int nr_bytes);
923 extern void blk_finish_request(struct request *rq, int error);
924 extern bool blk_end_request(struct request *rq, int error,
925                             unsigned int nr_bytes);
926 extern void blk_end_request_all(struct request *rq, int error);
927 extern bool blk_end_request_cur(struct request *rq, int error);
928 extern bool blk_end_request_err(struct request *rq, int error);
929 extern bool __blk_end_request(struct request *rq, int error,
930                               unsigned int nr_bytes);
931 extern void __blk_end_request_all(struct request *rq, int error);
932 extern bool __blk_end_request_cur(struct request *rq, int error);
933 extern bool __blk_end_request_err(struct request *rq, int error);
934
935 extern void blk_complete_request(struct request *);
936 extern void __blk_complete_request(struct request *);
937 extern void blk_abort_request(struct request *);
938 extern void blk_unprep_request(struct request *);
939
940 /*
941  * Access functions for manipulating queue properties
942  */
943 extern struct request_queue *blk_init_queue_node(request_fn_proc *rfn,
944                                         spinlock_t *lock, int node_id);
945 extern struct request_queue *blk_init_queue(request_fn_proc *, spinlock_t *);
946 extern struct request_queue *blk_init_allocated_queue(struct request_queue *,
947                                                       request_fn_proc *, spinlock_t *);
948 extern void blk_cleanup_queue(struct request_queue *);
949 extern void blk_queue_make_request(struct request_queue *, make_request_fn *);
950 extern void blk_queue_bounce_limit(struct request_queue *, u64);
951 extern void blk_limits_max_hw_sectors(struct queue_limits *, unsigned int);
952 extern void blk_queue_max_hw_sectors(struct request_queue *, unsigned int);
953 extern void blk_queue_chunk_sectors(struct request_queue *, unsigned int);
954 extern void blk_queue_max_segments(struct request_queue *, unsigned short);
955 extern void blk_queue_max_segment_size(struct request_queue *, unsigned int);
956 extern void blk_queue_max_discard_sectors(struct request_queue *q,
957                 unsigned int max_discard_sectors);
958 extern void blk_queue_max_write_same_sectors(struct request_queue *q,
959                 unsigned int max_write_same_sectors);
960 extern void blk_queue_logical_block_size(struct request_queue *, unsigned short);
961 extern void blk_queue_physical_block_size(struct request_queue *, unsigned int);
962 extern void blk_queue_alignment_offset(struct request_queue *q,
963                                        unsigned int alignment);
964 extern void blk_limits_io_min(struct queue_limits *limits, unsigned int min);
965 extern void blk_queue_io_min(struct request_queue *q, unsigned int min);
966 extern void blk_limits_io_opt(struct queue_limits *limits, unsigned int opt);
967 extern void blk_queue_io_opt(struct request_queue *q, unsigned int opt);
968 extern void blk_set_default_limits(struct queue_limits *lim);
969 extern void blk_set_stacking_limits(struct queue_limits *lim);
970 extern int blk_stack_limits(struct queue_limits *t, struct queue_limits *b,
971                             sector_t offset);
972 extern int bdev_stack_limits(struct queue_limits *t, struct block_device *bdev,
973                             sector_t offset);
974 extern void disk_stack_limits(struct gendisk *disk, struct block_device *bdev,
975                               sector_t offset);
976 extern void blk_queue_stack_limits(struct request_queue *t, struct request_queue *b);
977 extern void blk_queue_dma_pad(struct request_queue *, unsigned int);
978 extern void blk_queue_update_dma_pad(struct request_queue *, unsigned int);
979 extern int blk_queue_dma_drain(struct request_queue *q,
980                                dma_drain_needed_fn *dma_drain_needed,
981                                void *buf, unsigned int size);
982 extern void blk_queue_lld_busy(struct request_queue *q, lld_busy_fn *fn);
983 extern void blk_queue_segment_boundary(struct request_queue *, unsigned long);
984 extern void blk_queue_prep_rq(struct request_queue *, prep_rq_fn *pfn);
985 extern void blk_queue_unprep_rq(struct request_queue *, unprep_rq_fn *ufn);
986 extern void blk_queue_dma_alignment(struct request_queue *, int);
987 extern void blk_queue_update_dma_alignment(struct request_queue *, int);
988 extern void blk_queue_softirq_done(struct request_queue *, softirq_done_fn *);
989 extern void blk_queue_rq_timed_out(struct request_queue *, rq_timed_out_fn *);
990 extern void blk_queue_rq_timeout(struct request_queue *, unsigned int);
991 extern void blk_queue_flush(struct request_queue *q, unsigned int flush);
992 extern void blk_queue_flush_queueable(struct request_queue *q, bool queueable);
993 extern struct backing_dev_info *blk_get_backing_dev_info(struct block_device *bdev);
994
995 extern int blk_rq_map_sg(struct request_queue *, struct request *, struct scatterlist *);
996 extern void blk_dump_rq_flags(struct request *, char *);
997 extern long nr_blockdev_pages(void);
998
999 bool __must_check blk_get_queue(struct request_queue *);
1000 struct request_queue *blk_alloc_queue(gfp_t);
1001 struct request_queue *blk_alloc_queue_node(gfp_t, int);
1002 extern void blk_put_queue(struct request_queue *);
1003 extern void blk_set_queue_dying(struct request_queue *);
1004
1005 /*
1006  * block layer runtime pm functions
1007  */
1008 #ifdef CONFIG_PM
1009 extern void blk_pm_runtime_init(struct request_queue *q, struct device *dev);
1010 extern int blk_pre_runtime_suspend(struct request_queue *q);
1011 extern void blk_post_runtime_suspend(struct request_queue *q, int err);
1012 extern void blk_pre_runtime_resume(struct request_queue *q);
1013 extern void blk_post_runtime_resume(struct request_queue *q, int err);
1014 #else
1015 static inline void blk_pm_runtime_init(struct request_queue *q,
1016         struct device *dev) {}
1017 static inline int blk_pre_runtime_suspend(struct request_queue *q)
1018 {
1019         return -ENOSYS;
1020 }
1021 static inline void blk_post_runtime_suspend(struct request_queue *q, int err) {}
1022 static inline void blk_pre_runtime_resume(struct request_queue *q) {}
1023 static inline void blk_post_runtime_resume(struct request_queue *q, int err) {}
1024 #endif
1025
1026 /*
1027  * blk_plug permits building a queue of related requests by holding the I/O
1028  * fragments for a short period. This allows merging of sequential requests
1029  * into single larger request. As the requests are moved from a per-task list to
1030  * the device's request_queue in a batch, this results in improved scalability
1031  * as the lock contention for request_queue lock is reduced.
1032  *
1033  * It is ok not to disable preemption when adding the request to the plug list
1034  * or when attempting a merge, because blk_schedule_flush_list() will only flush
1035  * the plug list when the task sleeps by itself. For details, please see
1036  * schedule() where blk_schedule_flush_plug() is called.
1037  */
1038 struct blk_plug {
1039         struct list_head list; /* requests */
1040         struct list_head mq_list; /* blk-mq requests */
1041         struct list_head cb_list; /* md requires an unplug callback */
1042 };
1043 #define BLK_MAX_REQUEST_COUNT 16
1044
1045 struct blk_plug_cb;
1046 typedef void (*blk_plug_cb_fn)(struct blk_plug_cb *, bool);
1047 struct blk_plug_cb {
1048         struct list_head list;
1049         blk_plug_cb_fn callback;
1050         void *data;
1051 };
1052 extern struct blk_plug_cb *blk_check_plugged(blk_plug_cb_fn unplug,
1053                                              void *data, int size);
1054 extern void blk_start_plug(struct blk_plug *);
1055 extern void blk_finish_plug(struct blk_plug *);
1056 extern void blk_flush_plug_list(struct blk_plug *, bool);
1057
1058 static inline void blk_flush_plug(struct task_struct *tsk)
1059 {
1060         struct blk_plug *plug = tsk->plug;
1061
1062         if (plug)
1063                 blk_flush_plug_list(plug, false);
1064 }
1065
1066 static inline void blk_schedule_flush_plug(struct task_struct *tsk)
1067 {
1068         struct blk_plug *plug = tsk->plug;
1069
1070         if (plug)
1071                 blk_flush_plug_list(plug, true);
1072 }
1073
1074 static inline bool blk_needs_flush_plug(struct task_struct *tsk)
1075 {
1076         struct blk_plug *plug = tsk->plug;
1077
1078         return plug &&
1079                 (!list_empty(&plug->list) ||
1080                  !list_empty(&plug->mq_list) ||
1081                  !list_empty(&plug->cb_list));
1082 }
1083
1084 /*
1085  * tag stuff
1086  */
1087 extern int blk_queue_start_tag(struct request_queue *, struct request *);
1088 extern struct request *blk_queue_find_tag(struct request_queue *, int);
1089 extern void blk_queue_end_tag(struct request_queue *, struct request *);
1090 extern int blk_queue_init_tags(struct request_queue *, int, struct blk_queue_tag *, int);
1091 extern void blk_queue_free_tags(struct request_queue *);
1092 extern int blk_queue_resize_tags(struct request_queue *, int);
1093 extern void blk_queue_invalidate_tags(struct request_queue *);
1094 extern struct blk_queue_tag *blk_init_tags(int, int);
1095 extern void blk_free_tags(struct blk_queue_tag *);
1096
1097 static inline struct request *blk_map_queue_find_tag(struct blk_queue_tag *bqt,
1098                                                 int tag)
1099 {
1100         if (unlikely(bqt == NULL || tag >= bqt->real_max_depth))
1101                 return NULL;
1102         return bqt->tag_index[tag];
1103 }
1104
1105 #define BLKDEV_DISCARD_SECURE  0x01    /* secure discard */
1106
1107 extern int blkdev_issue_flush(struct block_device *, gfp_t, sector_t *);
1108 extern int blkdev_issue_discard(struct block_device *bdev, sector_t sector,
1109                 sector_t nr_sects, gfp_t gfp_mask, unsigned long flags);
1110 extern int blkdev_issue_write_same(struct block_device *bdev, sector_t sector,
1111                 sector_t nr_sects, gfp_t gfp_mask, struct page *page);
1112 extern int blkdev_issue_zeroout(struct block_device *bdev, sector_t sector,
1113                 sector_t nr_sects, gfp_t gfp_mask, bool discard);
1114 static inline int sb_issue_discard(struct super_block *sb, sector_t block,
1115                 sector_t nr_blocks, gfp_t gfp_mask, unsigned long flags)
1116 {
1117         return blkdev_issue_discard(sb->s_bdev, block << (sb->s_blocksize_bits - 9),
1118                                     nr_blocks << (sb->s_blocksize_bits - 9),
1119                                     gfp_mask, flags);
1120 }
1121 static inline int sb_issue_zeroout(struct super_block *sb, sector_t block,
1122                 sector_t nr_blocks, gfp_t gfp_mask)
1123 {
1124         return blkdev_issue_zeroout(sb->s_bdev,
1125                                     block << (sb->s_blocksize_bits - 9),
1126                                     nr_blocks << (sb->s_blocksize_bits - 9),
1127                                     gfp_mask, true);
1128 }
1129
1130 extern int blk_verify_command(unsigned char *cmd, fmode_t has_write_perm);
1131
1132 enum blk_default_limits {
1133         BLK_MAX_SEGMENTS        = 128,
1134         BLK_SAFE_MAX_SECTORS    = 255,
1135         BLK_DEF_MAX_SECTORS     = 2560,
1136         BLK_MAX_SEGMENT_SIZE    = 65536,
1137         BLK_SEG_BOUNDARY_MASK   = 0xFFFFFFFFUL,
1138 };
1139
1140 #define blkdev_entry_to_request(entry) list_entry((entry), struct request, queuelist)
1141
1142 static inline unsigned long queue_bounce_pfn(struct request_queue *q)
1143 {
1144         return q->limits.bounce_pfn;
1145 }
1146
1147 static inline unsigned long queue_segment_boundary(struct request_queue *q)
1148 {
1149         return q->limits.seg_boundary_mask;
1150 }
1151
1152 static inline unsigned int queue_max_sectors(struct request_queue *q)
1153 {
1154         return q->limits.max_sectors;
1155 }
1156
1157 static inline unsigned int queue_max_hw_sectors(struct request_queue *q)
1158 {
1159         return q->limits.max_hw_sectors;
1160 }
1161
1162 static inline unsigned short queue_max_segments(struct request_queue *q)
1163 {
1164         return q->limits.max_segments;
1165 }
1166
1167 static inline unsigned int queue_max_segment_size(struct request_queue *q)
1168 {
1169         return q->limits.max_segment_size;
1170 }
1171
1172 static inline unsigned short queue_logical_block_size(struct request_queue *q)
1173 {
1174         int retval = 512;
1175
1176         if (q && q->limits.logical_block_size)
1177                 retval = q->limits.logical_block_size;
1178
1179         return retval;
1180 }
1181
1182 static inline unsigned short bdev_logical_block_size(struct block_device *bdev)
1183 {
1184         return queue_logical_block_size(bdev_get_queue(bdev));
1185 }
1186
1187 static inline unsigned int queue_physical_block_size(struct request_queue *q)
1188 {
1189         return q->limits.physical_block_size;
1190 }
1191
1192 static inline unsigned int bdev_physical_block_size(struct block_device *bdev)
1193 {
1194         return queue_physical_block_size(bdev_get_queue(bdev));
1195 }
1196
1197 static inline unsigned int queue_io_min(struct request_queue *q)
1198 {
1199         return q->limits.io_min;
1200 }
1201
1202 static inline int bdev_io_min(struct block_device *bdev)
1203 {
1204         return queue_io_min(bdev_get_queue(bdev));
1205 }
1206
1207 static inline unsigned int queue_io_opt(struct request_queue *q)
1208 {
1209         return q->limits.io_opt;
1210 }
1211
1212 static inline int bdev_io_opt(struct block_device *bdev)
1213 {
1214         return queue_io_opt(bdev_get_queue(bdev));
1215 }
1216
1217 static inline int queue_alignment_offset(struct request_queue *q)
1218 {
1219         if (q->limits.misaligned)
1220                 return -1;
1221
1222         return q->limits.alignment_offset;
1223 }
1224
1225 static inline int queue_limit_alignment_offset(struct queue_limits *lim, sector_t sector)
1226 {
1227         unsigned int granularity = max(lim->physical_block_size, lim->io_min);
1228         unsigned int alignment = sector_div(sector, granularity >> 9) << 9;
1229
1230         return (granularity + lim->alignment_offset - alignment) % granularity;
1231 }
1232
1233 static inline int bdev_alignment_offset(struct block_device *bdev)
1234 {
1235         struct request_queue *q = bdev_get_queue(bdev);
1236
1237         if (q->limits.misaligned)
1238                 return -1;
1239
1240         if (bdev != bdev->bd_contains)
1241                 return bdev->bd_part->alignment_offset;
1242
1243         return q->limits.alignment_offset;
1244 }
1245
1246 static inline int queue_discard_alignment(struct request_queue *q)
1247 {
1248         if (q->limits.discard_misaligned)
1249                 return -1;
1250
1251         return q->limits.discard_alignment;
1252 }
1253
1254 static inline int queue_limit_discard_alignment(struct queue_limits *lim, sector_t sector)
1255 {
1256         unsigned int alignment, granularity, offset;
1257
1258         if (!lim->max_discard_sectors)
1259                 return 0;
1260
1261         /* Why are these in bytes, not sectors? */
1262         alignment = lim->discard_alignment >> 9;
1263         granularity = lim->discard_granularity >> 9;
1264         if (!granularity)
1265                 return 0;
1266
1267         /* Offset of the partition start in 'granularity' sectors */
1268         offset = sector_div(sector, granularity);
1269
1270         /* And why do we do this modulus *again* in blkdev_issue_discard()? */
1271         offset = (granularity + alignment - offset) % granularity;
1272
1273         /* Turn it back into bytes, gaah */
1274         return offset << 9;
1275 }
1276
1277 static inline int bdev_discard_alignment(struct block_device *bdev)
1278 {
1279         struct request_queue *q = bdev_get_queue(bdev);
1280
1281         if (bdev != bdev->bd_contains)
1282                 return bdev->bd_part->discard_alignment;
1283
1284         return q->limits.discard_alignment;
1285 }
1286
1287 static inline unsigned int queue_discard_zeroes_data(struct request_queue *q)
1288 {
1289         if (q->limits.max_discard_sectors && q->limits.discard_zeroes_data == 1)
1290                 return 1;
1291
1292         return 0;
1293 }
1294
1295 static inline unsigned int bdev_discard_zeroes_data(struct block_device *bdev)
1296 {
1297         return queue_discard_zeroes_data(bdev_get_queue(bdev));
1298 }
1299
1300 static inline unsigned int bdev_write_same(struct block_device *bdev)
1301 {
1302         struct request_queue *q = bdev_get_queue(bdev);
1303
1304         if (q)
1305                 return q->limits.max_write_same_sectors;
1306
1307         return 0;
1308 }
1309
1310 static inline int queue_dma_alignment(struct request_queue *q)
1311 {
1312         return q ? q->dma_alignment : 511;
1313 }
1314
1315 static inline int blk_rq_aligned(struct request_queue *q, unsigned long addr,
1316                                  unsigned int len)
1317 {
1318         unsigned int alignment = queue_dma_alignment(q) | q->dma_pad_mask;
1319         return !(addr & alignment) && !(len & alignment);
1320 }
1321
1322 /* assumes size > 256 */
1323 static inline unsigned int blksize_bits(unsigned int size)
1324 {
1325         unsigned int bits = 8;
1326         do {
1327                 bits++;
1328                 size >>= 1;
1329         } while (size > 256);
1330         return bits;
1331 }
1332
1333 static inline unsigned int block_size(struct block_device *bdev)
1334 {
1335         return bdev->bd_block_size;
1336 }
1337
1338 static inline bool queue_flush_queueable(struct request_queue *q)
1339 {
1340         return !q->flush_not_queueable;
1341 }
1342
1343 typedef struct {struct page *v;} Sector;
1344
1345 unsigned char *read_dev_sector(struct block_device *, sector_t, Sector *);
1346
1347 static inline void put_dev_sector(Sector p)
1348 {
1349         page_cache_release(p.v);
1350 }
1351
1352 struct work_struct;
1353 int kblockd_schedule_work(struct work_struct *work);
1354 int kblockd_schedule_delayed_work(struct delayed_work *dwork, unsigned long delay);
1355 int kblockd_schedule_delayed_work_on(int cpu, struct delayed_work *dwork, unsigned long delay);
1356
1357 #ifdef CONFIG_BLK_CGROUP
1358 /*
1359  * This should not be using sched_clock(). A real patch is in progress
1360  * to fix this up, until that is in place we need to disable preemption
1361  * around sched_clock() in this function and set_io_start_time_ns().
1362  */
1363 static inline void set_start_time_ns(struct request *req)
1364 {
1365         preempt_disable();
1366         req->start_time_ns = sched_clock();
1367         preempt_enable();
1368 }
1369
1370 static inline void set_io_start_time_ns(struct request *req)
1371 {
1372         preempt_disable();
1373         req->io_start_time_ns = sched_clock();
1374         preempt_enable();
1375 }
1376
1377 static inline uint64_t rq_start_time_ns(struct request *req)
1378 {
1379         return req->start_time_ns;
1380 }
1381
1382 static inline uint64_t rq_io_start_time_ns(struct request *req)
1383 {
1384         return req->io_start_time_ns;
1385 }
1386 #else
1387 static inline void set_start_time_ns(struct request *req) {}
1388 static inline void set_io_start_time_ns(struct request *req) {}
1389 static inline uint64_t rq_start_time_ns(struct request *req)
1390 {
1391         return 0;
1392 }
1393 static inline uint64_t rq_io_start_time_ns(struct request *req)
1394 {
1395         return 0;
1396 }
1397 #endif
1398
1399 #define MODULE_ALIAS_BLOCKDEV(major,minor) \
1400         MODULE_ALIAS("block-major-" __stringify(major) "-" __stringify(minor))
1401 #define MODULE_ALIAS_BLOCKDEV_MAJOR(major) \
1402         MODULE_ALIAS("block-major-" __stringify(major) "-*")
1403
1404 #if defined(CONFIG_BLK_DEV_INTEGRITY)
1405
1406 enum blk_integrity_flags {
1407         BLK_INTEGRITY_VERIFY            = 1 << 0,
1408         BLK_INTEGRITY_GENERATE          = 1 << 1,
1409         BLK_INTEGRITY_DEVICE_CAPABLE    = 1 << 2,
1410         BLK_INTEGRITY_IP_CHECKSUM       = 1 << 3,
1411 };
1412
1413 struct blk_integrity_iter {
1414         void                    *prot_buf;
1415         void                    *data_buf;
1416         sector_t                seed;
1417         unsigned int            data_size;
1418         unsigned short          interval;
1419         const char              *disk_name;
1420 };
1421
1422 typedef int (integrity_processing_fn) (struct blk_integrity_iter *);
1423
1424 struct blk_integrity {
1425         integrity_processing_fn *generate_fn;
1426         integrity_processing_fn *verify_fn;
1427
1428         unsigned short          flags;
1429         unsigned short          tuple_size;
1430         unsigned short          interval;
1431         unsigned short          tag_size;
1432
1433         const char              *name;
1434
1435         struct kobject          kobj;
1436 };
1437
1438 extern bool blk_integrity_is_initialized(struct gendisk *);
1439 extern int blk_integrity_register(struct gendisk *, struct blk_integrity *);
1440 extern void blk_integrity_unregister(struct gendisk *);
1441 extern int blk_integrity_compare(struct gendisk *, struct gendisk *);
1442 extern int blk_rq_map_integrity_sg(struct request_queue *, struct bio *,
1443                                    struct scatterlist *);
1444 extern int blk_rq_count_integrity_sg(struct request_queue *, struct bio *);
1445 extern bool blk_integrity_merge_rq(struct request_queue *, struct request *,
1446                                    struct request *);
1447 extern bool blk_integrity_merge_bio(struct request_queue *, struct request *,
1448                                     struct bio *);
1449
1450 static inline
1451 struct blk_integrity *bdev_get_integrity(struct block_device *bdev)
1452 {
1453         return bdev->bd_disk->integrity;
1454 }
1455
1456 static inline struct blk_integrity *blk_get_integrity(struct gendisk *disk)
1457 {
1458         return disk->integrity;
1459 }
1460
1461 static inline bool blk_integrity_rq(struct request *rq)
1462 {
1463         return rq->cmd_flags & REQ_INTEGRITY;
1464 }
1465
1466 static inline void blk_queue_max_integrity_segments(struct request_queue *q,
1467                                                     unsigned int segs)
1468 {
1469         q->limits.max_integrity_segments = segs;
1470 }
1471
1472 static inline unsigned short
1473 queue_max_integrity_segments(struct request_queue *q)
1474 {
1475         return q->limits.max_integrity_segments;
1476 }
1477
1478 #else /* CONFIG_BLK_DEV_INTEGRITY */
1479
1480 struct bio;
1481 struct block_device;
1482 struct gendisk;
1483 struct blk_integrity;
1484
1485 static inline int blk_integrity_rq(struct request *rq)
1486 {
1487         return 0;
1488 }
1489 static inline int blk_rq_count_integrity_sg(struct request_queue *q,
1490                                             struct bio *b)
1491 {
1492         return 0;
1493 }
1494 static inline int blk_rq_map_integrity_sg(struct request_queue *q,
1495                                           struct bio *b,
1496                                           struct scatterlist *s)
1497 {
1498         return 0;
1499 }
1500 static inline struct blk_integrity *bdev_get_integrity(struct block_device *b)
1501 {
1502         return NULL;
1503 }
1504 static inline struct blk_integrity *blk_get_integrity(struct gendisk *disk)
1505 {
1506         return NULL;
1507 }
1508 static inline int blk_integrity_compare(struct gendisk *a, struct gendisk *b)
1509 {
1510         return 0;
1511 }
1512 static inline int blk_integrity_register(struct gendisk *d,
1513                                          struct blk_integrity *b)
1514 {
1515         return 0;
1516 }
1517 static inline void blk_integrity_unregister(struct gendisk *d)
1518 {
1519 }
1520 static inline void blk_queue_max_integrity_segments(struct request_queue *q,
1521                                                     unsigned int segs)
1522 {
1523 }
1524 static inline unsigned short queue_max_integrity_segments(struct request_queue *q)
1525 {
1526         return 0;
1527 }
1528 static inline bool blk_integrity_merge_rq(struct request_queue *rq,
1529                                           struct request *r1,
1530                                           struct request *r2)
1531 {
1532         return true;
1533 }
1534 static inline bool blk_integrity_merge_bio(struct request_queue *rq,
1535                                            struct request *r,
1536                                            struct bio *b)
1537 {
1538         return true;
1539 }
1540 static inline bool blk_integrity_is_initialized(struct gendisk *g)
1541 {
1542         return 0;
1543 }
1544
1545 #endif /* CONFIG_BLK_DEV_INTEGRITY */
1546
1547 struct block_device_operations {
1548         int (*open) (struct block_device *, fmode_t);
1549         void (*release) (struct gendisk *, fmode_t);
1550         int (*rw_page)(struct block_device *, sector_t, struct page *, int rw);
1551         int (*ioctl) (struct block_device *, fmode_t, unsigned, unsigned long);
1552         int (*compat_ioctl) (struct block_device *, fmode_t, unsigned, unsigned long);
1553         long (*direct_access)(struct block_device *, sector_t,
1554                                         void **, unsigned long *pfn, long size);
1555         unsigned int (*check_events) (struct gendisk *disk,
1556                                       unsigned int clearing);
1557         /* ->media_changed() is DEPRECATED, use ->check_events() instead */
1558         int (*media_changed) (struct gendisk *);
1559         void (*unlock_native_capacity) (struct gendisk *);
1560         int (*revalidate_disk) (struct gendisk *);
1561         int (*getgeo)(struct block_device *, struct hd_geometry *);
1562         /* this callback is with swap_lock and sometimes page table lock held */
1563         void (*swap_slot_free_notify) (struct block_device *, unsigned long);
1564         struct module *owner;
1565 };
1566
1567 extern int __blkdev_driver_ioctl(struct block_device *, fmode_t, unsigned int,
1568                                  unsigned long);
1569 extern int bdev_read_page(struct block_device *, sector_t, struct page *);
1570 extern int bdev_write_page(struct block_device *, sector_t, struct page *,
1571                                                 struct writeback_control *);
1572 extern long bdev_direct_access(struct block_device *, sector_t, void **addr,
1573                                                 unsigned long *pfn, long size);
1574 #else /* CONFIG_BLOCK */
1575
1576 struct block_device;
1577
1578 /*
1579  * stubs for when the block layer is configured out
1580  */
1581 #define buffer_heads_over_limit 0
1582
1583 static inline long nr_blockdev_pages(void)
1584 {
1585         return 0;
1586 }
1587
1588 struct blk_plug {
1589 };
1590
1591 static inline void blk_start_plug(struct blk_plug *plug)
1592 {
1593 }
1594
1595 static inline void blk_finish_plug(struct blk_plug *plug)
1596 {
1597 }
1598
1599 static inline void blk_flush_plug(struct task_struct *task)
1600 {
1601 }
1602
1603 static inline void blk_schedule_flush_plug(struct task_struct *task)
1604 {
1605 }
1606
1607
1608 static inline bool blk_needs_flush_plug(struct task_struct *tsk)
1609 {
1610         return false;
1611 }
1612
1613 static inline int blkdev_issue_flush(struct block_device *bdev, gfp_t gfp_mask,
1614                                      sector_t *error_sector)
1615 {
1616         return 0;
1617 }
1618
1619 #endif /* CONFIG_BLOCK */
1620
1621 #endif