1// SPDX-License-Identifier: GPL-2.0
2/*
3 *  MQ Deadline i/o scheduler - adaptation of the legacy deadline scheduler,
4 *  for the blk-mq scheduling framework
5 *
6 *  Copyright (C) 2016 Jens Axboe <axboe@kernel.dk>
7 */
8#include <linux/kernel.h>
9#include <linux/fs.h>
10#include <linux/blkdev.h>
11#include <linux/bio.h>
12#include <linux/module.h>
13#include <linux/slab.h>
14#include <linux/init.h>
15#include <linux/compiler.h>
16#include <linux/rbtree.h>
17#include <linux/sbitmap.h>
18
19#include <trace/events/block.h>
20
21#include "elevator.h"
22#include "blk.h"
23#include "blk-mq.h"
24#include "blk-mq-debugfs.h"
25#include "blk-mq-sched.h"
26
27/*
28 * See Documentation/block/deadline-iosched.rst
29 */
30static const int read_expire = HZ / 2;  /* max time before a read is submitted. */
31static const int write_expire = 5 * HZ; /* ditto for writes, these limits are SOFT! */
32/*
33 * Time after which to dispatch lower priority requests even if higher
34 * priority requests are pending.
35 */
36static const int prio_aging_expire = 10 * HZ;
37static const int writes_starved = 2;    /* max times reads can starve a write */
38static const int fifo_batch = 16;       /* # of sequential requests treated as one
39				     by the above parameters. For throughput. */
40
41enum dd_data_dir {
42	DD_READ		= READ,
43	DD_WRITE	= WRITE,
44};
45
46enum { DD_DIR_COUNT = 2 };
47
48enum dd_prio {
49	DD_RT_PRIO	= 0,
50	DD_BE_PRIO	= 1,
51	DD_IDLE_PRIO	= 2,
52	DD_PRIO_MAX	= 2,
53};
54
55enum { DD_PRIO_COUNT = 3 };
56
57/*
58 * I/O statistics per I/O priority. It is fine if these counters overflow.
59 * What matters is that these counters are at least as wide as
60 * log2(max_outstanding_requests).
61 */
62struct io_stats_per_prio {
63	uint32_t inserted;
64	uint32_t merged;
65	uint32_t dispatched;
66	atomic_t completed;
67};
68
69/*
70 * Deadline scheduler data per I/O priority (enum dd_prio). Requests are
71 * present on both sort_list[] and fifo_list[].
72 */
73struct dd_per_prio {
74	struct list_head dispatch;
75	struct rb_root sort_list[DD_DIR_COUNT];
76	struct list_head fifo_list[DD_DIR_COUNT];
77	/* Position of the most recently dispatched request. */
78	sector_t latest_pos[DD_DIR_COUNT];
79	struct io_stats_per_prio stats;
80};
81
82struct deadline_data {
83	/*
84	 * run time data
85	 */
86
87	struct dd_per_prio per_prio[DD_PRIO_COUNT];
88
89	/* Data direction of latest dispatched request. */
90	enum dd_data_dir last_dir;
91	unsigned int batching;		/* number of sequential requests made */
92	unsigned int starved;		/* times reads have starved writes */
93
94	/*
95	 * settings that change how the i/o scheduler behaves
96	 */
97	int fifo_expire[DD_DIR_COUNT];
98	int fifo_batch;
99	int writes_starved;
100	int front_merges;
101	u32 async_depth;
102	int prio_aging_expire;
103
104	spinlock_t lock;
105};
106
107/* Maps an I/O priority class to a deadline scheduler priority. */
108static const enum dd_prio ioprio_class_to_prio[] = {
109	[IOPRIO_CLASS_NONE]	= DD_BE_PRIO,
110	[IOPRIO_CLASS_RT]	= DD_RT_PRIO,
111	[IOPRIO_CLASS_BE]	= DD_BE_PRIO,
112	[IOPRIO_CLASS_IDLE]	= DD_IDLE_PRIO,
113};
114
115static inline struct rb_root *
116deadline_rb_root(struct dd_per_prio *per_prio, struct request *rq)
117{
118	return &per_prio->sort_list[rq_data_dir(rq)];
119}
120
121/*
122 * Returns the I/O priority class (IOPRIO_CLASS_*) that has been assigned to a
123 * request.
124 */
125static u8 dd_rq_ioclass(struct request *rq)
126{
127	return IOPRIO_PRIO_CLASS(req_get_ioprio(rq));
128}
129
130/*
131 * Return the first request for which blk_rq_pos() >= @pos.
132 */
133static inline struct request *deadline_from_pos(struct dd_per_prio *per_prio,
134				enum dd_data_dir data_dir, sector_t pos)
135{
136	struct rb_node *node = per_prio->sort_list[data_dir].rb_node;
137	struct request *rq, *res = NULL;
138
139	if (!node)
140		return NULL;
141
142	rq = rb_entry_rq(node);
143	while (node) {
144		rq = rb_entry_rq(node);
145		if (blk_rq_pos(rq) >= pos) {
146			res = rq;
147			node = node->rb_left;
148		} else {
149			node = node->rb_right;
150		}
151	}
152	return res;
153}
154
155static void
156deadline_add_rq_rb(struct dd_per_prio *per_prio, struct request *rq)
157{
158	struct rb_root *root = deadline_rb_root(per_prio, rq);
159
160	elv_rb_add(root, rq);
161}
162
163static inline void
164deadline_del_rq_rb(struct dd_per_prio *per_prio, struct request *rq)
165{
166	elv_rb_del(deadline_rb_root(per_prio, rq), rq);
167}
168
169/*
170 * remove rq from rbtree and fifo.
171 */
172static void deadline_remove_request(struct request_queue *q,
173				    struct dd_per_prio *per_prio,
174				    struct request *rq)
175{
176	list_del_init(&rq->queuelist);
177
178	/*
179	 * We might not be on the rbtree, if we are doing an insert merge
180	 */
181	if (!RB_EMPTY_NODE(&rq->rb_node))
182		deadline_del_rq_rb(per_prio, rq);
183
184	elv_rqhash_del(q, rq);
185	if (q->last_merge == rq)
186		q->last_merge = NULL;
187}
188
189static void dd_request_merged(struct request_queue *q, struct request *req,
190			      enum elv_merge type)
191{
192	struct deadline_data *dd = q->elevator->elevator_data;
193	const u8 ioprio_class = dd_rq_ioclass(req);
194	const enum dd_prio prio = ioprio_class_to_prio[ioprio_class];
195	struct dd_per_prio *per_prio = &dd->per_prio[prio];
196
197	/*
198	 * if the merge was a front merge, we need to reposition request
199	 */
200	if (type == ELEVATOR_FRONT_MERGE) {
201		elv_rb_del(deadline_rb_root(per_prio, req), req);
202		deadline_add_rq_rb(per_prio, req);
203	}
204}
205
206/*
207 * Callback function that is invoked after @next has been merged into @req.
208 */
209static void dd_merged_requests(struct request_queue *q, struct request *req,
210			       struct request *next)
211{
212	struct deadline_data *dd = q->elevator->elevator_data;
213	const u8 ioprio_class = dd_rq_ioclass(next);
214	const enum dd_prio prio = ioprio_class_to_prio[ioprio_class];
215
216	lockdep_assert_held(&dd->lock);
217
218	dd->per_prio[prio].stats.merged++;
219
220	/*
221	 * if next expires before rq, assign its expire time to rq
222	 * and move into next position (next will be deleted) in fifo
223	 */
224	if (!list_empty(&req->queuelist) && !list_empty(&next->queuelist)) {
225		if (time_before((unsigned long)next->fifo_time,
226				(unsigned long)req->fifo_time)) {
227			list_move(&req->queuelist, &next->queuelist);
228			req->fifo_time = next->fifo_time;
229		}
230	}
231
232	/*
233	 * kill knowledge of next, this one is a goner
234	 */
235	deadline_remove_request(q, &dd->per_prio[prio], next);
236}
237
238/*
239 * move an entry to dispatch queue
240 */
241static void
242deadline_move_request(struct deadline_data *dd, struct dd_per_prio *per_prio,
243		      struct request *rq)
244{
245	/*
246	 * take it off the sort and fifo list
247	 */
248	deadline_remove_request(rq->q, per_prio, rq);
249}
250
251/* Number of requests queued for a given priority level. */
252static u32 dd_queued(struct deadline_data *dd, enum dd_prio prio)
253{
254	const struct io_stats_per_prio *stats = &dd->per_prio[prio].stats;
255
256	lockdep_assert_held(&dd->lock);
257
258	return stats->inserted - atomic_read(&stats->completed);
259}
260
261/*
262 * deadline_check_fifo returns true if and only if there are expired requests
263 * in the FIFO list. Requires !list_empty(&dd->fifo_list[data_dir]).
264 */
265static inline bool deadline_check_fifo(struct dd_per_prio *per_prio,
266				       enum dd_data_dir data_dir)
267{
268	struct request *rq = rq_entry_fifo(per_prio->fifo_list[data_dir].next);
269
270	return time_is_before_eq_jiffies((unsigned long)rq->fifo_time);
271}
272
273/*
274 * For the specified data direction, return the next request to
275 * dispatch using arrival ordered lists.
276 */
277static struct request *
278deadline_fifo_request(struct deadline_data *dd, struct dd_per_prio *per_prio,
279		      enum dd_data_dir data_dir)
280{
281	if (list_empty(&per_prio->fifo_list[data_dir]))
282		return NULL;
283
284	return rq_entry_fifo(per_prio->fifo_list[data_dir].next);
285}
286
287/*
288 * For the specified data direction, return the next request to
289 * dispatch using sector position sorted lists.
290 */
291static struct request *
292deadline_next_request(struct deadline_data *dd, struct dd_per_prio *per_prio,
293		      enum dd_data_dir data_dir)
294{
295	return deadline_from_pos(per_prio, data_dir,
296				 per_prio->latest_pos[data_dir]);
297}
298
299/*
300 * Returns true if and only if @rq started after @latest_start where
301 * @latest_start is in jiffies.
302 */
303static bool started_after(struct deadline_data *dd, struct request *rq,
304			  unsigned long latest_start)
305{
306	unsigned long start_time = (unsigned long)rq->fifo_time;
307
308	start_time -= dd->fifo_expire[rq_data_dir(rq)];
309
310	return time_after(start_time, latest_start);
311}
312
313/*
314 * deadline_dispatch_requests selects the best request according to
315 * read/write expire, fifo_batch, etc and with a start time <= @latest_start.
316 */
317static struct request *__dd_dispatch_request(struct deadline_data *dd,
318					     struct dd_per_prio *per_prio,
319					     unsigned long latest_start)
320{
321	struct request *rq, *next_rq;
322	enum dd_data_dir data_dir;
323	enum dd_prio prio;
324	u8 ioprio_class;
325
326	lockdep_assert_held(&dd->lock);
327
328	if (!list_empty(&per_prio->dispatch)) {
329		rq = list_first_entry(&per_prio->dispatch, struct request,
330				      queuelist);
331		if (started_after(dd, rq, latest_start))
332			return NULL;
333		list_del_init(&rq->queuelist);
334		data_dir = rq_data_dir(rq);
335		goto done;
336	}
337
338	/*
339	 * batches are currently reads XOR writes
340	 */
341	rq = deadline_next_request(dd, per_prio, dd->last_dir);
342	if (rq && dd->batching < dd->fifo_batch) {
343		/* we have a next request and are still entitled to batch */
344		data_dir = rq_data_dir(rq);
345		goto dispatch_request;
346	}
347
348	/*
349	 * at this point we are not running a batch. select the appropriate
350	 * data direction (read / write)
351	 */
352
353	if (!list_empty(&per_prio->fifo_list[DD_READ])) {
354		BUG_ON(RB_EMPTY_ROOT(&per_prio->sort_list[DD_READ]));
355
356		if (deadline_fifo_request(dd, per_prio, DD_WRITE) &&
357		    (dd->starved++ >= dd->writes_starved))
358			goto dispatch_writes;
359
360		data_dir = DD_READ;
361
362		goto dispatch_find_request;
363	}
364
365	/*
366	 * there are either no reads or writes have been starved
367	 */
368
369	if (!list_empty(&per_prio->fifo_list[DD_WRITE])) {
370dispatch_writes:
371		BUG_ON(RB_EMPTY_ROOT(&per_prio->sort_list[DD_WRITE]));
372
373		dd->starved = 0;
374
375		data_dir = DD_WRITE;
376
377		goto dispatch_find_request;
378	}
379
380	return NULL;
381
382dispatch_find_request:
383	/*
384	 * we are not running a batch, find best request for selected data_dir
385	 */
386	next_rq = deadline_next_request(dd, per_prio, data_dir);
387	if (deadline_check_fifo(per_prio, data_dir) || !next_rq) {
388		/*
389		 * A deadline has expired, the last request was in the other
390		 * direction, or we have run out of higher-sectored requests.
391		 * Start again from the request with the earliest expiry time.
392		 */
393		rq = deadline_fifo_request(dd, per_prio, data_dir);
394	} else {
395		/*
396		 * The last req was the same dir and we have a next request in
397		 * sort order. No expired requests so continue on from here.
398		 */
399		rq = next_rq;
400	}
401
402	if (!rq)
403		return NULL;
404
405	dd->last_dir = data_dir;
406	dd->batching = 0;
407
408dispatch_request:
409	if (started_after(dd, rq, latest_start))
410		return NULL;
411
412	/*
413	 * rq is the selected appropriate request.
414	 */
415	dd->batching++;
416	deadline_move_request(dd, per_prio, rq);
417done:
418	ioprio_class = dd_rq_ioclass(rq);
419	prio = ioprio_class_to_prio[ioprio_class];
420	dd->per_prio[prio].latest_pos[data_dir] = blk_rq_pos(rq);
421	dd->per_prio[prio].stats.dispatched++;
422	rq->rq_flags |= RQF_STARTED;
423	return rq;
424}
425
426/*
427 * Check whether there are any requests with priority other than DD_RT_PRIO
428 * that were inserted more than prio_aging_expire jiffies ago.
429 */
430static struct request *dd_dispatch_prio_aged_requests(struct deadline_data *dd,
431						      unsigned long now)
432{
433	struct request *rq;
434	enum dd_prio prio;
435	int prio_cnt;
436
437	lockdep_assert_held(&dd->lock);
438
439	prio_cnt = !!dd_queued(dd, DD_RT_PRIO) + !!dd_queued(dd, DD_BE_PRIO) +
440		   !!dd_queued(dd, DD_IDLE_PRIO);
441	if (prio_cnt < 2)
442		return NULL;
443
444	for (prio = DD_BE_PRIO; prio <= DD_PRIO_MAX; prio++) {
445		rq = __dd_dispatch_request(dd, &dd->per_prio[prio],
446					   now - dd->prio_aging_expire);
447		if (rq)
448			return rq;
449	}
450
451	return NULL;
452}
453
454/*
455 * Called from blk_mq_run_hw_queue() -> __blk_mq_sched_dispatch_requests().
456 *
457 * One confusing aspect here is that we get called for a specific
458 * hardware queue, but we may return a request that is for a
459 * different hardware queue. This is because mq-deadline has shared
460 * state for all hardware queues, in terms of sorting, FIFOs, etc.
461 */
462static struct request *dd_dispatch_request(struct blk_mq_hw_ctx *hctx)
463{
464	struct deadline_data *dd = hctx->queue->elevator->elevator_data;
465	const unsigned long now = jiffies;
466	struct request *rq;
467	enum dd_prio prio;
468
469	spin_lock(&dd->lock);
470	rq = dd_dispatch_prio_aged_requests(dd, now);
471	if (rq)
472		goto unlock;
473
474	/*
475	 * Next, dispatch requests in priority order. Ignore lower priority
476	 * requests if any higher priority requests are pending.
477	 */
478	for (prio = 0; prio <= DD_PRIO_MAX; prio++) {
479		rq = __dd_dispatch_request(dd, &dd->per_prio[prio], now);
480		if (rq || dd_queued(dd, prio))
481			break;
482	}
483
484unlock:
485	spin_unlock(&dd->lock);
486
487	return rq;
488}
489
490/*
491 * Called by __blk_mq_alloc_request(). The shallow_depth value set by this
492 * function is used by __blk_mq_get_tag().
493 */
494static void dd_limit_depth(blk_opf_t opf, struct blk_mq_alloc_data *data)
495{
496	struct deadline_data *dd = data->q->elevator->elevator_data;
497
498	/* Do not throttle synchronous reads. */
499	if (op_is_sync(opf) && !op_is_write(opf))
500		return;
501
502	/*
503	 * Throttle asynchronous requests and writes such that these requests
504	 * do not block the allocation of synchronous requests.
505	 */
506	data->shallow_depth = dd->async_depth;
507}
508
509/* Called by blk_mq_update_nr_requests(). */
510static void dd_depth_updated(struct blk_mq_hw_ctx *hctx)
511{
512	struct request_queue *q = hctx->queue;
513	struct deadline_data *dd = q->elevator->elevator_data;
514	struct blk_mq_tags *tags = hctx->sched_tags;
515
516	dd->async_depth = max(1UL, 3 * q->nr_requests / 4);
517
518	sbitmap_queue_min_shallow_depth(&tags->bitmap_tags, dd->async_depth);
519}
520
521/* Called by blk_mq_init_hctx() and blk_mq_init_sched(). */
522static int dd_init_hctx(struct blk_mq_hw_ctx *hctx, unsigned int hctx_idx)
523{
524	dd_depth_updated(hctx);
525	return 0;
526}
527
528static void dd_exit_sched(struct elevator_queue *e)
529{
530	struct deadline_data *dd = e->elevator_data;
531	enum dd_prio prio;
532
533	for (prio = 0; prio <= DD_PRIO_MAX; prio++) {
534		struct dd_per_prio *per_prio = &dd->per_prio[prio];
535		const struct io_stats_per_prio *stats = &per_prio->stats;
536		uint32_t queued;
537
538		WARN_ON_ONCE(!list_empty(&per_prio->fifo_list[DD_READ]));
539		WARN_ON_ONCE(!list_empty(&per_prio->fifo_list[DD_WRITE]));
540
541		spin_lock(&dd->lock);
542		queued = dd_queued(dd, prio);
543		spin_unlock(&dd->lock);
544
545		WARN_ONCE(queued != 0,
546			  "statistics for priority %d: i %u m %u d %u c %u\n",
547			  prio, stats->inserted, stats->merged,
548			  stats->dispatched, atomic_read(&stats->completed));
549	}
550
551	kfree(dd);
552}
553
554/*
555 * initialize elevator private data (deadline_data).
556 */
557static int dd_init_sched(struct request_queue *q, struct elevator_type *e)
558{
559	struct deadline_data *dd;
560	struct elevator_queue *eq;
561	enum dd_prio prio;
562	int ret = -ENOMEM;
563
564	eq = elevator_alloc(q, e);
565	if (!eq)
566		return ret;
567
568	dd = kzalloc_node(sizeof(*dd), GFP_KERNEL, q->node);
569	if (!dd)
570		goto put_eq;
571
572	eq->elevator_data = dd;
573
574	for (prio = 0; prio <= DD_PRIO_MAX; prio++) {
575		struct dd_per_prio *per_prio = &dd->per_prio[prio];
576
577		INIT_LIST_HEAD(&per_prio->dispatch);
578		INIT_LIST_HEAD(&per_prio->fifo_list[DD_READ]);
579		INIT_LIST_HEAD(&per_prio->fifo_list[DD_WRITE]);
580		per_prio->sort_list[DD_READ] = RB_ROOT;
581		per_prio->sort_list[DD_WRITE] = RB_ROOT;
582	}
583	dd->fifo_expire[DD_READ] = read_expire;
584	dd->fifo_expire[DD_WRITE] = write_expire;
585	dd->writes_starved = writes_starved;
586	dd->front_merges = 1;
587	dd->last_dir = DD_WRITE;
588	dd->fifo_batch = fifo_batch;
589	dd->prio_aging_expire = prio_aging_expire;
590	spin_lock_init(&dd->lock);
591
592	/* We dispatch from request queue wide instead of hw queue */
593	blk_queue_flag_set(QUEUE_FLAG_SQ_SCHED, q);
594
595	q->elevator = eq;
596	return 0;
597
598put_eq:
599	kobject_put(&eq->kobj);
600	return ret;
601}
602
603/*
604 * Try to merge @bio into an existing request. If @bio has been merged into
605 * an existing request, store the pointer to that request into *@rq.
606 */
607static int dd_request_merge(struct request_queue *q, struct request **rq,
608			    struct bio *bio)
609{
610	struct deadline_data *dd = q->elevator->elevator_data;
611	const u8 ioprio_class = IOPRIO_PRIO_CLASS(bio->bi_ioprio);
612	const enum dd_prio prio = ioprio_class_to_prio[ioprio_class];
613	struct dd_per_prio *per_prio = &dd->per_prio[prio];
614	sector_t sector = bio_end_sector(bio);
615	struct request *__rq;
616
617	if (!dd->front_merges)
618		return ELEVATOR_NO_MERGE;
619
620	__rq = elv_rb_find(&per_prio->sort_list[bio_data_dir(bio)], sector);
621	if (__rq) {
622		BUG_ON(sector != blk_rq_pos(__rq));
623
624		if (elv_bio_merge_ok(__rq, bio)) {
625			*rq = __rq;
626			if (blk_discard_mergable(__rq))
627				return ELEVATOR_DISCARD_MERGE;
628			return ELEVATOR_FRONT_MERGE;
629		}
630	}
631
632	return ELEVATOR_NO_MERGE;
633}
634
635/*
636 * Attempt to merge a bio into an existing request. This function is called
637 * before @bio is associated with a request.
638 */
639static bool dd_bio_merge(struct request_queue *q, struct bio *bio,
640		unsigned int nr_segs)
641{
642	struct deadline_data *dd = q->elevator->elevator_data;
643	struct request *free = NULL;
644	bool ret;
645
646	spin_lock(&dd->lock);
647	ret = blk_mq_sched_try_merge(q, bio, nr_segs, &free);
648	spin_unlock(&dd->lock);
649
650	if (free)
651		blk_mq_free_request(free);
652
653	return ret;
654}
655
656/*
657 * add rq to rbtree and fifo
658 */
659static void dd_insert_request(struct blk_mq_hw_ctx *hctx, struct request *rq,
660			      blk_insert_t flags, struct list_head *free)
661{
662	struct request_queue *q = hctx->queue;
663	struct deadline_data *dd = q->elevator->elevator_data;
664	const enum dd_data_dir data_dir = rq_data_dir(rq);
665	u16 ioprio = req_get_ioprio(rq);
666	u8 ioprio_class = IOPRIO_PRIO_CLASS(ioprio);
667	struct dd_per_prio *per_prio;
668	enum dd_prio prio;
669
670	lockdep_assert_held(&dd->lock);
671
672	prio = ioprio_class_to_prio[ioprio_class];
673	per_prio = &dd->per_prio[prio];
674	if (!rq->elv.priv[0]) {
675		per_prio->stats.inserted++;
676		rq->elv.priv[0] = (void *)(uintptr_t)1;
677	}
678
679	if (blk_mq_sched_try_insert_merge(q, rq, free))
680		return;
681
682	trace_block_rq_insert(rq);
683
684	if (flags & BLK_MQ_INSERT_AT_HEAD) {
685		list_add(&rq->queuelist, &per_prio->dispatch);
686		rq->fifo_time = jiffies;
687	} else {
688		struct list_head *insert_before;
689
690		deadline_add_rq_rb(per_prio, rq);
691
692		if (rq_mergeable(rq)) {
693			elv_rqhash_add(q, rq);
694			if (!q->last_merge)
695				q->last_merge = rq;
696		}
697
698		/*
699		 * set expire time and add to fifo list
700		 */
701		rq->fifo_time = jiffies + dd->fifo_expire[data_dir];
702		insert_before = &per_prio->fifo_list[data_dir];
703		list_add_tail(&rq->queuelist, insert_before);
704	}
705}
706
707/*
708 * Called from blk_mq_insert_request() or blk_mq_dispatch_plug_list().
709 */
710static void dd_insert_requests(struct blk_mq_hw_ctx *hctx,
711			       struct list_head *list,
712			       blk_insert_t flags)
713{
714	struct request_queue *q = hctx->queue;
715	struct deadline_data *dd = q->elevator->elevator_data;
716	LIST_HEAD(free);
717
718	spin_lock(&dd->lock);
719	while (!list_empty(list)) {
720		struct request *rq;
721
722		rq = list_first_entry(list, struct request, queuelist);
723		list_del_init(&rq->queuelist);
724		dd_insert_request(hctx, rq, flags, &free);
725	}
726	spin_unlock(&dd->lock);
727
728	blk_mq_free_requests(&free);
729}
730
731/* Callback from inside blk_mq_rq_ctx_init(). */
732static void dd_prepare_request(struct request *rq)
733{
734	rq->elv.priv[0] = NULL;
735}
736
737/*
738 * Callback from inside blk_mq_free_request().
739 */
740static void dd_finish_request(struct request *rq)
741{
742	struct request_queue *q = rq->q;
743	struct deadline_data *dd = q->elevator->elevator_data;
744	const u8 ioprio_class = dd_rq_ioclass(rq);
745	const enum dd_prio prio = ioprio_class_to_prio[ioprio_class];
746	struct dd_per_prio *per_prio = &dd->per_prio[prio];
747
748	/*
749	 * The block layer core may call dd_finish_request() without having
750	 * called dd_insert_requests(). Skip requests that bypassed I/O
751	 * scheduling. See also blk_mq_request_bypass_insert().
752	 */
753	if (rq->elv.priv[0])
754		atomic_inc(&per_prio->stats.completed);
755}
756
757static bool dd_has_work_for_prio(struct dd_per_prio *per_prio)
758{
759	return !list_empty_careful(&per_prio->dispatch) ||
760		!list_empty_careful(&per_prio->fifo_list[DD_READ]) ||
761		!list_empty_careful(&per_prio->fifo_list[DD_WRITE]);
762}
763
764static bool dd_has_work(struct blk_mq_hw_ctx *hctx)
765{
766	struct deadline_data *dd = hctx->queue->elevator->elevator_data;
767	enum dd_prio prio;
768
769	for (prio = 0; prio <= DD_PRIO_MAX; prio++)
770		if (dd_has_work_for_prio(&dd->per_prio[prio]))
771			return true;
772
773	return false;
774}
775
776/*
777 * sysfs parts below
778 */
779#define SHOW_INT(__FUNC, __VAR)						\
780static ssize_t __FUNC(struct elevator_queue *e, char *page)		\
781{									\
782	struct deadline_data *dd = e->elevator_data;			\
783									\
784	return sysfs_emit(page, "%d\n", __VAR);				\
785}
786#define SHOW_JIFFIES(__FUNC, __VAR) SHOW_INT(__FUNC, jiffies_to_msecs(__VAR))
787SHOW_JIFFIES(deadline_read_expire_show, dd->fifo_expire[DD_READ]);
788SHOW_JIFFIES(deadline_write_expire_show, dd->fifo_expire[DD_WRITE]);
789SHOW_JIFFIES(deadline_prio_aging_expire_show, dd->prio_aging_expire);
790SHOW_INT(deadline_writes_starved_show, dd->writes_starved);
791SHOW_INT(deadline_front_merges_show, dd->front_merges);
792SHOW_INT(deadline_async_depth_show, dd->async_depth);
793SHOW_INT(deadline_fifo_batch_show, dd->fifo_batch);
794#undef SHOW_INT
795#undef SHOW_JIFFIES
796
797#define STORE_FUNCTION(__FUNC, __PTR, MIN, MAX, __CONV)			\
798static ssize_t __FUNC(struct elevator_queue *e, const char *page, size_t count)	\
799{									\
800	struct deadline_data *dd = e->elevator_data;			\
801	int __data, __ret;						\
802									\
803	__ret = kstrtoint(page, 0, &__data);				\
804	if (__ret < 0)							\
805		return __ret;						\
806	if (__data < (MIN))						\
807		__data = (MIN);						\
808	else if (__data > (MAX))					\
809		__data = (MAX);						\
810	*(__PTR) = __CONV(__data);					\
811	return count;							\
812}
813#define STORE_INT(__FUNC, __PTR, MIN, MAX)				\
814	STORE_FUNCTION(__FUNC, __PTR, MIN, MAX, )
815#define STORE_JIFFIES(__FUNC, __PTR, MIN, MAX)				\
816	STORE_FUNCTION(__FUNC, __PTR, MIN, MAX, msecs_to_jiffies)
817STORE_JIFFIES(deadline_read_expire_store, &dd->fifo_expire[DD_READ], 0, INT_MAX);
818STORE_JIFFIES(deadline_write_expire_store, &dd->fifo_expire[DD_WRITE], 0, INT_MAX);
819STORE_JIFFIES(deadline_prio_aging_expire_store, &dd->prio_aging_expire, 0, INT_MAX);
820STORE_INT(deadline_writes_starved_store, &dd->writes_starved, INT_MIN, INT_MAX);
821STORE_INT(deadline_front_merges_store, &dd->front_merges, 0, 1);
822STORE_INT(deadline_async_depth_store, &dd->async_depth, 1, INT_MAX);
823STORE_INT(deadline_fifo_batch_store, &dd->fifo_batch, 0, INT_MAX);
824#undef STORE_FUNCTION
825#undef STORE_INT
826#undef STORE_JIFFIES
827
828#define DD_ATTR(name) \
829	__ATTR(name, 0644, deadline_##name##_show, deadline_##name##_store)
830
831static struct elv_fs_entry deadline_attrs[] = {
832	DD_ATTR(read_expire),
833	DD_ATTR(write_expire),
834	DD_ATTR(writes_starved),
835	DD_ATTR(front_merges),
836	DD_ATTR(async_depth),
837	DD_ATTR(fifo_batch),
838	DD_ATTR(prio_aging_expire),
839	__ATTR_NULL
840};
841
842#ifdef CONFIG_BLK_DEBUG_FS
843#define DEADLINE_DEBUGFS_DDIR_ATTRS(prio, data_dir, name)		\
844static void *deadline_##name##_fifo_start(struct seq_file *m,		\
845					  loff_t *pos)			\
846	__acquires(&dd->lock)						\
847{									\
848	struct request_queue *q = m->private;				\
849	struct deadline_data *dd = q->elevator->elevator_data;		\
850	struct dd_per_prio *per_prio = &dd->per_prio[prio];		\
851									\
852	spin_lock(&dd->lock);						\
853	return seq_list_start(&per_prio->fifo_list[data_dir], *pos);	\
854}									\
855									\
856static void *deadline_##name##_fifo_next(struct seq_file *m, void *v,	\
857					 loff_t *pos)			\
858{									\
859	struct request_queue *q = m->private;				\
860	struct deadline_data *dd = q->elevator->elevator_data;		\
861	struct dd_per_prio *per_prio = &dd->per_prio[prio];		\
862									\
863	return seq_list_next(v, &per_prio->fifo_list[data_dir], pos);	\
864}									\
865									\
866static void deadline_##name##_fifo_stop(struct seq_file *m, void *v)	\
867	__releases(&dd->lock)						\
868{									\
869	struct request_queue *q = m->private;				\
870	struct deadline_data *dd = q->elevator->elevator_data;		\
871									\
872	spin_unlock(&dd->lock);						\
873}									\
874									\
875static const struct seq_operations deadline_##name##_fifo_seq_ops = {	\
876	.start	= deadline_##name##_fifo_start,				\
877	.next	= deadline_##name##_fifo_next,				\
878	.stop	= deadline_##name##_fifo_stop,				\
879	.show	= blk_mq_debugfs_rq_show,				\
880};									\
881									\
882static int deadline_##name##_next_rq_show(void *data,			\
883					  struct seq_file *m)		\
884{									\
885	struct request_queue *q = data;					\
886	struct deadline_data *dd = q->elevator->elevator_data;		\
887	struct dd_per_prio *per_prio = &dd->per_prio[prio];		\
888	struct request *rq;						\
889									\
890	rq = deadline_from_pos(per_prio, data_dir,			\
891			       per_prio->latest_pos[data_dir]);		\
892	if (rq)								\
893		__blk_mq_debugfs_rq_show(m, rq);			\
894	return 0;							\
895}
896
897DEADLINE_DEBUGFS_DDIR_ATTRS(DD_RT_PRIO, DD_READ, read0);
898DEADLINE_DEBUGFS_DDIR_ATTRS(DD_RT_PRIO, DD_WRITE, write0);
899DEADLINE_DEBUGFS_DDIR_ATTRS(DD_BE_PRIO, DD_READ, read1);
900DEADLINE_DEBUGFS_DDIR_ATTRS(DD_BE_PRIO, DD_WRITE, write1);
901DEADLINE_DEBUGFS_DDIR_ATTRS(DD_IDLE_PRIO, DD_READ, read2);
902DEADLINE_DEBUGFS_DDIR_ATTRS(DD_IDLE_PRIO, DD_WRITE, write2);
903#undef DEADLINE_DEBUGFS_DDIR_ATTRS
904
905static int deadline_batching_show(void *data, struct seq_file *m)
906{
907	struct request_queue *q = data;
908	struct deadline_data *dd = q->elevator->elevator_data;
909
910	seq_printf(m, "%u\n", dd->batching);
911	return 0;
912}
913
914static int deadline_starved_show(void *data, struct seq_file *m)
915{
916	struct request_queue *q = data;
917	struct deadline_data *dd = q->elevator->elevator_data;
918
919	seq_printf(m, "%u\n", dd->starved);
920	return 0;
921}
922
923static int dd_async_depth_show(void *data, struct seq_file *m)
924{
925	struct request_queue *q = data;
926	struct deadline_data *dd = q->elevator->elevator_data;
927
928	seq_printf(m, "%u\n", dd->async_depth);
929	return 0;
930}
931
932static int dd_queued_show(void *data, struct seq_file *m)
933{
934	struct request_queue *q = data;
935	struct deadline_data *dd = q->elevator->elevator_data;
936	u32 rt, be, idle;
937
938	spin_lock(&dd->lock);
939	rt = dd_queued(dd, DD_RT_PRIO);
940	be = dd_queued(dd, DD_BE_PRIO);
941	idle = dd_queued(dd, DD_IDLE_PRIO);
942	spin_unlock(&dd->lock);
943
944	seq_printf(m, "%u %u %u\n", rt, be, idle);
945
946	return 0;
947}
948
949/* Number of requests owned by the block driver for a given priority. */
950static u32 dd_owned_by_driver(struct deadline_data *dd, enum dd_prio prio)
951{
952	const struct io_stats_per_prio *stats = &dd->per_prio[prio].stats;
953
954	lockdep_assert_held(&dd->lock);
955
956	return stats->dispatched + stats->merged -
957		atomic_read(&stats->completed);
958}
959
960static int dd_owned_by_driver_show(void *data, struct seq_file *m)
961{
962	struct request_queue *q = data;
963	struct deadline_data *dd = q->elevator->elevator_data;
964	u32 rt, be, idle;
965
966	spin_lock(&dd->lock);
967	rt = dd_owned_by_driver(dd, DD_RT_PRIO);
968	be = dd_owned_by_driver(dd, DD_BE_PRIO);
969	idle = dd_owned_by_driver(dd, DD_IDLE_PRIO);
970	spin_unlock(&dd->lock);
971
972	seq_printf(m, "%u %u %u\n", rt, be, idle);
973
974	return 0;
975}
976
977#define DEADLINE_DISPATCH_ATTR(prio)					\
978static void *deadline_dispatch##prio##_start(struct seq_file *m,	\
979					     loff_t *pos)		\
980	__acquires(&dd->lock)						\
981{									\
982	struct request_queue *q = m->private;				\
983	struct deadline_data *dd = q->elevator->elevator_data;		\
984	struct dd_per_prio *per_prio = &dd->per_prio[prio];		\
985									\
986	spin_lock(&dd->lock);						\
987	return seq_list_start(&per_prio->dispatch, *pos);		\
988}									\
989									\
990static void *deadline_dispatch##prio##_next(struct seq_file *m,		\
991					    void *v, loff_t *pos)	\
992{									\
993	struct request_queue *q = m->private;				\
994	struct deadline_data *dd = q->elevator->elevator_data;		\
995	struct dd_per_prio *per_prio = &dd->per_prio[prio];		\
996									\
997	return seq_list_next(v, &per_prio->dispatch, pos);		\
998}									\
999									\
1000static void deadline_dispatch##prio##_stop(struct seq_file *m, void *v)	\
1001	__releases(&dd->lock)						\
1002{									\
1003	struct request_queue *q = m->private;				\
1004	struct deadline_data *dd = q->elevator->elevator_data;		\
1005									\
1006	spin_unlock(&dd->lock);						\
1007}									\
1008									\
1009static const struct seq_operations deadline_dispatch##prio##_seq_ops = { \
1010	.start	= deadline_dispatch##prio##_start,			\
1011	.next	= deadline_dispatch##prio##_next,			\
1012	.stop	= deadline_dispatch##prio##_stop,			\
1013	.show	= blk_mq_debugfs_rq_show,				\
1014}
1015
1016DEADLINE_DISPATCH_ATTR(0);
1017DEADLINE_DISPATCH_ATTR(1);
1018DEADLINE_DISPATCH_ATTR(2);
1019#undef DEADLINE_DISPATCH_ATTR
1020
1021#define DEADLINE_QUEUE_DDIR_ATTRS(name)					\
1022	{#name "_fifo_list", 0400,					\
1023			.seq_ops = &deadline_##name##_fifo_seq_ops}
1024#define DEADLINE_NEXT_RQ_ATTR(name)					\
1025	{#name "_next_rq", 0400, deadline_##name##_next_rq_show}
1026static const struct blk_mq_debugfs_attr deadline_queue_debugfs_attrs[] = {
1027	DEADLINE_QUEUE_DDIR_ATTRS(read0),
1028	DEADLINE_QUEUE_DDIR_ATTRS(write0),
1029	DEADLINE_QUEUE_DDIR_ATTRS(read1),
1030	DEADLINE_QUEUE_DDIR_ATTRS(write1),
1031	DEADLINE_QUEUE_DDIR_ATTRS(read2),
1032	DEADLINE_QUEUE_DDIR_ATTRS(write2),
1033	DEADLINE_NEXT_RQ_ATTR(read0),
1034	DEADLINE_NEXT_RQ_ATTR(write0),
1035	DEADLINE_NEXT_RQ_ATTR(read1),
1036	DEADLINE_NEXT_RQ_ATTR(write1),
1037	DEADLINE_NEXT_RQ_ATTR(read2),
1038	DEADLINE_NEXT_RQ_ATTR(write2),
1039	{"batching", 0400, deadline_batching_show},
1040	{"starved", 0400, deadline_starved_show},
1041	{"async_depth", 0400, dd_async_depth_show},
1042	{"dispatch0", 0400, .seq_ops = &deadline_dispatch0_seq_ops},
1043	{"dispatch1", 0400, .seq_ops = &deadline_dispatch1_seq_ops},
1044	{"dispatch2", 0400, .seq_ops = &deadline_dispatch2_seq_ops},
1045	{"owned_by_driver", 0400, dd_owned_by_driver_show},
1046	{"queued", 0400, dd_queued_show},
1047	{},
1048};
1049#undef DEADLINE_QUEUE_DDIR_ATTRS
1050#endif
1051
1052static struct elevator_type mq_deadline = {
1053	.ops = {
1054		.depth_updated		= dd_depth_updated,
1055		.limit_depth		= dd_limit_depth,
1056		.insert_requests	= dd_insert_requests,
1057		.dispatch_request	= dd_dispatch_request,
1058		.prepare_request	= dd_prepare_request,
1059		.finish_request		= dd_finish_request,
1060		.next_request		= elv_rb_latter_request,
1061		.former_request		= elv_rb_former_request,
1062		.bio_merge		= dd_bio_merge,
1063		.request_merge		= dd_request_merge,
1064		.requests_merged	= dd_merged_requests,
1065		.request_merged		= dd_request_merged,
1066		.has_work		= dd_has_work,
1067		.init_sched		= dd_init_sched,
1068		.exit_sched		= dd_exit_sched,
1069		.init_hctx		= dd_init_hctx,
1070	},
1071
1072#ifdef CONFIG_BLK_DEBUG_FS
1073	.queue_debugfs_attrs = deadline_queue_debugfs_attrs,
1074#endif
1075	.elevator_attrs = deadline_attrs,
1076	.elevator_name = "mq-deadline",
1077	.elevator_alias = "deadline",
1078	.elevator_owner = THIS_MODULE,
1079};
1080MODULE_ALIAS("mq-deadline-iosched");
1081
1082static int __init deadline_init(void)
1083{
1084	return elv_register(&mq_deadline);
1085}
1086
1087static void __exit deadline_exit(void)
1088{
1089	elv_unregister(&mq_deadline);
1090}
1091
1092module_init(deadline_init);
1093module_exit(deadline_exit);
1094
1095MODULE_AUTHOR("Jens Axboe, Damien Le Moal and Bart Van Assche");
1096MODULE_LICENSE("GPL");
1097MODULE_DESCRIPTION("MQ deadline IO scheduler");
1098