]> asedeno.scripts.mit.edu Git - linux.git/blob - drivers/scsi/qedf/qedf_io.c
drivers: Remove explicit invocations of mmiowb()
[linux.git] / drivers / scsi / qedf / qedf_io.c
1 /*
2  *  QLogic FCoE Offload Driver
3  *  Copyright (c) 2016-2018 Cavium Inc.
4  *
5  *  This software is available under the terms of the GNU General Public License
6  *  (GPL) Version 2, available from the file COPYING in the main directory of
7  *  this source tree.
8  */
9 #include <linux/spinlock.h>
10 #include <linux/vmalloc.h>
11 #include "qedf.h"
12 #include <scsi/scsi_tcq.h>
13
14 void qedf_cmd_timer_set(struct qedf_ctx *qedf, struct qedf_ioreq *io_req,
15         unsigned int timer_msec)
16 {
17         queue_delayed_work(qedf->timer_work_queue, &io_req->timeout_work,
18             msecs_to_jiffies(timer_msec));
19 }
20
21 static void qedf_cmd_timeout(struct work_struct *work)
22 {
23
24         struct qedf_ioreq *io_req =
25             container_of(work, struct qedf_ioreq, timeout_work.work);
26         struct qedf_ctx *qedf;
27         struct qedf_rport *fcport;
28         u8 op = 0;
29
30         if (io_req == NULL) {
31                 QEDF_INFO(NULL, QEDF_LOG_IO, "io_req is NULL.\n");
32                 return;
33         }
34
35         fcport = io_req->fcport;
36         if (io_req->fcport == NULL) {
37                 QEDF_INFO(NULL, QEDF_LOG_IO,  "fcport is NULL.\n");
38                 return;
39         }
40
41         qedf = fcport->qedf;
42
43         switch (io_req->cmd_type) {
44         case QEDF_ABTS:
45                 if (qedf == NULL) {
46                         QEDF_INFO(NULL, QEDF_LOG_IO, "qedf is NULL for xid=0x%x.\n",
47                             io_req->xid);
48                         return;
49                 }
50
51                 QEDF_ERR((&qedf->dbg_ctx), "ABTS timeout, xid=0x%x.\n",
52                     io_req->xid);
53                 /* Cleanup timed out ABTS */
54                 qedf_initiate_cleanup(io_req, true);
55                 complete(&io_req->abts_done);
56
57                 /*
58                  * Need to call kref_put for reference taken when initiate_abts
59                  * was called since abts_compl won't be called now that we've
60                  * cleaned up the task.
61                  */
62                 kref_put(&io_req->refcount, qedf_release_cmd);
63
64                 /*
65                  * Now that the original I/O and the ABTS are complete see
66                  * if we need to reconnect to the target.
67                  */
68                 qedf_restart_rport(fcport);
69                 break;
70         case QEDF_ELS:
71                 kref_get(&io_req->refcount);
72                 /*
73                  * Don't attempt to clean an ELS timeout as any subseqeunt
74                  * ABTS or cleanup requests just hang.  For now just free
75                  * the resources of the original I/O and the RRQ
76                  */
77                 QEDF_ERR(&(qedf->dbg_ctx), "ELS timeout, xid=0x%x.\n",
78                           io_req->xid);
79                 io_req->event = QEDF_IOREQ_EV_ELS_TMO;
80                 /* Call callback function to complete command */
81                 if (io_req->cb_func && io_req->cb_arg) {
82                         op = io_req->cb_arg->op;
83                         io_req->cb_func(io_req->cb_arg);
84                         io_req->cb_arg = NULL;
85                 }
86                 qedf_initiate_cleanup(io_req, true);
87                 kref_put(&io_req->refcount, qedf_release_cmd);
88                 break;
89         case QEDF_SEQ_CLEANUP:
90                 QEDF_ERR(&(qedf->dbg_ctx), "Sequence cleanup timeout, "
91                     "xid=0x%x.\n", io_req->xid);
92                 qedf_initiate_cleanup(io_req, true);
93                 io_req->event = QEDF_IOREQ_EV_ELS_TMO;
94                 qedf_process_seq_cleanup_compl(qedf, NULL, io_req);
95                 break;
96         default:
97                 break;
98         }
99 }
100
101 void qedf_cmd_mgr_free(struct qedf_cmd_mgr *cmgr)
102 {
103         struct io_bdt *bdt_info;
104         struct qedf_ctx *qedf = cmgr->qedf;
105         size_t bd_tbl_sz;
106         u16 min_xid = QEDF_MIN_XID;
107         u16 max_xid = (FCOE_PARAMS_NUM_TASKS - 1);
108         int num_ios;
109         int i;
110         struct qedf_ioreq *io_req;
111
112         num_ios = max_xid - min_xid + 1;
113
114         /* Free fcoe_bdt_ctx structures */
115         if (!cmgr->io_bdt_pool)
116                 goto free_cmd_pool;
117
118         bd_tbl_sz = QEDF_MAX_BDS_PER_CMD * sizeof(struct scsi_sge);
119         for (i = 0; i < num_ios; i++) {
120                 bdt_info = cmgr->io_bdt_pool[i];
121                 if (bdt_info->bd_tbl) {
122                         dma_free_coherent(&qedf->pdev->dev, bd_tbl_sz,
123                             bdt_info->bd_tbl, bdt_info->bd_tbl_dma);
124                         bdt_info->bd_tbl = NULL;
125                 }
126         }
127
128         /* Destroy io_bdt pool */
129         for (i = 0; i < num_ios; i++) {
130                 kfree(cmgr->io_bdt_pool[i]);
131                 cmgr->io_bdt_pool[i] = NULL;
132         }
133
134         kfree(cmgr->io_bdt_pool);
135         cmgr->io_bdt_pool = NULL;
136
137 free_cmd_pool:
138
139         for (i = 0; i < num_ios; i++) {
140                 io_req = &cmgr->cmds[i];
141                 kfree(io_req->sgl_task_params);
142                 kfree(io_req->task_params);
143                 /* Make sure we free per command sense buffer */
144                 if (io_req->sense_buffer)
145                         dma_free_coherent(&qedf->pdev->dev,
146                             QEDF_SCSI_SENSE_BUFFERSIZE, io_req->sense_buffer,
147                             io_req->sense_buffer_dma);
148                 cancel_delayed_work_sync(&io_req->rrq_work);
149         }
150
151         /* Free command manager itself */
152         vfree(cmgr);
153 }
154
155 static void qedf_handle_rrq(struct work_struct *work)
156 {
157         struct qedf_ioreq *io_req =
158             container_of(work, struct qedf_ioreq, rrq_work.work);
159
160         qedf_send_rrq(io_req);
161
162 }
163
164 struct qedf_cmd_mgr *qedf_cmd_mgr_alloc(struct qedf_ctx *qedf)
165 {
166         struct qedf_cmd_mgr *cmgr;
167         struct io_bdt *bdt_info;
168         struct qedf_ioreq *io_req;
169         u16 xid;
170         int i;
171         int num_ios;
172         u16 min_xid = QEDF_MIN_XID;
173         u16 max_xid = (FCOE_PARAMS_NUM_TASKS - 1);
174
175         /* Make sure num_queues is already set before calling this function */
176         if (!qedf->num_queues) {
177                 QEDF_ERR(&(qedf->dbg_ctx), "num_queues is not set.\n");
178                 return NULL;
179         }
180
181         if (max_xid <= min_xid || max_xid == FC_XID_UNKNOWN) {
182                 QEDF_WARN(&(qedf->dbg_ctx), "Invalid min_xid 0x%x and "
183                            "max_xid 0x%x.\n", min_xid, max_xid);
184                 return NULL;
185         }
186
187         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_DISC, "min xid 0x%x, max xid "
188                    "0x%x.\n", min_xid, max_xid);
189
190         num_ios = max_xid - min_xid + 1;
191
192         cmgr = vzalloc(sizeof(struct qedf_cmd_mgr));
193         if (!cmgr) {
194                 QEDF_WARN(&(qedf->dbg_ctx), "Failed to alloc cmd mgr.\n");
195                 return NULL;
196         }
197
198         cmgr->qedf = qedf;
199         spin_lock_init(&cmgr->lock);
200
201         /*
202          * Initialize I/O request fields.
203          */
204         xid = QEDF_MIN_XID;
205
206         for (i = 0; i < num_ios; i++) {
207                 io_req = &cmgr->cmds[i];
208                 INIT_DELAYED_WORK(&io_req->timeout_work, qedf_cmd_timeout);
209
210                 io_req->xid = xid++;
211
212                 INIT_DELAYED_WORK(&io_req->rrq_work, qedf_handle_rrq);
213
214                 /* Allocate DMA memory to hold sense buffer */
215                 io_req->sense_buffer = dma_alloc_coherent(&qedf->pdev->dev,
216                     QEDF_SCSI_SENSE_BUFFERSIZE, &io_req->sense_buffer_dma,
217                     GFP_KERNEL);
218                 if (!io_req->sense_buffer)
219                         goto mem_err;
220
221                 /* Allocate task parameters to pass to f/w init funcions */
222                 io_req->task_params = kzalloc(sizeof(*io_req->task_params),
223                                               GFP_KERNEL);
224                 if (!io_req->task_params) {
225                         QEDF_ERR(&(qedf->dbg_ctx),
226                                  "Failed to allocate task_params for xid=0x%x\n",
227                                  i);
228                         goto mem_err;
229                 }
230
231                 /*
232                  * Allocate scatter/gather list info to pass to f/w init
233                  * functions.
234                  */
235                 io_req->sgl_task_params = kzalloc(
236                     sizeof(struct scsi_sgl_task_params), GFP_KERNEL);
237                 if (!io_req->sgl_task_params) {
238                         QEDF_ERR(&(qedf->dbg_ctx),
239                                  "Failed to allocate sgl_task_params for xid=0x%x\n",
240                                  i);
241                         goto mem_err;
242                 }
243         }
244
245         /* Allocate pool of io_bdts - one for each qedf_ioreq */
246         cmgr->io_bdt_pool = kmalloc_array(num_ios, sizeof(struct io_bdt *),
247             GFP_KERNEL);
248
249         if (!cmgr->io_bdt_pool) {
250                 QEDF_WARN(&(qedf->dbg_ctx), "Failed to alloc io_bdt_pool.\n");
251                 goto mem_err;
252         }
253
254         for (i = 0; i < num_ios; i++) {
255                 cmgr->io_bdt_pool[i] = kmalloc(sizeof(struct io_bdt),
256                     GFP_KERNEL);
257                 if (!cmgr->io_bdt_pool[i]) {
258                         QEDF_WARN(&(qedf->dbg_ctx),
259                                   "Failed to alloc io_bdt_pool[%d].\n", i);
260                         goto mem_err;
261                 }
262         }
263
264         for (i = 0; i < num_ios; i++) {
265                 bdt_info = cmgr->io_bdt_pool[i];
266                 bdt_info->bd_tbl = dma_alloc_coherent(&qedf->pdev->dev,
267                     QEDF_MAX_BDS_PER_CMD * sizeof(struct scsi_sge),
268                     &bdt_info->bd_tbl_dma, GFP_KERNEL);
269                 if (!bdt_info->bd_tbl) {
270                         QEDF_WARN(&(qedf->dbg_ctx),
271                                   "Failed to alloc bdt_tbl[%d].\n", i);
272                         goto mem_err;
273                 }
274         }
275         atomic_set(&cmgr->free_list_cnt, num_ios);
276         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
277             "cmgr->free_list_cnt=%d.\n",
278             atomic_read(&cmgr->free_list_cnt));
279
280         return cmgr;
281
282 mem_err:
283         qedf_cmd_mgr_free(cmgr);
284         return NULL;
285 }
286
287 struct qedf_ioreq *qedf_alloc_cmd(struct qedf_rport *fcport, u8 cmd_type)
288 {
289         struct qedf_ctx *qedf = fcport->qedf;
290         struct qedf_cmd_mgr *cmd_mgr = qedf->cmd_mgr;
291         struct qedf_ioreq *io_req = NULL;
292         struct io_bdt *bd_tbl;
293         u16 xid;
294         uint32_t free_sqes;
295         int i;
296         unsigned long flags;
297
298         free_sqes = atomic_read(&fcport->free_sqes);
299
300         if (!free_sqes) {
301                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
302                     "Returning NULL, free_sqes=%d.\n ",
303                     free_sqes);
304                 goto out_failed;
305         }
306
307         /* Limit the number of outstanding R/W tasks */
308         if ((atomic_read(&fcport->num_active_ios) >=
309             NUM_RW_TASKS_PER_CONNECTION)) {
310                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
311                     "Returning NULL, num_active_ios=%d.\n",
312                     atomic_read(&fcport->num_active_ios));
313                 goto out_failed;
314         }
315
316         /* Limit global TIDs certain tasks */
317         if (atomic_read(&cmd_mgr->free_list_cnt) <= GBL_RSVD_TASKS) {
318                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
319                     "Returning NULL, free_list_cnt=%d.\n",
320                     atomic_read(&cmd_mgr->free_list_cnt));
321                 goto out_failed;
322         }
323
324         spin_lock_irqsave(&cmd_mgr->lock, flags);
325         for (i = 0; i < FCOE_PARAMS_NUM_TASKS; i++) {
326                 io_req = &cmd_mgr->cmds[cmd_mgr->idx];
327                 cmd_mgr->idx++;
328                 if (cmd_mgr->idx == FCOE_PARAMS_NUM_TASKS)
329                         cmd_mgr->idx = 0;
330
331                 /* Check to make sure command was previously freed */
332                 if (!test_bit(QEDF_CMD_OUTSTANDING, &io_req->flags))
333                         break;
334         }
335
336         if (i == FCOE_PARAMS_NUM_TASKS) {
337                 spin_unlock_irqrestore(&cmd_mgr->lock, flags);
338                 goto out_failed;
339         }
340
341         set_bit(QEDF_CMD_OUTSTANDING, &io_req->flags);
342         spin_unlock_irqrestore(&cmd_mgr->lock, flags);
343
344         atomic_inc(&fcport->num_active_ios);
345         atomic_dec(&fcport->free_sqes);
346         xid = io_req->xid;
347         atomic_dec(&cmd_mgr->free_list_cnt);
348
349         io_req->cmd_mgr = cmd_mgr;
350         io_req->fcport = fcport;
351
352         /* Hold the io_req against deletion */
353         kref_init(&io_req->refcount);
354
355         /* Bind io_bdt for this io_req */
356         /* Have a static link between io_req and io_bdt_pool */
357         bd_tbl = io_req->bd_tbl = cmd_mgr->io_bdt_pool[xid];
358         if (bd_tbl == NULL) {
359                 QEDF_ERR(&(qedf->dbg_ctx), "bd_tbl is NULL, xid=%x.\n", xid);
360                 kref_put(&io_req->refcount, qedf_release_cmd);
361                 goto out_failed;
362         }
363         bd_tbl->io_req = io_req;
364         io_req->cmd_type = cmd_type;
365         io_req->tm_flags = 0;
366
367         /* Reset sequence offset data */
368         io_req->rx_buf_off = 0;
369         io_req->tx_buf_off = 0;
370         io_req->rx_id = 0xffff; /* No OX_ID */
371
372         return io_req;
373
374 out_failed:
375         /* Record failure for stats and return NULL to caller */
376         qedf->alloc_failures++;
377         return NULL;
378 }
379
380 static void qedf_free_mp_resc(struct qedf_ioreq *io_req)
381 {
382         struct qedf_mp_req *mp_req = &(io_req->mp_req);
383         struct qedf_ctx *qedf = io_req->fcport->qedf;
384         uint64_t sz = sizeof(struct scsi_sge);
385
386         /* clear tm flags */
387         if (mp_req->mp_req_bd) {
388                 dma_free_coherent(&qedf->pdev->dev, sz,
389                     mp_req->mp_req_bd, mp_req->mp_req_bd_dma);
390                 mp_req->mp_req_bd = NULL;
391         }
392         if (mp_req->mp_resp_bd) {
393                 dma_free_coherent(&qedf->pdev->dev, sz,
394                     mp_req->mp_resp_bd, mp_req->mp_resp_bd_dma);
395                 mp_req->mp_resp_bd = NULL;
396         }
397         if (mp_req->req_buf) {
398                 dma_free_coherent(&qedf->pdev->dev, QEDF_PAGE_SIZE,
399                     mp_req->req_buf, mp_req->req_buf_dma);
400                 mp_req->req_buf = NULL;
401         }
402         if (mp_req->resp_buf) {
403                 dma_free_coherent(&qedf->pdev->dev, QEDF_PAGE_SIZE,
404                     mp_req->resp_buf, mp_req->resp_buf_dma);
405                 mp_req->resp_buf = NULL;
406         }
407 }
408
409 void qedf_release_cmd(struct kref *ref)
410 {
411         struct qedf_ioreq *io_req =
412             container_of(ref, struct qedf_ioreq, refcount);
413         struct qedf_cmd_mgr *cmd_mgr = io_req->cmd_mgr;
414         struct qedf_rport *fcport = io_req->fcport;
415
416         if (io_req->cmd_type == QEDF_ELS ||
417             io_req->cmd_type == QEDF_TASK_MGMT_CMD)
418                 qedf_free_mp_resc(io_req);
419
420         atomic_inc(&cmd_mgr->free_list_cnt);
421         atomic_dec(&fcport->num_active_ios);
422         if (atomic_read(&fcport->num_active_ios) < 0)
423                 QEDF_WARN(&(fcport->qedf->dbg_ctx), "active_ios < 0.\n");
424
425         /* Increment task retry identifier now that the request is released */
426         io_req->task_retry_identifier++;
427
428         clear_bit(QEDF_CMD_OUTSTANDING, &io_req->flags);
429 }
430
431 static int qedf_split_bd(struct qedf_ioreq *io_req, u64 addr, int sg_len,
432         int bd_index)
433 {
434         struct scsi_sge *bd = io_req->bd_tbl->bd_tbl;
435         int frag_size, sg_frags;
436
437         sg_frags = 0;
438         while (sg_len) {
439                 if (sg_len > QEDF_BD_SPLIT_SZ)
440                         frag_size = QEDF_BD_SPLIT_SZ;
441                 else
442                         frag_size = sg_len;
443                 bd[bd_index + sg_frags].sge_addr.lo = U64_LO(addr);
444                 bd[bd_index + sg_frags].sge_addr.hi = U64_HI(addr);
445                 bd[bd_index + sg_frags].sge_len = (uint16_t)frag_size;
446
447                 addr += (u64)frag_size;
448                 sg_frags++;
449                 sg_len -= frag_size;
450         }
451         return sg_frags;
452 }
453
454 static int qedf_map_sg(struct qedf_ioreq *io_req)
455 {
456         struct scsi_cmnd *sc = io_req->sc_cmd;
457         struct Scsi_Host *host = sc->device->host;
458         struct fc_lport *lport = shost_priv(host);
459         struct qedf_ctx *qedf = lport_priv(lport);
460         struct scsi_sge *bd = io_req->bd_tbl->bd_tbl;
461         struct scatterlist *sg;
462         int byte_count = 0;
463         int sg_count = 0;
464         int bd_count = 0;
465         int sg_frags;
466         unsigned int sg_len;
467         u64 addr, end_addr;
468         int i;
469
470         sg_count = dma_map_sg(&qedf->pdev->dev, scsi_sglist(sc),
471             scsi_sg_count(sc), sc->sc_data_direction);
472
473         sg = scsi_sglist(sc);
474
475         /*
476          * New condition to send single SGE as cached-SGL with length less
477          * than 64k.
478          */
479         if ((sg_count == 1) && (sg_dma_len(sg) <=
480             QEDF_MAX_SGLEN_FOR_CACHESGL)) {
481                 sg_len = sg_dma_len(sg);
482                 addr = (u64)sg_dma_address(sg);
483
484                 bd[bd_count].sge_addr.lo = (addr & 0xffffffff);
485                 bd[bd_count].sge_addr.hi = (addr >> 32);
486                 bd[bd_count].sge_len = (u16)sg_len;
487
488                 return ++bd_count;
489         }
490
491         scsi_for_each_sg(sc, sg, sg_count, i) {
492                 sg_len = sg_dma_len(sg);
493                 addr = (u64)sg_dma_address(sg);
494                 end_addr = (u64)(addr + sg_len);
495
496                 /*
497                  * First s/g element in the list so check if the end_addr
498                  * is paged aligned. Also check to make sure the length is
499                  * at least page size.
500                  */
501                 if ((i == 0) && (sg_count > 1) &&
502                     ((end_addr % QEDF_PAGE_SIZE) ||
503                     sg_len < QEDF_PAGE_SIZE))
504                         io_req->use_slowpath = true;
505                 /*
506                  * Last s/g element so check if the start address is paged
507                  * aligned.
508                  */
509                 else if ((i == (sg_count - 1)) && (sg_count > 1) &&
510                     (addr % QEDF_PAGE_SIZE))
511                         io_req->use_slowpath = true;
512                 /*
513                  * Intermediate s/g element so check if start and end address
514                  * is page aligned.
515                  */
516                 else if ((i != 0) && (i != (sg_count - 1)) &&
517                     ((addr % QEDF_PAGE_SIZE) || (end_addr % QEDF_PAGE_SIZE)))
518                         io_req->use_slowpath = true;
519
520                 if (sg_len > QEDF_MAX_BD_LEN) {
521                         sg_frags = qedf_split_bd(io_req, addr, sg_len,
522                             bd_count);
523                 } else {
524                         sg_frags = 1;
525                         bd[bd_count].sge_addr.lo = U64_LO(addr);
526                         bd[bd_count].sge_addr.hi  = U64_HI(addr);
527                         bd[bd_count].sge_len = (uint16_t)sg_len;
528                 }
529
530                 bd_count += sg_frags;
531                 byte_count += sg_len;
532         }
533
534         if (byte_count != scsi_bufflen(sc))
535                 QEDF_ERR(&(qedf->dbg_ctx), "byte_count = %d != "
536                           "scsi_bufflen = %d, task_id = 0x%x.\n", byte_count,
537                            scsi_bufflen(sc), io_req->xid);
538
539         return bd_count;
540 }
541
542 static int qedf_build_bd_list_from_sg(struct qedf_ioreq *io_req)
543 {
544         struct scsi_cmnd *sc = io_req->sc_cmd;
545         struct scsi_sge *bd = io_req->bd_tbl->bd_tbl;
546         int bd_count;
547
548         if (scsi_sg_count(sc)) {
549                 bd_count = qedf_map_sg(io_req);
550                 if (bd_count == 0)
551                         return -ENOMEM;
552         } else {
553                 bd_count = 0;
554                 bd[0].sge_addr.lo = bd[0].sge_addr.hi = 0;
555                 bd[0].sge_len = 0;
556         }
557         io_req->bd_tbl->bd_valid = bd_count;
558
559         return 0;
560 }
561
562 static void qedf_build_fcp_cmnd(struct qedf_ioreq *io_req,
563                                   struct fcp_cmnd *fcp_cmnd)
564 {
565         struct scsi_cmnd *sc_cmd = io_req->sc_cmd;
566
567         /* fcp_cmnd is 32 bytes */
568         memset(fcp_cmnd, 0, FCP_CMND_LEN);
569
570         /* 8 bytes: SCSI LUN info */
571         int_to_scsilun(sc_cmd->device->lun,
572                         (struct scsi_lun *)&fcp_cmnd->fc_lun);
573
574         /* 4 bytes: flag info */
575         fcp_cmnd->fc_pri_ta = 0;
576         fcp_cmnd->fc_tm_flags = io_req->tm_flags;
577         fcp_cmnd->fc_flags = io_req->io_req_flags;
578         fcp_cmnd->fc_cmdref = 0;
579
580         /* Populate data direction */
581         if (io_req->cmd_type == QEDF_TASK_MGMT_CMD) {
582                 fcp_cmnd->fc_flags |= FCP_CFL_RDDATA;
583         } else {
584                 if (sc_cmd->sc_data_direction == DMA_TO_DEVICE)
585                         fcp_cmnd->fc_flags |= FCP_CFL_WRDATA;
586                 else if (sc_cmd->sc_data_direction == DMA_FROM_DEVICE)
587                         fcp_cmnd->fc_flags |= FCP_CFL_RDDATA;
588         }
589
590         fcp_cmnd->fc_pri_ta = FCP_PTA_SIMPLE;
591
592         /* 16 bytes: CDB information */
593         if (io_req->cmd_type != QEDF_TASK_MGMT_CMD)
594                 memcpy(fcp_cmnd->fc_cdb, sc_cmd->cmnd, sc_cmd->cmd_len);
595
596         /* 4 bytes: FCP data length */
597         fcp_cmnd->fc_dl = htonl(io_req->data_xfer_len);
598 }
599
600 static void  qedf_init_task(struct qedf_rport *fcport, struct fc_lport *lport,
601         struct qedf_ioreq *io_req, struct e4_fcoe_task_context *task_ctx,
602         struct fcoe_wqe *sqe)
603 {
604         enum fcoe_task_type task_type;
605         struct scsi_cmnd *sc_cmd = io_req->sc_cmd;
606         struct io_bdt *bd_tbl = io_req->bd_tbl;
607         u8 fcp_cmnd[32];
608         u32 tmp_fcp_cmnd[8];
609         int bd_count = 0;
610         struct qedf_ctx *qedf = fcport->qedf;
611         uint16_t cq_idx = smp_processor_id() % qedf->num_queues;
612         struct regpair sense_data_buffer_phys_addr;
613         u32 tx_io_size = 0;
614         u32 rx_io_size = 0;
615         int i, cnt;
616
617         /* Note init_initiator_rw_fcoe_task memsets the task context */
618         io_req->task = task_ctx;
619         memset(task_ctx, 0, sizeof(struct e4_fcoe_task_context));
620         memset(io_req->task_params, 0, sizeof(struct fcoe_task_params));
621         memset(io_req->sgl_task_params, 0, sizeof(struct scsi_sgl_task_params));
622
623         /* Set task type bassed on DMA directio of command */
624         if (io_req->cmd_type == QEDF_TASK_MGMT_CMD) {
625                 task_type = FCOE_TASK_TYPE_READ_INITIATOR;
626         } else {
627                 if (sc_cmd->sc_data_direction == DMA_TO_DEVICE) {
628                         task_type = FCOE_TASK_TYPE_WRITE_INITIATOR;
629                         tx_io_size = io_req->data_xfer_len;
630                 } else {
631                         task_type = FCOE_TASK_TYPE_READ_INITIATOR;
632                         rx_io_size = io_req->data_xfer_len;
633                 }
634         }
635
636         /* Setup the fields for fcoe_task_params */
637         io_req->task_params->context = task_ctx;
638         io_req->task_params->sqe = sqe;
639         io_req->task_params->task_type = task_type;
640         io_req->task_params->tx_io_size = tx_io_size;
641         io_req->task_params->rx_io_size = rx_io_size;
642         io_req->task_params->conn_cid = fcport->fw_cid;
643         io_req->task_params->itid = io_req->xid;
644         io_req->task_params->cq_rss_number = cq_idx;
645         io_req->task_params->is_tape_device = fcport->dev_type;
646
647         /* Fill in information for scatter/gather list */
648         if (io_req->cmd_type != QEDF_TASK_MGMT_CMD) {
649                 bd_count = bd_tbl->bd_valid;
650                 io_req->sgl_task_params->sgl = bd_tbl->bd_tbl;
651                 io_req->sgl_task_params->sgl_phys_addr.lo =
652                         U64_LO(bd_tbl->bd_tbl_dma);
653                 io_req->sgl_task_params->sgl_phys_addr.hi =
654                         U64_HI(bd_tbl->bd_tbl_dma);
655                 io_req->sgl_task_params->num_sges = bd_count;
656                 io_req->sgl_task_params->total_buffer_size =
657                     scsi_bufflen(io_req->sc_cmd);
658                 io_req->sgl_task_params->small_mid_sge =
659                         io_req->use_slowpath;
660         }
661
662         /* Fill in physical address of sense buffer */
663         sense_data_buffer_phys_addr.lo = U64_LO(io_req->sense_buffer_dma);
664         sense_data_buffer_phys_addr.hi = U64_HI(io_req->sense_buffer_dma);
665
666         /* fill FCP_CMND IU */
667         qedf_build_fcp_cmnd(io_req, (struct fcp_cmnd *)tmp_fcp_cmnd);
668
669         /* Swap fcp_cmnd since FC is big endian */
670         cnt = sizeof(struct fcp_cmnd) / sizeof(u32);
671         for (i = 0; i < cnt; i++) {
672                 tmp_fcp_cmnd[i] = cpu_to_be32(tmp_fcp_cmnd[i]);
673         }
674         memcpy(fcp_cmnd, tmp_fcp_cmnd, sizeof(struct fcp_cmnd));
675
676         init_initiator_rw_fcoe_task(io_req->task_params,
677                                     io_req->sgl_task_params,
678                                     sense_data_buffer_phys_addr,
679                                     io_req->task_retry_identifier, fcp_cmnd);
680
681         /* Increment SGL type counters */
682         if (bd_count == 1) {
683                 qedf->single_sge_ios++;
684                 io_req->sge_type = QEDF_IOREQ_SINGLE_SGE;
685         } else if (io_req->use_slowpath) {
686                 qedf->slow_sge_ios++;
687                 io_req->sge_type = QEDF_IOREQ_SLOW_SGE;
688         } else {
689                 qedf->fast_sge_ios++;
690                 io_req->sge_type = QEDF_IOREQ_FAST_SGE;
691         }
692 }
693
694 void qedf_init_mp_task(struct qedf_ioreq *io_req,
695         struct e4_fcoe_task_context *task_ctx, struct fcoe_wqe *sqe)
696 {
697         struct qedf_mp_req *mp_req = &(io_req->mp_req);
698         struct qedf_rport *fcport = io_req->fcport;
699         struct qedf_ctx *qedf = io_req->fcport->qedf;
700         struct fc_frame_header *fc_hdr;
701         struct fcoe_tx_mid_path_params task_fc_hdr;
702         struct scsi_sgl_task_params tx_sgl_task_params;
703         struct scsi_sgl_task_params rx_sgl_task_params;
704
705         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_DISC,
706                   "Initializing MP task for cmd_type=%d\n",
707                   io_req->cmd_type);
708
709         qedf->control_requests++;
710
711         memset(&tx_sgl_task_params, 0, sizeof(struct scsi_sgl_task_params));
712         memset(&rx_sgl_task_params, 0, sizeof(struct scsi_sgl_task_params));
713         memset(task_ctx, 0, sizeof(struct e4_fcoe_task_context));
714         memset(&task_fc_hdr, 0, sizeof(struct fcoe_tx_mid_path_params));
715
716         /* Setup the task from io_req for easy reference */
717         io_req->task = task_ctx;
718
719         /* Setup the fields for fcoe_task_params */
720         io_req->task_params->context = task_ctx;
721         io_req->task_params->sqe = sqe;
722         io_req->task_params->task_type = FCOE_TASK_TYPE_MIDPATH;
723         io_req->task_params->tx_io_size = io_req->data_xfer_len;
724         /* rx_io_size tells the f/w how large a response buffer we have */
725         io_req->task_params->rx_io_size = PAGE_SIZE;
726         io_req->task_params->conn_cid = fcport->fw_cid;
727         io_req->task_params->itid = io_req->xid;
728         /* Return middle path commands on CQ 0 */
729         io_req->task_params->cq_rss_number = 0;
730         io_req->task_params->is_tape_device = fcport->dev_type;
731
732         fc_hdr = &(mp_req->req_fc_hdr);
733         /* Set OX_ID and RX_ID based on driver task id */
734         fc_hdr->fh_ox_id = io_req->xid;
735         fc_hdr->fh_rx_id = htons(0xffff);
736
737         /* Set up FC header information */
738         task_fc_hdr.parameter = fc_hdr->fh_parm_offset;
739         task_fc_hdr.r_ctl = fc_hdr->fh_r_ctl;
740         task_fc_hdr.type = fc_hdr->fh_type;
741         task_fc_hdr.cs_ctl = fc_hdr->fh_cs_ctl;
742         task_fc_hdr.df_ctl = fc_hdr->fh_df_ctl;
743         task_fc_hdr.rx_id = fc_hdr->fh_rx_id;
744         task_fc_hdr.ox_id = fc_hdr->fh_ox_id;
745
746         /* Set up s/g list parameters for request buffer */
747         tx_sgl_task_params.sgl = mp_req->mp_req_bd;
748         tx_sgl_task_params.sgl_phys_addr.lo = U64_LO(mp_req->mp_req_bd_dma);
749         tx_sgl_task_params.sgl_phys_addr.hi = U64_HI(mp_req->mp_req_bd_dma);
750         tx_sgl_task_params.num_sges = 1;
751         /* Set PAGE_SIZE for now since sg element is that size ??? */
752         tx_sgl_task_params.total_buffer_size = io_req->data_xfer_len;
753         tx_sgl_task_params.small_mid_sge = 0;
754
755         /* Set up s/g list parameters for request buffer */
756         rx_sgl_task_params.sgl = mp_req->mp_resp_bd;
757         rx_sgl_task_params.sgl_phys_addr.lo = U64_LO(mp_req->mp_resp_bd_dma);
758         rx_sgl_task_params.sgl_phys_addr.hi = U64_HI(mp_req->mp_resp_bd_dma);
759         rx_sgl_task_params.num_sges = 1;
760         /* Set PAGE_SIZE for now since sg element is that size ??? */
761         rx_sgl_task_params.total_buffer_size = PAGE_SIZE;
762         rx_sgl_task_params.small_mid_sge = 0;
763
764
765         /*
766          * Last arg is 0 as previous code did not set that we wanted the
767          * fc header information.
768          */
769         init_initiator_midpath_unsolicited_fcoe_task(io_req->task_params,
770                                                      &task_fc_hdr,
771                                                      &tx_sgl_task_params,
772                                                      &rx_sgl_task_params, 0);
773
774         /* Midpath requests always consume 1 SGE */
775         qedf->single_sge_ios++;
776 }
777
778 /* Presumed that fcport->rport_lock is held */
779 u16 qedf_get_sqe_idx(struct qedf_rport *fcport)
780 {
781         uint16_t total_sqe = (fcport->sq_mem_size)/(sizeof(struct fcoe_wqe));
782         u16 rval;
783
784         rval = fcport->sq_prod_idx;
785
786         /* Adjust ring index */
787         fcport->sq_prod_idx++;
788         fcport->fw_sq_prod_idx++;
789         if (fcport->sq_prod_idx == total_sqe)
790                 fcport->sq_prod_idx = 0;
791
792         return rval;
793 }
794
795 void qedf_ring_doorbell(struct qedf_rport *fcport)
796 {
797         struct fcoe_db_data dbell = { 0 };
798
799         dbell.agg_flags = 0;
800
801         dbell.params |= DB_DEST_XCM << FCOE_DB_DATA_DEST_SHIFT;
802         dbell.params |= DB_AGG_CMD_SET << FCOE_DB_DATA_AGG_CMD_SHIFT;
803         dbell.params |= DQ_XCM_FCOE_SQ_PROD_CMD <<
804             FCOE_DB_DATA_AGG_VAL_SEL_SHIFT;
805
806         dbell.sq_prod = fcport->fw_sq_prod_idx;
807         writel(*(u32 *)&dbell, fcport->p_doorbell);
808         /* Make sure SQ index is updated so f/w prcesses requests in order */
809         wmb();
810 }
811
812 static void qedf_trace_io(struct qedf_rport *fcport, struct qedf_ioreq *io_req,
813                           int8_t direction)
814 {
815         struct qedf_ctx *qedf = fcport->qedf;
816         struct qedf_io_log *io_log;
817         struct scsi_cmnd *sc_cmd = io_req->sc_cmd;
818         unsigned long flags;
819         uint8_t op;
820
821         spin_lock_irqsave(&qedf->io_trace_lock, flags);
822
823         io_log = &qedf->io_trace_buf[qedf->io_trace_idx];
824         io_log->direction = direction;
825         io_log->task_id = io_req->xid;
826         io_log->port_id = fcport->rdata->ids.port_id;
827         io_log->lun = sc_cmd->device->lun;
828         io_log->op = op = sc_cmd->cmnd[0];
829         io_log->lba[0] = sc_cmd->cmnd[2];
830         io_log->lba[1] = sc_cmd->cmnd[3];
831         io_log->lba[2] = sc_cmd->cmnd[4];
832         io_log->lba[3] = sc_cmd->cmnd[5];
833         io_log->bufflen = scsi_bufflen(sc_cmd);
834         io_log->sg_count = scsi_sg_count(sc_cmd);
835         io_log->result = sc_cmd->result;
836         io_log->jiffies = jiffies;
837         io_log->refcount = kref_read(&io_req->refcount);
838
839         if (direction == QEDF_IO_TRACE_REQ) {
840                 /* For requests we only care abot the submission CPU */
841                 io_log->req_cpu = io_req->cpu;
842                 io_log->int_cpu = 0;
843                 io_log->rsp_cpu = 0;
844         } else if (direction == QEDF_IO_TRACE_RSP) {
845                 io_log->req_cpu = io_req->cpu;
846                 io_log->int_cpu = io_req->int_cpu;
847                 io_log->rsp_cpu = smp_processor_id();
848         }
849
850         io_log->sge_type = io_req->sge_type;
851
852         qedf->io_trace_idx++;
853         if (qedf->io_trace_idx == QEDF_IO_TRACE_SIZE)
854                 qedf->io_trace_idx = 0;
855
856         spin_unlock_irqrestore(&qedf->io_trace_lock, flags);
857 }
858
859 int qedf_post_io_req(struct qedf_rport *fcport, struct qedf_ioreq *io_req)
860 {
861         struct scsi_cmnd *sc_cmd = io_req->sc_cmd;
862         struct Scsi_Host *host = sc_cmd->device->host;
863         struct fc_lport *lport = shost_priv(host);
864         struct qedf_ctx *qedf = lport_priv(lport);
865         struct e4_fcoe_task_context *task_ctx;
866         u16 xid;
867         enum fcoe_task_type req_type = 0;
868         struct fcoe_wqe *sqe;
869         u16 sqe_idx;
870
871         /* Initialize rest of io_req fileds */
872         io_req->data_xfer_len = scsi_bufflen(sc_cmd);
873         sc_cmd->SCp.ptr = (char *)io_req;
874         io_req->use_slowpath = false; /* Assume fast SGL by default */
875
876         /* Record which cpu this request is associated with */
877         io_req->cpu = smp_processor_id();
878
879         if (sc_cmd->sc_data_direction == DMA_FROM_DEVICE) {
880                 req_type = FCOE_TASK_TYPE_READ_INITIATOR;
881                 io_req->io_req_flags = QEDF_READ;
882                 qedf->input_requests++;
883         } else if (sc_cmd->sc_data_direction == DMA_TO_DEVICE) {
884                 req_type = FCOE_TASK_TYPE_WRITE_INITIATOR;
885                 io_req->io_req_flags = QEDF_WRITE;
886                 qedf->output_requests++;
887         } else {
888                 io_req->io_req_flags = 0;
889                 qedf->control_requests++;
890         }
891
892         xid = io_req->xid;
893
894         /* Build buffer descriptor list for firmware from sg list */
895         if (qedf_build_bd_list_from_sg(io_req)) {
896                 QEDF_ERR(&(qedf->dbg_ctx), "BD list creation failed.\n");
897                 kref_put(&io_req->refcount, qedf_release_cmd);
898                 return -EAGAIN;
899         }
900
901         if (!test_bit(QEDF_RPORT_SESSION_READY, &fcport->flags)) {
902                 QEDF_ERR(&(qedf->dbg_ctx), "Session not offloaded yet.\n");
903                 kref_put(&io_req->refcount, qedf_release_cmd);
904         }
905
906         /* Obtain free SQE */
907         sqe_idx = qedf_get_sqe_idx(fcport);
908         sqe = &fcport->sq[sqe_idx];
909         memset(sqe, 0, sizeof(struct fcoe_wqe));
910
911         /* Get the task context */
912         task_ctx = qedf_get_task_mem(&qedf->tasks, xid);
913         if (!task_ctx) {
914                 QEDF_WARN(&(qedf->dbg_ctx), "task_ctx is NULL, xid=%d.\n",
915                            xid);
916                 kref_put(&io_req->refcount, qedf_release_cmd);
917                 return -EINVAL;
918         }
919
920         qedf_init_task(fcport, lport, io_req, task_ctx, sqe);
921
922         /* Ring doorbell */
923         qedf_ring_doorbell(fcport);
924
925         if (qedf_io_tracing && io_req->sc_cmd)
926                 qedf_trace_io(fcport, io_req, QEDF_IO_TRACE_REQ);
927
928         return false;
929 }
930
931 int
932 qedf_queuecommand(struct Scsi_Host *host, struct scsi_cmnd *sc_cmd)
933 {
934         struct fc_lport *lport = shost_priv(host);
935         struct qedf_ctx *qedf = lport_priv(lport);
936         struct fc_rport *rport = starget_to_rport(scsi_target(sc_cmd->device));
937         struct fc_rport_libfc_priv *rp = rport->dd_data;
938         struct qedf_rport *fcport;
939         struct qedf_ioreq *io_req;
940         int rc = 0;
941         int rval;
942         unsigned long flags = 0;
943
944
945         if (test_bit(QEDF_UNLOADING, &qedf->flags) ||
946             test_bit(QEDF_DBG_STOP_IO, &qedf->flags)) {
947                 sc_cmd->result = DID_NO_CONNECT << 16;
948                 sc_cmd->scsi_done(sc_cmd);
949                 return 0;
950         }
951
952         if (!qedf->pdev->msix_enabled) {
953                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
954                     "Completing sc_cmd=%p DID_NO_CONNECT as MSI-X is not enabled.\n",
955                     sc_cmd);
956                 sc_cmd->result = DID_NO_CONNECT << 16;
957                 sc_cmd->scsi_done(sc_cmd);
958                 return 0;
959         }
960
961         rval = fc_remote_port_chkready(rport);
962         if (rval) {
963                 sc_cmd->result = rval;
964                 sc_cmd->scsi_done(sc_cmd);
965                 return 0;
966         }
967
968         /* Retry command if we are doing a qed drain operation */
969         if (test_bit(QEDF_DRAIN_ACTIVE, &qedf->flags)) {
970                 rc = SCSI_MLQUEUE_HOST_BUSY;
971                 goto exit_qcmd;
972         }
973
974         if (lport->state != LPORT_ST_READY ||
975             atomic_read(&qedf->link_state) != QEDF_LINK_UP) {
976                 rc = SCSI_MLQUEUE_HOST_BUSY;
977                 goto exit_qcmd;
978         }
979
980         /* rport and tgt are allocated together, so tgt should be non-NULL */
981         fcport = (struct qedf_rport *)&rp[1];
982
983         if (!test_bit(QEDF_RPORT_SESSION_READY, &fcport->flags)) {
984                 /*
985                  * Session is not offloaded yet. Let SCSI-ml retry
986                  * the command.
987                  */
988                 rc = SCSI_MLQUEUE_TARGET_BUSY;
989                 goto exit_qcmd;
990         }
991         if (fcport->retry_delay_timestamp) {
992                 if (time_after(jiffies, fcport->retry_delay_timestamp)) {
993                         fcport->retry_delay_timestamp = 0;
994                 } else {
995                         /* If retry_delay timer is active, flow off the ML */
996                         rc = SCSI_MLQUEUE_TARGET_BUSY;
997                         goto exit_qcmd;
998                 }
999         }
1000
1001         io_req = qedf_alloc_cmd(fcport, QEDF_SCSI_CMD);
1002         if (!io_req) {
1003                 rc = SCSI_MLQUEUE_HOST_BUSY;
1004                 goto exit_qcmd;
1005         }
1006
1007         io_req->sc_cmd = sc_cmd;
1008
1009         /* Take fcport->rport_lock for posting to fcport send queue */
1010         spin_lock_irqsave(&fcport->rport_lock, flags);
1011         if (qedf_post_io_req(fcport, io_req)) {
1012                 QEDF_WARN(&(qedf->dbg_ctx), "Unable to post io_req\n");
1013                 /* Return SQE to pool */
1014                 atomic_inc(&fcport->free_sqes);
1015                 rc = SCSI_MLQUEUE_HOST_BUSY;
1016         }
1017         spin_unlock_irqrestore(&fcport->rport_lock, flags);
1018
1019 exit_qcmd:
1020         return rc;
1021 }
1022
1023 static void qedf_parse_fcp_rsp(struct qedf_ioreq *io_req,
1024                                  struct fcoe_cqe_rsp_info *fcp_rsp)
1025 {
1026         struct scsi_cmnd *sc_cmd = io_req->sc_cmd;
1027         struct qedf_ctx *qedf = io_req->fcport->qedf;
1028         u8 rsp_flags = fcp_rsp->rsp_flags.flags;
1029         int fcp_sns_len = 0;
1030         int fcp_rsp_len = 0;
1031         uint8_t *rsp_info, *sense_data;
1032
1033         io_req->fcp_status = FC_GOOD;
1034         io_req->fcp_resid = 0;
1035         if (rsp_flags & (FCOE_FCP_RSP_FLAGS_FCP_RESID_OVER |
1036             FCOE_FCP_RSP_FLAGS_FCP_RESID_UNDER))
1037                 io_req->fcp_resid = fcp_rsp->fcp_resid;
1038
1039         io_req->scsi_comp_flags = rsp_flags;
1040         CMD_SCSI_STATUS(sc_cmd) = io_req->cdb_status =
1041             fcp_rsp->scsi_status_code;
1042
1043         if (rsp_flags &
1044             FCOE_FCP_RSP_FLAGS_FCP_RSP_LEN_VALID)
1045                 fcp_rsp_len = fcp_rsp->fcp_rsp_len;
1046
1047         if (rsp_flags &
1048             FCOE_FCP_RSP_FLAGS_FCP_SNS_LEN_VALID)
1049                 fcp_sns_len = fcp_rsp->fcp_sns_len;
1050
1051         io_req->fcp_rsp_len = fcp_rsp_len;
1052         io_req->fcp_sns_len = fcp_sns_len;
1053         rsp_info = sense_data = io_req->sense_buffer;
1054
1055         /* fetch fcp_rsp_code */
1056         if ((fcp_rsp_len == 4) || (fcp_rsp_len == 8)) {
1057                 /* Only for task management function */
1058                 io_req->fcp_rsp_code = rsp_info[3];
1059                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
1060                     "fcp_rsp_code = %d\n", io_req->fcp_rsp_code);
1061                 /* Adjust sense-data location. */
1062                 sense_data += fcp_rsp_len;
1063         }
1064
1065         if (fcp_sns_len > SCSI_SENSE_BUFFERSIZE) {
1066                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
1067                     "Truncating sense buffer\n");
1068                 fcp_sns_len = SCSI_SENSE_BUFFERSIZE;
1069         }
1070
1071         /* The sense buffer can be NULL for TMF commands */
1072         if (sc_cmd->sense_buffer) {
1073                 memset(sc_cmd->sense_buffer, 0, SCSI_SENSE_BUFFERSIZE);
1074                 if (fcp_sns_len)
1075                         memcpy(sc_cmd->sense_buffer, sense_data,
1076                             fcp_sns_len);
1077         }
1078 }
1079
1080 static void qedf_unmap_sg_list(struct qedf_ctx *qedf, struct qedf_ioreq *io_req)
1081 {
1082         struct scsi_cmnd *sc = io_req->sc_cmd;
1083
1084         if (io_req->bd_tbl->bd_valid && sc && scsi_sg_count(sc)) {
1085                 dma_unmap_sg(&qedf->pdev->dev, scsi_sglist(sc),
1086                     scsi_sg_count(sc), sc->sc_data_direction);
1087                 io_req->bd_tbl->bd_valid = 0;
1088         }
1089 }
1090
1091 void qedf_scsi_completion(struct qedf_ctx *qedf, struct fcoe_cqe *cqe,
1092         struct qedf_ioreq *io_req)
1093 {
1094         u16 xid, rval;
1095         struct e4_fcoe_task_context *task_ctx;
1096         struct scsi_cmnd *sc_cmd;
1097         struct fcoe_cqe_rsp_info *fcp_rsp;
1098         struct qedf_rport *fcport;
1099         int refcount;
1100         u16 scope, qualifier = 0;
1101         u8 fw_residual_flag = 0;
1102
1103         if (!io_req)
1104                 return;
1105         if (!cqe)
1106                 return;
1107
1108         xid = io_req->xid;
1109         task_ctx = qedf_get_task_mem(&qedf->tasks, xid);
1110         sc_cmd = io_req->sc_cmd;
1111         fcp_rsp = &cqe->cqe_info.rsp_info;
1112
1113         if (!sc_cmd) {
1114                 QEDF_WARN(&(qedf->dbg_ctx), "sc_cmd is NULL!\n");
1115                 return;
1116         }
1117
1118         if (!sc_cmd->SCp.ptr) {
1119                 QEDF_WARN(&(qedf->dbg_ctx), "SCp.ptr is NULL, returned in "
1120                     "another context.\n");
1121                 return;
1122         }
1123
1124         if (!sc_cmd->request) {
1125                 QEDF_WARN(&(qedf->dbg_ctx), "sc_cmd->request is NULL, "
1126                     "sc_cmd=%p.\n", sc_cmd);
1127                 return;
1128         }
1129
1130         if (!sc_cmd->request->q) {
1131                 QEDF_WARN(&(qedf->dbg_ctx), "request->q is NULL so request "
1132                    "is not valid, sc_cmd=%p.\n", sc_cmd);
1133                 return;
1134         }
1135
1136         fcport = io_req->fcport;
1137
1138         qedf_parse_fcp_rsp(io_req, fcp_rsp);
1139
1140         qedf_unmap_sg_list(qedf, io_req);
1141
1142         /* Check for FCP transport error */
1143         if (io_req->fcp_rsp_len > 3 && io_req->fcp_rsp_code) {
1144                 QEDF_ERR(&(qedf->dbg_ctx),
1145                     "FCP I/O protocol failure xid=0x%x fcp_rsp_len=%d "
1146                     "fcp_rsp_code=%d.\n", io_req->xid, io_req->fcp_rsp_len,
1147                     io_req->fcp_rsp_code);
1148                 sc_cmd->result = DID_BUS_BUSY << 16;
1149                 goto out;
1150         }
1151
1152         fw_residual_flag = GET_FIELD(cqe->cqe_info.rsp_info.fw_error_flags,
1153             FCOE_CQE_RSP_INFO_FW_UNDERRUN);
1154         if (fw_residual_flag) {
1155                 QEDF_ERR(&(qedf->dbg_ctx),
1156                     "Firmware detected underrun: xid=0x%x fcp_rsp.flags=0x%02x "
1157                     "fcp_resid=%d fw_residual=0x%x.\n", io_req->xid,
1158                     fcp_rsp->rsp_flags.flags, io_req->fcp_resid,
1159                     cqe->cqe_info.rsp_info.fw_residual);
1160
1161                 if (io_req->cdb_status == 0)
1162                         sc_cmd->result = (DID_ERROR << 16) | io_req->cdb_status;
1163                 else
1164                         sc_cmd->result = (DID_OK << 16) | io_req->cdb_status;
1165
1166                 /* Abort the command since we did not get all the data */
1167                 init_completion(&io_req->abts_done);
1168                 rval = qedf_initiate_abts(io_req, true);
1169                 if (rval) {
1170                         QEDF_ERR(&(qedf->dbg_ctx), "Failed to queue ABTS.\n");
1171                         sc_cmd->result = (DID_ERROR << 16) | io_req->cdb_status;
1172                 }
1173
1174                 /*
1175                  * Set resid to the whole buffer length so we won't try to resue
1176                  * any previously data.
1177                  */
1178                 scsi_set_resid(sc_cmd, scsi_bufflen(sc_cmd));
1179                 goto out;
1180         }
1181
1182         switch (io_req->fcp_status) {
1183         case FC_GOOD:
1184                 if (io_req->cdb_status == 0) {
1185                         /* Good I/O completion */
1186                         sc_cmd->result = DID_OK << 16;
1187                 } else {
1188                         refcount = kref_read(&io_req->refcount);
1189                         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
1190                             "%d:0:%d:%lld xid=0x%0x op=0x%02x "
1191                             "lba=%02x%02x%02x%02x cdb_status=%d "
1192                             "fcp_resid=0x%x refcount=%d.\n",
1193                             qedf->lport->host->host_no, sc_cmd->device->id,
1194                             sc_cmd->device->lun, io_req->xid,
1195                             sc_cmd->cmnd[0], sc_cmd->cmnd[2], sc_cmd->cmnd[3],
1196                             sc_cmd->cmnd[4], sc_cmd->cmnd[5],
1197                             io_req->cdb_status, io_req->fcp_resid,
1198                             refcount);
1199                         sc_cmd->result = (DID_OK << 16) | io_req->cdb_status;
1200
1201                         if (io_req->cdb_status == SAM_STAT_TASK_SET_FULL ||
1202                             io_req->cdb_status == SAM_STAT_BUSY) {
1203                                 /*
1204                                  * Check whether we need to set retry_delay at
1205                                  * all based on retry_delay module parameter
1206                                  * and the status qualifier.
1207                                  */
1208
1209                                 /* Upper 2 bits */
1210                                 scope = fcp_rsp->retry_delay_timer & 0xC000;
1211                                 /* Lower 14 bits */
1212                                 qualifier = fcp_rsp->retry_delay_timer & 0x3FFF;
1213
1214                                 if (qedf_retry_delay &&
1215                                     scope > 0 && qualifier > 0 &&
1216                                     qualifier <= 0x3FEF) {
1217                                         /* Check we don't go over the max */
1218                                         if (qualifier > QEDF_RETRY_DELAY_MAX)
1219                                                 qualifier =
1220                                                     QEDF_RETRY_DELAY_MAX;
1221                                         fcport->retry_delay_timestamp =
1222                                             jiffies + (qualifier * HZ / 10);
1223                                 }
1224                                 /* Record stats */
1225                                 if (io_req->cdb_status ==
1226                                     SAM_STAT_TASK_SET_FULL)
1227                                         qedf->task_set_fulls++;
1228                                 else
1229                                         qedf->busy++;
1230                         }
1231                 }
1232                 if (io_req->fcp_resid)
1233                         scsi_set_resid(sc_cmd, io_req->fcp_resid);
1234                 break;
1235         default:
1236                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO, "fcp_status=%d.\n",
1237                            io_req->fcp_status);
1238                 break;
1239         }
1240
1241 out:
1242         if (qedf_io_tracing)
1243                 qedf_trace_io(fcport, io_req, QEDF_IO_TRACE_RSP);
1244
1245         io_req->sc_cmd = NULL;
1246         sc_cmd->SCp.ptr =  NULL;
1247         sc_cmd->scsi_done(sc_cmd);
1248         kref_put(&io_req->refcount, qedf_release_cmd);
1249 }
1250
1251 /* Return a SCSI command in some other context besides a normal completion */
1252 void qedf_scsi_done(struct qedf_ctx *qedf, struct qedf_ioreq *io_req,
1253         int result)
1254 {
1255         u16 xid;
1256         struct scsi_cmnd *sc_cmd;
1257         int refcount;
1258
1259         if (!io_req)
1260                 return;
1261
1262         xid = io_req->xid;
1263         sc_cmd = io_req->sc_cmd;
1264
1265         if (!sc_cmd) {
1266                 QEDF_WARN(&(qedf->dbg_ctx), "sc_cmd is NULL!\n");
1267                 return;
1268         }
1269
1270         if (!sc_cmd->SCp.ptr) {
1271                 QEDF_WARN(&(qedf->dbg_ctx), "SCp.ptr is NULL, returned in "
1272                     "another context.\n");
1273                 return;
1274         }
1275
1276         qedf_unmap_sg_list(qedf, io_req);
1277
1278         sc_cmd->result = result << 16;
1279         refcount = kref_read(&io_req->refcount);
1280         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO, "%d:0:%d:%lld: Completing "
1281             "sc_cmd=%p result=0x%08x op=0x%02x lba=0x%02x%02x%02x%02x, "
1282             "allowed=%d retries=%d refcount=%d.\n",
1283             qedf->lport->host->host_no, sc_cmd->device->id,
1284             sc_cmd->device->lun, sc_cmd, sc_cmd->result, sc_cmd->cmnd[0],
1285             sc_cmd->cmnd[2], sc_cmd->cmnd[3], sc_cmd->cmnd[4],
1286             sc_cmd->cmnd[5], sc_cmd->allowed, sc_cmd->retries,
1287             refcount);
1288
1289         /*
1290          * Set resid to the whole buffer length so we won't try to resue any
1291          * previously read data
1292          */
1293         scsi_set_resid(sc_cmd, scsi_bufflen(sc_cmd));
1294
1295         if (qedf_io_tracing)
1296                 qedf_trace_io(io_req->fcport, io_req, QEDF_IO_TRACE_RSP);
1297
1298         io_req->sc_cmd = NULL;
1299         sc_cmd->SCp.ptr = NULL;
1300         sc_cmd->scsi_done(sc_cmd);
1301         kref_put(&io_req->refcount, qedf_release_cmd);
1302 }
1303
1304 /*
1305  * Handle warning type CQE completions. This is mainly used for REC timer
1306  * popping.
1307  */
1308 void qedf_process_warning_compl(struct qedf_ctx *qedf, struct fcoe_cqe *cqe,
1309         struct qedf_ioreq *io_req)
1310 {
1311         int rval, i;
1312         struct qedf_rport *fcport = io_req->fcport;
1313         u64 err_warn_bit_map;
1314         u8 err_warn = 0xff;
1315
1316         if (!cqe)
1317                 return;
1318
1319         QEDF_ERR(&(io_req->fcport->qedf->dbg_ctx), "Warning CQE, "
1320                   "xid=0x%x\n", io_req->xid);
1321         QEDF_ERR(&(io_req->fcport->qedf->dbg_ctx),
1322                   "err_warn_bitmap=%08x:%08x\n",
1323                   le32_to_cpu(cqe->cqe_info.err_info.err_warn_bitmap_hi),
1324                   le32_to_cpu(cqe->cqe_info.err_info.err_warn_bitmap_lo));
1325         QEDF_ERR(&(io_req->fcport->qedf->dbg_ctx), "tx_buff_off=%08x, "
1326                   "rx_buff_off=%08x, rx_id=%04x\n",
1327                   le32_to_cpu(cqe->cqe_info.err_info.tx_buf_off),
1328                   le32_to_cpu(cqe->cqe_info.err_info.rx_buf_off),
1329                   le32_to_cpu(cqe->cqe_info.err_info.rx_id));
1330
1331         /* Normalize the error bitmap value to an just an unsigned int */
1332         err_warn_bit_map = (u64)
1333             ((u64)cqe->cqe_info.err_info.err_warn_bitmap_hi << 32) |
1334             (u64)cqe->cqe_info.err_info.err_warn_bitmap_lo;
1335         for (i = 0; i < 64; i++) {
1336                 if (err_warn_bit_map & (u64)((u64)1 << i)) {
1337                         err_warn = i;
1338                         break;
1339                 }
1340         }
1341
1342         /* Check if REC TOV expired if this is a tape device */
1343         if (fcport->dev_type == QEDF_RPORT_TYPE_TAPE) {
1344                 if (err_warn ==
1345                     FCOE_WARNING_CODE_REC_TOV_TIMER_EXPIRATION) {
1346                         QEDF_ERR(&(qedf->dbg_ctx), "REC timer expired.\n");
1347                         if (!test_bit(QEDF_CMD_SRR_SENT, &io_req->flags)) {
1348                                 io_req->rx_buf_off =
1349                                     cqe->cqe_info.err_info.rx_buf_off;
1350                                 io_req->tx_buf_off =
1351                                     cqe->cqe_info.err_info.tx_buf_off;
1352                                 io_req->rx_id = cqe->cqe_info.err_info.rx_id;
1353                                 rval = qedf_send_rec(io_req);
1354                                 /*
1355                                  * We only want to abort the io_req if we
1356                                  * can't queue the REC command as we want to
1357                                  * keep the exchange open for recovery.
1358                                  */
1359                                 if (rval)
1360                                         goto send_abort;
1361                         }
1362                         return;
1363                 }
1364         }
1365
1366 send_abort:
1367         init_completion(&io_req->abts_done);
1368         rval = qedf_initiate_abts(io_req, true);
1369         if (rval)
1370                 QEDF_ERR(&(qedf->dbg_ctx), "Failed to queue ABTS.\n");
1371 }
1372
1373 /* Cleanup a command when we receive an error detection completion */
1374 void qedf_process_error_detect(struct qedf_ctx *qedf, struct fcoe_cqe *cqe,
1375         struct qedf_ioreq *io_req)
1376 {
1377         int rval;
1378
1379         if (!cqe)
1380                 return;
1381
1382         QEDF_ERR(&(io_req->fcport->qedf->dbg_ctx), "Error detection CQE, "
1383                   "xid=0x%x\n", io_req->xid);
1384         QEDF_ERR(&(io_req->fcport->qedf->dbg_ctx),
1385                   "err_warn_bitmap=%08x:%08x\n",
1386                   le32_to_cpu(cqe->cqe_info.err_info.err_warn_bitmap_hi),
1387                   le32_to_cpu(cqe->cqe_info.err_info.err_warn_bitmap_lo));
1388         QEDF_ERR(&(io_req->fcport->qedf->dbg_ctx), "tx_buff_off=%08x, "
1389                   "rx_buff_off=%08x, rx_id=%04x\n",
1390                   le32_to_cpu(cqe->cqe_info.err_info.tx_buf_off),
1391                   le32_to_cpu(cqe->cqe_info.err_info.rx_buf_off),
1392                   le32_to_cpu(cqe->cqe_info.err_info.rx_id));
1393
1394         if (qedf->stop_io_on_error) {
1395                 qedf_stop_all_io(qedf);
1396                 return;
1397         }
1398
1399         init_completion(&io_req->abts_done);
1400         rval = qedf_initiate_abts(io_req, true);
1401         if (rval)
1402                 QEDF_ERR(&(qedf->dbg_ctx), "Failed to queue ABTS.\n");
1403 }
1404
1405 static void qedf_flush_els_req(struct qedf_ctx *qedf,
1406         struct qedf_ioreq *els_req)
1407 {
1408         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
1409             "Flushing ELS request xid=0x%x refcount=%d.\n", els_req->xid,
1410             kref_read(&els_req->refcount));
1411
1412         /*
1413          * Need to distinguish this from a timeout when calling the
1414          * els_req->cb_func.
1415          */
1416         els_req->event = QEDF_IOREQ_EV_ELS_FLUSH;
1417
1418         /* Cancel the timer */
1419         cancel_delayed_work_sync(&els_req->timeout_work);
1420
1421         /* Call callback function to complete command */
1422         if (els_req->cb_func && els_req->cb_arg) {
1423                 els_req->cb_func(els_req->cb_arg);
1424                 els_req->cb_arg = NULL;
1425         }
1426
1427         /* Release kref for original initiate_els */
1428         kref_put(&els_req->refcount, qedf_release_cmd);
1429 }
1430
1431 /* A value of -1 for lun is a wild card that means flush all
1432  * active SCSI I/Os for the target.
1433  */
1434 void qedf_flush_active_ios(struct qedf_rport *fcport, int lun)
1435 {
1436         struct qedf_ioreq *io_req;
1437         struct qedf_ctx *qedf;
1438         struct qedf_cmd_mgr *cmd_mgr;
1439         int i, rc;
1440
1441         if (!fcport)
1442                 return;
1443
1444         /* Check that fcport is still offloaded */
1445         if (!test_bit(QEDF_RPORT_SESSION_READY, &fcport->flags)) {
1446                 QEDF_ERR(NULL, "fcport is no longer offloaded.\n");
1447                 return;
1448         }
1449
1450         qedf = fcport->qedf;
1451         cmd_mgr = qedf->cmd_mgr;
1452
1453         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO, "Flush active i/o's.\n");
1454
1455         for (i = 0; i < FCOE_PARAMS_NUM_TASKS; i++) {
1456                 io_req = &cmd_mgr->cmds[i];
1457
1458                 if (!io_req)
1459                         continue;
1460                 if (io_req->fcport != fcport)
1461                         continue;
1462                 if (io_req->cmd_type == QEDF_ELS) {
1463                         rc = kref_get_unless_zero(&io_req->refcount);
1464                         if (!rc) {
1465                                 QEDF_ERR(&(qedf->dbg_ctx),
1466                                     "Could not get kref for ELS io_req=0x%p xid=0x%x.\n",
1467                                     io_req, io_req->xid);
1468                                 continue;
1469                         }
1470                         qedf_flush_els_req(qedf, io_req);
1471                         /*
1472                          * Release the kref and go back to the top of the
1473                          * loop.
1474                          */
1475                         goto free_cmd;
1476                 }
1477
1478                 if (io_req->cmd_type == QEDF_ABTS) {
1479                         rc = kref_get_unless_zero(&io_req->refcount);
1480                         if (!rc) {
1481                                 QEDF_ERR(&(qedf->dbg_ctx),
1482                                     "Could not get kref for abort io_req=0x%p xid=0x%x.\n",
1483                                     io_req, io_req->xid);
1484                                 continue;
1485                         }
1486                         QEDF_INFO(&qedf->dbg_ctx, QEDF_LOG_IO,
1487                             "Flushing abort xid=0x%x.\n", io_req->xid);
1488
1489                         clear_bit(QEDF_CMD_IN_ABORT, &io_req->flags);
1490
1491                         if (io_req->sc_cmd) {
1492                                 if (io_req->return_scsi_cmd_on_abts)
1493                                         qedf_scsi_done(qedf, io_req, DID_ERROR);
1494                         }
1495
1496                         /* Notify eh_abort handler that ABTS is complete */
1497                         complete(&io_req->abts_done);
1498                         kref_put(&io_req->refcount, qedf_release_cmd);
1499
1500                         goto free_cmd;
1501                 }
1502
1503                 if (!io_req->sc_cmd)
1504                         continue;
1505                 if (lun > 0) {
1506                         if (io_req->sc_cmd->device->lun !=
1507                             (u64)lun)
1508                                 continue;
1509                 }
1510
1511                 /*
1512                  * Use kref_get_unless_zero in the unlikely case the command
1513                  * we're about to flush was completed in the normal SCSI path
1514                  */
1515                 rc = kref_get_unless_zero(&io_req->refcount);
1516                 if (!rc) {
1517                         QEDF_ERR(&(qedf->dbg_ctx), "Could not get kref for "
1518                             "io_req=0x%p xid=0x%x\n", io_req, io_req->xid);
1519                         continue;
1520                 }
1521                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO,
1522                     "Cleanup xid=0x%x.\n", io_req->xid);
1523
1524                 /* Cleanup task and return I/O mid-layer */
1525                 qedf_initiate_cleanup(io_req, true);
1526
1527 free_cmd:
1528                 kref_put(&io_req->refcount, qedf_release_cmd);
1529         }
1530 }
1531
1532 /*
1533  * Initiate a ABTS middle path command. Note that we don't have to initialize
1534  * the task context for an ABTS task.
1535  */
1536 int qedf_initiate_abts(struct qedf_ioreq *io_req, bool return_scsi_cmd_on_abts)
1537 {
1538         struct fc_lport *lport;
1539         struct qedf_rport *fcport = io_req->fcport;
1540         struct fc_rport_priv *rdata;
1541         struct qedf_ctx *qedf;
1542         u16 xid;
1543         u32 r_a_tov = 0;
1544         int rc = 0;
1545         unsigned long flags;
1546         struct fcoe_wqe *sqe;
1547         u16 sqe_idx;
1548
1549         /* Sanity check qedf_rport before dereferencing any pointers */
1550         if (!test_bit(QEDF_RPORT_SESSION_READY, &fcport->flags)) {
1551                 QEDF_ERR(NULL, "tgt not offloaded\n");
1552                 rc = 1;
1553                 goto abts_err;
1554         }
1555
1556         rdata = fcport->rdata;
1557         r_a_tov = rdata->r_a_tov;
1558         qedf = fcport->qedf;
1559         lport = qedf->lport;
1560
1561         if (lport->state != LPORT_ST_READY || !(lport->link_up)) {
1562                 QEDF_ERR(&(qedf->dbg_ctx), "link is not ready\n");
1563                 rc = 1;
1564                 goto abts_err;
1565         }
1566
1567         if (atomic_read(&qedf->link_down_tmo_valid) > 0) {
1568                 QEDF_ERR(&(qedf->dbg_ctx), "link_down_tmo active.\n");
1569                 rc = 1;
1570                 goto abts_err;
1571         }
1572
1573         /* Ensure room on SQ */
1574         if (!atomic_read(&fcport->free_sqes)) {
1575                 QEDF_ERR(&(qedf->dbg_ctx), "No SQ entries available\n");
1576                 rc = 1;
1577                 goto abts_err;
1578         }
1579
1580         if (test_bit(QEDF_RPORT_UPLOADING_CONNECTION, &fcport->flags)) {
1581                 QEDF_ERR(&qedf->dbg_ctx, "fcport is uploading.\n");
1582                 rc = 1;
1583                 goto out;
1584         }
1585
1586         if (!test_bit(QEDF_CMD_OUTSTANDING, &io_req->flags) ||
1587             test_bit(QEDF_CMD_IN_CLEANUP, &io_req->flags) ||
1588             test_bit(QEDF_CMD_IN_ABORT, &io_req->flags)) {
1589                 QEDF_ERR(&(qedf->dbg_ctx), "io_req xid=0x%x already in "
1590                           "cleanup or abort processing or already "
1591                           "completed.\n", io_req->xid);
1592                 rc = 1;
1593                 goto out;
1594         }
1595
1596         kref_get(&io_req->refcount);
1597
1598         xid = io_req->xid;
1599         qedf->control_requests++;
1600         qedf->packet_aborts++;
1601
1602         /* Set the return CPU to be the same as the request one */
1603         io_req->cpu = smp_processor_id();
1604
1605         /* Set the command type to abort */
1606         io_req->cmd_type = QEDF_ABTS;
1607         io_req->return_scsi_cmd_on_abts = return_scsi_cmd_on_abts;
1608
1609         set_bit(QEDF_CMD_IN_ABORT, &io_req->flags);
1610         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_SCSI_TM, "ABTS io_req xid = "
1611                    "0x%x\n", xid);
1612
1613         qedf_cmd_timer_set(qedf, io_req, QEDF_ABORT_TIMEOUT * HZ);
1614
1615         spin_lock_irqsave(&fcport->rport_lock, flags);
1616
1617         sqe_idx = qedf_get_sqe_idx(fcport);
1618         sqe = &fcport->sq[sqe_idx];
1619         memset(sqe, 0, sizeof(struct fcoe_wqe));
1620         io_req->task_params->sqe = sqe;
1621
1622         init_initiator_abort_fcoe_task(io_req->task_params);
1623         qedf_ring_doorbell(fcport);
1624
1625         spin_unlock_irqrestore(&fcport->rport_lock, flags);
1626
1627         return rc;
1628 abts_err:
1629         /*
1630          * If the ABTS task fails to queue then we need to cleanup the
1631          * task at the firmware.
1632          */
1633         qedf_initiate_cleanup(io_req, return_scsi_cmd_on_abts);
1634 out:
1635         return rc;
1636 }
1637
1638 void qedf_process_abts_compl(struct qedf_ctx *qedf, struct fcoe_cqe *cqe,
1639         struct qedf_ioreq *io_req)
1640 {
1641         uint32_t r_ctl;
1642         uint16_t xid;
1643
1644         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_SCSI_TM, "Entered with xid = "
1645                    "0x%x cmd_type = %d\n", io_req->xid, io_req->cmd_type);
1646
1647         cancel_delayed_work(&io_req->timeout_work);
1648
1649         xid = io_req->xid;
1650         r_ctl = cqe->cqe_info.abts_info.r_ctl;
1651
1652         switch (r_ctl) {
1653         case FC_RCTL_BA_ACC:
1654                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_SCSI_TM,
1655                     "ABTS response - ACC Send RRQ after R_A_TOV\n");
1656                 io_req->event = QEDF_IOREQ_EV_ABORT_SUCCESS;
1657                 /*
1658                  * Dont release this cmd yet. It will be relesed
1659                  * after we get RRQ response
1660                  */
1661                 kref_get(&io_req->refcount);
1662                 queue_delayed_work(qedf->dpc_wq, &io_req->rrq_work,
1663                     msecs_to_jiffies(qedf->lport->r_a_tov));
1664                 break;
1665         /* For error cases let the cleanup return the command */
1666         case FC_RCTL_BA_RJT:
1667                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_SCSI_TM,
1668                    "ABTS response - RJT\n");
1669                 io_req->event = QEDF_IOREQ_EV_ABORT_FAILED;
1670                 break;
1671         default:
1672                 QEDF_ERR(&(qedf->dbg_ctx), "Unknown ABTS response\n");
1673                 break;
1674         }
1675
1676         clear_bit(QEDF_CMD_IN_ABORT, &io_req->flags);
1677
1678         if (io_req->sc_cmd) {
1679                 if (io_req->return_scsi_cmd_on_abts)
1680                         qedf_scsi_done(qedf, io_req, DID_ERROR);
1681         }
1682
1683         /* Notify eh_abort handler that ABTS is complete */
1684         complete(&io_req->abts_done);
1685
1686         kref_put(&io_req->refcount, qedf_release_cmd);
1687 }
1688
1689 int qedf_init_mp_req(struct qedf_ioreq *io_req)
1690 {
1691         struct qedf_mp_req *mp_req;
1692         struct scsi_sge *mp_req_bd;
1693         struct scsi_sge *mp_resp_bd;
1694         struct qedf_ctx *qedf = io_req->fcport->qedf;
1695         dma_addr_t addr;
1696         uint64_t sz;
1697
1698         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_MP_REQ, "Entered.\n");
1699
1700         mp_req = (struct qedf_mp_req *)&(io_req->mp_req);
1701         memset(mp_req, 0, sizeof(struct qedf_mp_req));
1702
1703         if (io_req->cmd_type != QEDF_ELS) {
1704                 mp_req->req_len = sizeof(struct fcp_cmnd);
1705                 io_req->data_xfer_len = mp_req->req_len;
1706         } else
1707                 mp_req->req_len = io_req->data_xfer_len;
1708
1709         mp_req->req_buf = dma_alloc_coherent(&qedf->pdev->dev, QEDF_PAGE_SIZE,
1710             &mp_req->req_buf_dma, GFP_KERNEL);
1711         if (!mp_req->req_buf) {
1712                 QEDF_ERR(&(qedf->dbg_ctx), "Unable to alloc MP req buffer\n");
1713                 qedf_free_mp_resc(io_req);
1714                 return -ENOMEM;
1715         }
1716
1717         mp_req->resp_buf = dma_alloc_coherent(&qedf->pdev->dev,
1718             QEDF_PAGE_SIZE, &mp_req->resp_buf_dma, GFP_KERNEL);
1719         if (!mp_req->resp_buf) {
1720                 QEDF_ERR(&(qedf->dbg_ctx), "Unable to alloc TM resp "
1721                           "buffer\n");
1722                 qedf_free_mp_resc(io_req);
1723                 return -ENOMEM;
1724         }
1725
1726         /* Allocate and map mp_req_bd and mp_resp_bd */
1727         sz = sizeof(struct scsi_sge);
1728         mp_req->mp_req_bd = dma_alloc_coherent(&qedf->pdev->dev, sz,
1729             &mp_req->mp_req_bd_dma, GFP_KERNEL);
1730         if (!mp_req->mp_req_bd) {
1731                 QEDF_ERR(&(qedf->dbg_ctx), "Unable to alloc MP req bd\n");
1732                 qedf_free_mp_resc(io_req);
1733                 return -ENOMEM;
1734         }
1735
1736         mp_req->mp_resp_bd = dma_alloc_coherent(&qedf->pdev->dev, sz,
1737             &mp_req->mp_resp_bd_dma, GFP_KERNEL);
1738         if (!mp_req->mp_resp_bd) {
1739                 QEDF_ERR(&(qedf->dbg_ctx), "Unable to alloc MP resp bd\n");
1740                 qedf_free_mp_resc(io_req);
1741                 return -ENOMEM;
1742         }
1743
1744         /* Fill bd table */
1745         addr = mp_req->req_buf_dma;
1746         mp_req_bd = mp_req->mp_req_bd;
1747         mp_req_bd->sge_addr.lo = U64_LO(addr);
1748         mp_req_bd->sge_addr.hi = U64_HI(addr);
1749         mp_req_bd->sge_len = QEDF_PAGE_SIZE;
1750
1751         /*
1752          * MP buffer is either a task mgmt command or an ELS.
1753          * So the assumption is that it consumes a single bd
1754          * entry in the bd table
1755          */
1756         mp_resp_bd = mp_req->mp_resp_bd;
1757         addr = mp_req->resp_buf_dma;
1758         mp_resp_bd->sge_addr.lo = U64_LO(addr);
1759         mp_resp_bd->sge_addr.hi = U64_HI(addr);
1760         mp_resp_bd->sge_len = QEDF_PAGE_SIZE;
1761
1762         return 0;
1763 }
1764
1765 /*
1766  * Last ditch effort to clear the port if it's stuck. Used only after a
1767  * cleanup task times out.
1768  */
1769 static void qedf_drain_request(struct qedf_ctx *qedf)
1770 {
1771         if (test_bit(QEDF_DRAIN_ACTIVE, &qedf->flags)) {
1772                 QEDF_ERR(&(qedf->dbg_ctx), "MCP drain already active.\n");
1773                 return;
1774         }
1775
1776         /* Set bit to return all queuecommand requests as busy */
1777         set_bit(QEDF_DRAIN_ACTIVE, &qedf->flags);
1778
1779         /* Call qed drain request for function. Should be synchronous */
1780         qed_ops->common->drain(qedf->cdev);
1781
1782         /* Settle time for CQEs to be returned */
1783         msleep(100);
1784
1785         /* Unplug and continue */
1786         clear_bit(QEDF_DRAIN_ACTIVE, &qedf->flags);
1787 }
1788
1789 /*
1790  * Returns SUCCESS if the cleanup task does not timeout, otherwise return
1791  * FAILURE.
1792  */
1793 int qedf_initiate_cleanup(struct qedf_ioreq *io_req,
1794         bool return_scsi_cmd_on_abts)
1795 {
1796         struct qedf_rport *fcport;
1797         struct qedf_ctx *qedf;
1798         uint16_t xid;
1799         struct e4_fcoe_task_context *task;
1800         int tmo = 0;
1801         int rc = SUCCESS;
1802         unsigned long flags;
1803         struct fcoe_wqe *sqe;
1804         u16 sqe_idx;
1805
1806         fcport = io_req->fcport;
1807         if (!fcport) {
1808                 QEDF_ERR(NULL, "fcport is NULL.\n");
1809                 return SUCCESS;
1810         }
1811
1812         /* Sanity check qedf_rport before dereferencing any pointers */
1813         if (!test_bit(QEDF_RPORT_SESSION_READY, &fcport->flags)) {
1814                 QEDF_ERR(NULL, "tgt not offloaded\n");
1815                 rc = 1;
1816                 return SUCCESS;
1817         }
1818
1819         qedf = fcport->qedf;
1820         if (!qedf) {
1821                 QEDF_ERR(NULL, "qedf is NULL.\n");
1822                 return SUCCESS;
1823         }
1824
1825         if (!test_bit(QEDF_CMD_OUTSTANDING, &io_req->flags) ||
1826             test_bit(QEDF_CMD_IN_CLEANUP, &io_req->flags)) {
1827                 QEDF_ERR(&(qedf->dbg_ctx), "io_req xid=0x%x already in "
1828                           "cleanup processing or already completed.\n",
1829                           io_req->xid);
1830                 return SUCCESS;
1831         }
1832
1833         /* Ensure room on SQ */
1834         if (!atomic_read(&fcport->free_sqes)) {
1835                 QEDF_ERR(&(qedf->dbg_ctx), "No SQ entries available\n");
1836                 return FAILED;
1837         }
1838
1839
1840         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO, "Entered xid=0x%x\n",
1841             io_req->xid);
1842
1843         /* Cleanup cmds re-use the same TID as the original I/O */
1844         xid = io_req->xid;
1845         io_req->cmd_type = QEDF_CLEANUP;
1846         io_req->return_scsi_cmd_on_abts = return_scsi_cmd_on_abts;
1847
1848         /* Set the return CPU to be the same as the request one */
1849         io_req->cpu = smp_processor_id();
1850
1851         set_bit(QEDF_CMD_IN_CLEANUP, &io_req->flags);
1852
1853         task = qedf_get_task_mem(&qedf->tasks, xid);
1854
1855         init_completion(&io_req->tm_done);
1856
1857         spin_lock_irqsave(&fcport->rport_lock, flags);
1858
1859         sqe_idx = qedf_get_sqe_idx(fcport);
1860         sqe = &fcport->sq[sqe_idx];
1861         memset(sqe, 0, sizeof(struct fcoe_wqe));
1862         io_req->task_params->sqe = sqe;
1863
1864         init_initiator_cleanup_fcoe_task(io_req->task_params);
1865         qedf_ring_doorbell(fcport);
1866
1867         spin_unlock_irqrestore(&fcport->rport_lock, flags);
1868
1869         tmo = wait_for_completion_timeout(&io_req->tm_done,
1870             QEDF_CLEANUP_TIMEOUT * HZ);
1871
1872         if (!tmo) {
1873                 rc = FAILED;
1874                 /* Timeout case */
1875                 QEDF_ERR(&(qedf->dbg_ctx), "Cleanup command timeout, "
1876                           "xid=%x.\n", io_req->xid);
1877                 clear_bit(QEDF_CMD_IN_CLEANUP, &io_req->flags);
1878                 /* Issue a drain request if cleanup task times out */
1879                 QEDF_ERR(&(qedf->dbg_ctx), "Issuing MCP drain request.\n");
1880                 qedf_drain_request(qedf);
1881         }
1882
1883         if (io_req->sc_cmd) {
1884                 if (io_req->return_scsi_cmd_on_abts)
1885                         qedf_scsi_done(qedf, io_req, DID_ERROR);
1886         }
1887
1888         if (rc == SUCCESS)
1889                 io_req->event = QEDF_IOREQ_EV_CLEANUP_SUCCESS;
1890         else
1891                 io_req->event = QEDF_IOREQ_EV_CLEANUP_FAILED;
1892
1893         return rc;
1894 }
1895
1896 void qedf_process_cleanup_compl(struct qedf_ctx *qedf, struct fcoe_cqe *cqe,
1897         struct qedf_ioreq *io_req)
1898 {
1899         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_IO, "Entered xid = 0x%x\n",
1900                    io_req->xid);
1901
1902         clear_bit(QEDF_CMD_IN_CLEANUP, &io_req->flags);
1903
1904         /* Complete so we can finish cleaning up the I/O */
1905         complete(&io_req->tm_done);
1906 }
1907
1908 static int qedf_execute_tmf(struct qedf_rport *fcport, struct scsi_cmnd *sc_cmd,
1909         uint8_t tm_flags)
1910 {
1911         struct qedf_ioreq *io_req;
1912         struct e4_fcoe_task_context *task;
1913         struct qedf_ctx *qedf = fcport->qedf;
1914         struct fc_lport *lport = qedf->lport;
1915         int rc = 0;
1916         uint16_t xid;
1917         int tmo = 0;
1918         unsigned long flags;
1919         struct fcoe_wqe *sqe;
1920         u16 sqe_idx;
1921
1922         if (!sc_cmd) {
1923                 QEDF_ERR(&(qedf->dbg_ctx), "invalid arg\n");
1924                 return FAILED;
1925         }
1926
1927         if (!test_bit(QEDF_RPORT_SESSION_READY, &fcport->flags)) {
1928                 QEDF_ERR(&(qedf->dbg_ctx), "fcport not offloaded\n");
1929                 rc = FAILED;
1930                 return FAILED;
1931         }
1932
1933         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_SCSI_TM, "portid = 0x%x "
1934                    "tm_flags = %d\n", fcport->rdata->ids.port_id, tm_flags);
1935
1936         io_req = qedf_alloc_cmd(fcport, QEDF_TASK_MGMT_CMD);
1937         if (!io_req) {
1938                 QEDF_ERR(&(qedf->dbg_ctx), "Failed TMF");
1939                 rc = -EAGAIN;
1940                 goto reset_tmf_err;
1941         }
1942
1943         if (tm_flags == FCP_TMF_LUN_RESET)
1944                 qedf->lun_resets++;
1945         else if (tm_flags == FCP_TMF_TGT_RESET)
1946                 qedf->target_resets++;
1947
1948         /* Initialize rest of io_req fields */
1949         io_req->sc_cmd = sc_cmd;
1950         io_req->fcport = fcport;
1951         io_req->cmd_type = QEDF_TASK_MGMT_CMD;
1952
1953         /* Set the return CPU to be the same as the request one */
1954         io_req->cpu = smp_processor_id();
1955
1956         /* Set TM flags */
1957         io_req->io_req_flags = QEDF_READ;
1958         io_req->data_xfer_len = 0;
1959         io_req->tm_flags = tm_flags;
1960
1961         /* Default is to return a SCSI command when an error occurs */
1962         io_req->return_scsi_cmd_on_abts = true;
1963
1964         /* Obtain exchange id */
1965         xid = io_req->xid;
1966
1967         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_SCSI_TM, "TMF io_req xid = "
1968                    "0x%x\n", xid);
1969
1970         /* Initialize task context for this IO request */
1971         task = qedf_get_task_mem(&qedf->tasks, xid);
1972
1973         init_completion(&io_req->tm_done);
1974
1975         spin_lock_irqsave(&fcport->rport_lock, flags);
1976
1977         sqe_idx = qedf_get_sqe_idx(fcport);
1978         sqe = &fcport->sq[sqe_idx];
1979         memset(sqe, 0, sizeof(struct fcoe_wqe));
1980
1981         qedf_init_task(fcport, lport, io_req, task, sqe);
1982         qedf_ring_doorbell(fcport);
1983
1984         spin_unlock_irqrestore(&fcport->rport_lock, flags);
1985
1986         tmo = wait_for_completion_timeout(&io_req->tm_done,
1987             QEDF_TM_TIMEOUT * HZ);
1988
1989         if (!tmo) {
1990                 rc = FAILED;
1991                 QEDF_ERR(&(qedf->dbg_ctx), "wait for tm_cmpl timeout!\n");
1992         } else {
1993                 /* Check TMF response code */
1994                 if (io_req->fcp_rsp_code == 0)
1995                         rc = SUCCESS;
1996                 else
1997                         rc = FAILED;
1998         }
1999
2000         if (tm_flags == FCP_TMF_LUN_RESET)
2001                 qedf_flush_active_ios(fcport, (int)sc_cmd->device->lun);
2002         else
2003                 qedf_flush_active_ios(fcport, -1);
2004
2005         kref_put(&io_req->refcount, qedf_release_cmd);
2006
2007         if (rc != SUCCESS) {
2008                 QEDF_ERR(&(qedf->dbg_ctx), "task mgmt command failed...\n");
2009                 rc = FAILED;
2010         } else {
2011                 QEDF_ERR(&(qedf->dbg_ctx), "task mgmt command success...\n");
2012                 rc = SUCCESS;
2013         }
2014 reset_tmf_err:
2015         return rc;
2016 }
2017
2018 int qedf_initiate_tmf(struct scsi_cmnd *sc_cmd, u8 tm_flags)
2019 {
2020         struct fc_rport *rport = starget_to_rport(scsi_target(sc_cmd->device));
2021         struct fc_rport_libfc_priv *rp = rport->dd_data;
2022         struct qedf_rport *fcport = (struct qedf_rport *)&rp[1];
2023         struct qedf_ctx *qedf;
2024         struct fc_lport *lport;
2025         int rc = SUCCESS;
2026         int rval;
2027
2028         rval = fc_remote_port_chkready(rport);
2029
2030         if (rval) {
2031                 QEDF_ERR(NULL, "device_reset rport not ready\n");
2032                 rc = FAILED;
2033                 goto tmf_err;
2034         }
2035
2036         if (fcport == NULL) {
2037                 QEDF_ERR(NULL, "device_reset: rport is NULL\n");
2038                 rc = FAILED;
2039                 goto tmf_err;
2040         }
2041
2042         qedf = fcport->qedf;
2043         lport = qedf->lport;
2044
2045         if (test_bit(QEDF_UNLOADING, &qedf->flags) ||
2046             test_bit(QEDF_DBG_STOP_IO, &qedf->flags)) {
2047                 rc = SUCCESS;
2048                 goto tmf_err;
2049         }
2050
2051         if (lport->state != LPORT_ST_READY || !(lport->link_up)) {
2052                 QEDF_ERR(&(qedf->dbg_ctx), "link is not ready\n");
2053                 rc = FAILED;
2054                 goto tmf_err;
2055         }
2056
2057         rc = qedf_execute_tmf(fcport, sc_cmd, tm_flags);
2058
2059 tmf_err:
2060         return rc;
2061 }
2062
2063 void qedf_process_tmf_compl(struct qedf_ctx *qedf, struct fcoe_cqe *cqe,
2064         struct qedf_ioreq *io_req)
2065 {
2066         struct fcoe_cqe_rsp_info *fcp_rsp;
2067
2068         fcp_rsp = &cqe->cqe_info.rsp_info;
2069         qedf_parse_fcp_rsp(io_req, fcp_rsp);
2070
2071         io_req->sc_cmd = NULL;
2072         complete(&io_req->tm_done);
2073 }
2074
2075 void qedf_process_unsol_compl(struct qedf_ctx *qedf, uint16_t que_idx,
2076         struct fcoe_cqe *cqe)
2077 {
2078         unsigned long flags;
2079         uint16_t tmp;
2080         uint16_t pktlen = cqe->cqe_info.unsolic_info.pkt_len;
2081         u32 payload_len, crc;
2082         struct fc_frame_header *fh;
2083         struct fc_frame *fp;
2084         struct qedf_io_work *io_work;
2085         u32 bdq_idx;
2086         void *bdq_addr;
2087         struct scsi_bd *p_bd_info;
2088
2089         p_bd_info = &cqe->cqe_info.unsolic_info.bd_info;
2090         QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_UNSOL,
2091                   "address.hi=%x, address.lo=%x, opaque_data.hi=%x, opaque_data.lo=%x, bdq_prod_idx=%u, len=%u\n",
2092                   le32_to_cpu(p_bd_info->address.hi),
2093                   le32_to_cpu(p_bd_info->address.lo),
2094                   le32_to_cpu(p_bd_info->opaque.fcoe_opaque.hi),
2095                   le32_to_cpu(p_bd_info->opaque.fcoe_opaque.lo),
2096                   qedf->bdq_prod_idx, pktlen);
2097
2098         bdq_idx = le32_to_cpu(p_bd_info->opaque.fcoe_opaque.lo);
2099         if (bdq_idx >= QEDF_BDQ_SIZE) {
2100                 QEDF_ERR(&(qedf->dbg_ctx), "bdq_idx is out of range %d.\n",
2101                     bdq_idx);
2102                 goto increment_prod;
2103         }
2104
2105         bdq_addr = qedf->bdq[bdq_idx].buf_addr;
2106         if (!bdq_addr) {
2107                 QEDF_ERR(&(qedf->dbg_ctx), "bdq_addr is NULL, dropping "
2108                     "unsolicited packet.\n");
2109                 goto increment_prod;
2110         }
2111
2112         if (qedf_dump_frames) {
2113                 QEDF_INFO(&(qedf->dbg_ctx), QEDF_LOG_UNSOL,
2114                     "BDQ frame is at addr=%p.\n", bdq_addr);
2115                 print_hex_dump(KERN_WARNING, "bdq ", DUMP_PREFIX_OFFSET, 16, 1,
2116                     (void *)bdq_addr, pktlen, false);
2117         }
2118
2119         /* Allocate frame */
2120         payload_len = pktlen - sizeof(struct fc_frame_header);
2121         fp = fc_frame_alloc(qedf->lport, payload_len);
2122         if (!fp) {
2123                 QEDF_ERR(&(qedf->dbg_ctx), "Could not allocate fp.\n");
2124                 goto increment_prod;
2125         }
2126
2127         /* Copy data from BDQ buffer into fc_frame struct */
2128         fh = (struct fc_frame_header *)fc_frame_header_get(fp);
2129         memcpy(fh, (void *)bdq_addr, pktlen);
2130
2131         /* Initialize the frame so libfc sees it as a valid frame */
2132         crc = fcoe_fc_crc(fp);
2133         fc_frame_init(fp);
2134         fr_dev(fp) = qedf->lport;
2135         fr_sof(fp) = FC_SOF_I3;
2136         fr_eof(fp) = FC_EOF_T;
2137         fr_crc(fp) = cpu_to_le32(~crc);
2138
2139         /*
2140          * We need to return the frame back up to libfc in a non-atomic
2141          * context
2142          */
2143         io_work = mempool_alloc(qedf->io_mempool, GFP_ATOMIC);
2144         if (!io_work) {
2145                 QEDF_WARN(&(qedf->dbg_ctx), "Could not allocate "
2146                            "work for I/O completion.\n");
2147                 fc_frame_free(fp);
2148                 goto increment_prod;
2149         }
2150         memset(io_work, 0, sizeof(struct qedf_io_work));
2151
2152         INIT_WORK(&io_work->work, qedf_fp_io_handler);
2153
2154         /* Copy contents of CQE for deferred processing */
2155         memcpy(&io_work->cqe, cqe, sizeof(struct fcoe_cqe));
2156
2157         io_work->qedf = qedf;
2158         io_work->fp = fp;
2159
2160         queue_work_on(smp_processor_id(), qedf_io_wq, &io_work->work);
2161 increment_prod:
2162         spin_lock_irqsave(&qedf->hba_lock, flags);
2163
2164         /* Increment producer to let f/w know we've handled the frame */
2165         qedf->bdq_prod_idx++;
2166
2167         /* Producer index wraps at uint16_t boundary */
2168         if (qedf->bdq_prod_idx == 0xffff)
2169                 qedf->bdq_prod_idx = 0;
2170
2171         writew(qedf->bdq_prod_idx, qedf->bdq_primary_prod);
2172         tmp = readw(qedf->bdq_primary_prod);
2173         writew(qedf->bdq_prod_idx, qedf->bdq_secondary_prod);
2174         tmp = readw(qedf->bdq_secondary_prod);
2175
2176         spin_unlock_irqrestore(&qedf->hba_lock, flags);
2177 }