]> git.proxmox.com Git - mirror_ubuntu-bionic-kernel.git/blobdiff - drivers/scsi/mpt3sas/mpt3sas_base.c
Merge tag 'modules-for-v4.15' of git://git.kernel.org/pub/scm/linux/kernel/git/jeyu...
[mirror_ubuntu-bionic-kernel.git] / drivers / scsi / mpt3sas / mpt3sas_base.c
index 1ad3cbb362f50f24d4b1d770d641761e95e2ce2d..8027de465d474fc0a9dfe196cfcb41fcc1c0e129 100644 (file)
@@ -106,7 +106,7 @@ _base_get_ioc_facts(struct MPT3SAS_ADAPTER *ioc);
  *
  */
 static int
-_scsih_set_fwfault_debug(const char *val, struct kernel_param *kp)
+_scsih_set_fwfault_debug(const char *val, const struct kernel_param *kp)
 {
        int ret = param_set_int(val, kp);
        struct MPT3SAS_ADAPTER *ioc;
@@ -557,6 +557,11 @@ _base_sas_ioc_info(struct MPT3SAS_ADAPTER *ioc, MPI2DefaultReply_t *mpi_reply,
                frame_sz = sizeof(Mpi2SmpPassthroughRequest_t) + ioc->sge_size;
                func_str = "smp_passthru";
                break;
+       case MPI2_FUNCTION_NVME_ENCAPSULATED:
+               frame_sz = sizeof(Mpi26NVMeEncapsulatedRequest_t) +
+                   ioc->sge_size;
+               func_str = "nvme_encapsulated";
+               break;
        default:
                frame_sz = 32;
                func_str = "unknown";
@@ -658,6 +663,26 @@ _base_display_event_data(struct MPT3SAS_ADAPTER *ioc,
        case MPI2_EVENT_ACTIVE_CABLE_EXCEPTION:
                desc = "Cable Event";
                break;
+       case MPI2_EVENT_PCIE_DEVICE_STATUS_CHANGE:
+               desc = "PCIE Device Status Change";
+               break;
+       case MPI2_EVENT_PCIE_ENUMERATION:
+       {
+               Mpi26EventDataPCIeEnumeration_t *event_data =
+                       (Mpi26EventDataPCIeEnumeration_t *)mpi_reply->EventData;
+               pr_info(MPT3SAS_FMT "PCIE Enumeration: (%s)", ioc->name,
+                          (event_data->ReasonCode ==
+                               MPI26_EVENT_PCIE_ENUM_RC_STARTED) ?
+                               "start" : "stop");
+               if (event_data->EnumerationStatus)
+                       pr_info("enumeration_status(0x%08x)",
+                                  le32_to_cpu(event_data->EnumerationStatus));
+               pr_info("\n");
+               return;
+       }
+       case MPI2_EVENT_PCIE_TOPOLOGY_CHANGE_LIST:
+               desc = "PCIE Topology Change List";
+               break;
        }
 
        if (!desc)
@@ -985,7 +1010,9 @@ _base_interrupt(int irq, void *bus_id)
                if (request_desript_type ==
                    MPI25_RPY_DESCRIPT_FLAGS_FAST_PATH_SCSI_IO_SUCCESS ||
                    request_desript_type ==
-                   MPI2_RPY_DESCRIPT_FLAGS_SCSI_IO_SUCCESS) {
+                   MPI2_RPY_DESCRIPT_FLAGS_SCSI_IO_SUCCESS ||
+                   request_desript_type ==
+                   MPI26_RPY_DESCRIPT_FLAGS_PCIE_ENCAPSULATED_SUCCESS) {
                        cb_idx = _base_get_cb_idx(ioc, smid);
                        if ((likely(cb_idx < MPT_MAX_CALLBACKS)) &&
                            (likely(mpt_callbacks[cb_idx] != NULL))) {
@@ -1345,6 +1372,223 @@ _base_build_sg(struct MPT3SAS_ADAPTER *ioc, void *psge,
        }
 }
 
+/* IEEE format sgls */
+
+/**
+ * _base_build_nvme_prp - This function is called for NVMe end devices to build
+ * a native SGL (NVMe PRP). The native SGL is built starting in the first PRP
+ * entry of the NVMe message (PRP1).  If the data buffer is small enough to be
+ * described entirely using PRP1, then PRP2 is not used.  If needed, PRP2 is
+ * used to describe a larger data buffer.  If the data buffer is too large to
+ * describe using the two PRP entriess inside the NVMe message, then PRP1
+ * describes the first data memory segment, and PRP2 contains a pointer to a PRP
+ * list located elsewhere in memory to describe the remaining data memory
+ * segments.  The PRP list will be contiguous.
+
+ * The native SGL for NVMe devices is a Physical Region Page (PRP).  A PRP
+ * consists of a list of PRP entries to describe a number of noncontigous
+ * physical memory segments as a single memory buffer, just as a SGL does.  Note
+ * however, that this function is only used by the IOCTL call, so the memory
+ * given will be guaranteed to be contiguous.  There is no need to translate
+ * non-contiguous SGL into a PRP in this case.  All PRPs will describe
+ * contiguous space that is one page size each.
+ *
+ * Each NVMe message contains two PRP entries.  The first (PRP1) either contains
+ * a PRP list pointer or a PRP element, depending upon the command.  PRP2
+ * contains the second PRP element if the memory being described fits within 2
+ * PRP entries, or a PRP list pointer if the PRP spans more than two entries.
+ *
+ * A PRP list pointer contains the address of a PRP list, structured as a linear
+ * array of PRP entries.  Each PRP entry in this list describes a segment of
+ * physical memory.
+ *
+ * Each 64-bit PRP entry comprises an address and an offset field.  The address
+ * always points at the beginning of a 4KB physical memory page, and the offset
+ * describes where within that 4KB page the memory segment begins.  Only the
+ * first element in a PRP list may contain a non-zero offest, implying that all
+ * memory segments following the first begin at the start of a 4KB page.
+ *
+ * Each PRP element normally describes 4KB of physical memory, with exceptions
+ * for the first and last elements in the list.  If the memory being described
+ * by the list begins at a non-zero offset within the first 4KB page, then the
+ * first PRP element will contain a non-zero offset indicating where the region
+ * begins within the 4KB page.  The last memory segment may end before the end
+ * of the 4KB segment, depending upon the overall size of the memory being
+ * described by the PRP list.
+ *
+ * Since PRP entries lack any indication of size, the overall data buffer length
+ * is used to determine where the end of the data memory buffer is located, and
+ * how many PRP entries are required to describe it.
+ *
+ * @ioc: per adapter object
+ * @smid: system request message index for getting asscociated SGL
+ * @nvme_encap_request: the NVMe request msg frame pointer
+ * @data_out_dma: physical address for WRITES
+ * @data_out_sz: data xfer size for WRITES
+ * @data_in_dma: physical address for READS
+ * @data_in_sz: data xfer size for READS
+ *
+ * Returns nothing.
+ */
+static void
+_base_build_nvme_prp(struct MPT3SAS_ADAPTER *ioc, u16 smid,
+       Mpi26NVMeEncapsulatedRequest_t *nvme_encap_request,
+       dma_addr_t data_out_dma, size_t data_out_sz, dma_addr_t data_in_dma,
+       size_t data_in_sz)
+{
+       int             prp_size = NVME_PRP_SIZE;
+       __le64          *prp_entry, *prp1_entry, *prp2_entry;
+       __le64          *prp_page;
+       dma_addr_t      prp_entry_dma, prp_page_dma, dma_addr;
+       u32             offset, entry_len;
+       u32             page_mask_result, page_mask;
+       size_t          length;
+
+       /*
+        * Not all commands require a data transfer. If no data, just return
+        * without constructing any PRP.
+        */
+       if (!data_in_sz && !data_out_sz)
+               return;
+       /*
+        * Set pointers to PRP1 and PRP2, which are in the NVMe command.
+        * PRP1 is located at a 24 byte offset from the start of the NVMe
+        * command.  Then set the current PRP entry pointer to PRP1.
+        */
+       prp1_entry = (__le64 *)(nvme_encap_request->NVMe_Command +
+           NVME_CMD_PRP1_OFFSET);
+       prp2_entry = (__le64 *)(nvme_encap_request->NVMe_Command +
+           NVME_CMD_PRP2_OFFSET);
+       prp_entry = prp1_entry;
+       /*
+        * For the PRP entries, use the specially allocated buffer of
+        * contiguous memory.
+        */
+       prp_page = (__le64 *)mpt3sas_base_get_pcie_sgl(ioc, smid);
+       prp_page_dma = mpt3sas_base_get_pcie_sgl_dma(ioc, smid);
+
+       /*
+        * Check if we are within 1 entry of a page boundary we don't
+        * want our first entry to be a PRP List entry.
+        */
+       page_mask = ioc->page_size - 1;
+       page_mask_result = (uintptr_t)((u8 *)prp_page + prp_size) & page_mask;
+       if (!page_mask_result) {
+               /* Bump up to next page boundary. */
+               prp_page = (__le64 *)((u8 *)prp_page + prp_size);
+               prp_page_dma = prp_page_dma + prp_size;
+       }
+
+       /*
+        * Set PRP physical pointer, which initially points to the current PRP
+        * DMA memory page.
+        */
+       prp_entry_dma = prp_page_dma;
+
+       /* Get physical address and length of the data buffer. */
+       if (data_in_sz) {
+               dma_addr = data_in_dma;
+               length = data_in_sz;
+       } else {
+               dma_addr = data_out_dma;
+               length = data_out_sz;
+       }
+
+       /* Loop while the length is not zero. */
+       while (length) {
+               /*
+                * Check if we need to put a list pointer here if we are at
+                * page boundary - prp_size (8 bytes).
+                */
+               page_mask_result = (prp_entry_dma + prp_size) & page_mask;
+               if (!page_mask_result) {
+                       /*
+                        * This is the last entry in a PRP List, so we need to
+                        * put a PRP list pointer here.  What this does is:
+                        *   - bump the current memory pointer to the next
+                        *     address, which will be the next full page.
+                        *   - set the PRP Entry to point to that page.  This
+                        *     is now the PRP List pointer.
+                        *   - bump the PRP Entry pointer the start of the
+                        *     next page.  Since all of this PRP memory is
+                        *     contiguous, no need to get a new page - it's
+                        *     just the next address.
+                        */
+                       prp_entry_dma++;
+                       *prp_entry = cpu_to_le64(prp_entry_dma);
+                       prp_entry++;
+               }
+
+               /* Need to handle if entry will be part of a page. */
+               offset = dma_addr & page_mask;
+               entry_len = ioc->page_size - offset;
+
+               if (prp_entry == prp1_entry) {
+                       /*
+                        * Must fill in the first PRP pointer (PRP1) before
+                        * moving on.
+                        */
+                       *prp1_entry = cpu_to_le64(dma_addr);
+
+                       /*
+                        * Now point to the second PRP entry within the
+                        * command (PRP2).
+                        */
+                       prp_entry = prp2_entry;
+               } else if (prp_entry == prp2_entry) {
+                       /*
+                        * Should the PRP2 entry be a PRP List pointer or just
+                        * a regular PRP pointer?  If there is more than one
+                        * more page of data, must use a PRP List pointer.
+                        */
+                       if (length > ioc->page_size) {
+                               /*
+                                * PRP2 will contain a PRP List pointer because
+                                * more PRP's are needed with this command. The
+                                * list will start at the beginning of the
+                                * contiguous buffer.
+                                */
+                               *prp2_entry = cpu_to_le64(prp_entry_dma);
+
+                               /*
+                                * The next PRP Entry will be the start of the
+                                * first PRP List.
+                                */
+                               prp_entry = prp_page;
+                       } else {
+                               /*
+                                * After this, the PRP Entries are complete.
+                                * This command uses 2 PRP's and no PRP list.
+                                */
+                               *prp2_entry = cpu_to_le64(dma_addr);
+                       }
+               } else {
+                       /*
+                        * Put entry in list and bump the addresses.
+                        *
+                        * After PRP1 and PRP2 are filled in, this will fill in
+                        * all remaining PRP entries in a PRP List, one per
+                        * each time through the loop.
+                        */
+                       *prp_entry = cpu_to_le64(dma_addr);
+                       prp_entry++;
+                       prp_entry_dma++;
+               }
+
+               /*
+                * Bump the phys address of the command's data buffer by the
+                * entry_len.
+                */
+               dma_addr += entry_len;
+
+               /* Decrement length accounting for last partial page. */
+               if (entry_len > length)
+                       length = 0;
+               else
+                       length -= entry_len;
+       }
+}
+
 /**
  * base_make_prp_nvme -
  * Prepare PRPs(Physical Region Page)- SGLs specific to NVMe drives only
@@ -1358,17 +1602,16 @@ _base_build_sg(struct MPT3SAS_ADAPTER *ioc, void *psge,
  * Returns:            true: PRPs are built
  *                     false: IEEE SGLs needs to be built
  */
-void
+static void
 base_make_prp_nvme(struct MPT3SAS_ADAPTER *ioc,
                struct scsi_cmnd *scmd,
                Mpi25SCSIIORequest_t *mpi_request,
                u16 smid, int sge_count)
 {
-       int sge_len, offset, num_prp_in_chain = 0;
+       int sge_len, num_prp_in_chain = 0;
        Mpi25IeeeSgeChain64_t *main_chain_element, *ptr_first_sgl;
-       u64 *curr_buff;
-       dma_addr_t msg_phys;
-       u64 sge_addr;
+       __le64 *curr_buff;
+       dma_addr_t msg_dma, sge_addr, offset;
        u32 page_mask, page_mask_result;
        struct scatterlist *sg_scmd;
        u32 first_prp_len;
@@ -1415,9 +1658,9 @@ base_make_prp_nvme(struct MPT3SAS_ADAPTER *ioc,
         * page (4k).
         */
        curr_buff = mpt3sas_base_get_pcie_sgl(ioc, smid);
-       msg_phys = (dma_addr_t)mpt3sas_base_get_pcie_sgl_dma(ioc, smid);
+       msg_dma = mpt3sas_base_get_pcie_sgl_dma(ioc, smid);
 
-       main_chain_element->Address = cpu_to_le64(msg_phys);
+       main_chain_element->Address = cpu_to_le64(msg_dma);
        main_chain_element->NextChainOffset = 0;
        main_chain_element->Flags = MPI2_IEEE_SGE_FLAGS_CHAIN_ELEMENT |
                        MPI2_IEEE_SGE_FLAGS_SYSTEM_ADDR |
@@ -1429,7 +1672,7 @@ base_make_prp_nvme(struct MPT3SAS_ADAPTER *ioc,
        sge_addr = sg_dma_address(sg_scmd);
        sge_len = sg_dma_len(sg_scmd);
 
-       offset = (u32)(sge_addr & page_mask);
+       offset = sge_addr & page_mask;
        first_prp_len = nvme_pg_size - offset;
 
        ptr_first_sgl->Address = cpu_to_le64(sge_addr);
@@ -1447,7 +1690,7 @@ base_make_prp_nvme(struct MPT3SAS_ADAPTER *ioc,
        }
 
        for (;;) {
-               offset = (u32)(sge_addr & page_mask);
+               offset = sge_addr & page_mask;
 
                /* Put PRP pointer due to page boundary*/
                page_mask_result = (uintptr_t)(curr_buff + 1) & page_mask;
@@ -1455,15 +1698,15 @@ base_make_prp_nvme(struct MPT3SAS_ADAPTER *ioc,
                        scmd_printk(KERN_NOTICE,
                                scmd, "page boundary curr_buff: 0x%p\n",
                                curr_buff);
-                       msg_phys += 8;
-                       *curr_buff = cpu_to_le64(msg_phys);
+                       msg_dma += 8;
+                       *curr_buff = cpu_to_le64(msg_dma);
                        curr_buff++;
                        num_prp_in_chain++;
                }
 
                *curr_buff = cpu_to_le64(sge_addr);
                curr_buff++;
-               msg_phys += 8;
+               msg_dma += 8;
                num_prp_in_chain++;
 
                sge_addr += nvme_pg_size;
@@ -1494,7 +1737,7 @@ base_is_prp_possible(struct MPT3SAS_ADAPTER *ioc,
        struct scatterlist *sg_scmd;
        bool build_prp = true;
 
-       data_length = cpu_to_le32(scsi_bufflen(scmd));
+       data_length = scsi_bufflen(scmd);
        sg_scmd = scsi_sglist(scmd);
 
        /* If Datalenth is <= 16K and number of SGE’s entries are <= 2
@@ -2509,11 +2752,10 @@ mpt3sas_base_get_pcie_sgl(struct MPT3SAS_ADAPTER *ioc, u16 smid)
  *
  * Returns phys pointer to the address of the PCIe buffer.
  */
-void *
+dma_addr_t
 mpt3sas_base_get_pcie_sgl_dma(struct MPT3SAS_ADAPTER *ioc, u16 smid)
 {
-       return (void *)(uintptr_t)
-               (ioc->scsi_lookup[smid - 1].pcie_sg_list.pcie_sgl_dma);
+       return ioc->scsi_lookup[smid - 1].pcie_sg_list.pcie_sgl_dma;
 }
 
 /**
@@ -2793,6 +3035,30 @@ _base_put_smid_hi_priority(struct MPT3SAS_ADAPTER *ioc, u16 smid,
            &ioc->scsi_lookup_lock);
 }
 
+/**
+ * _base_put_smid_nvme_encap - send NVMe encapsulated request to
+ *  firmware
+ * @ioc: per adapter object
+ * @smid: system request message index
+ *
+ * Return nothing.
+ */
+static void
+_base_put_smid_nvme_encap(struct MPT3SAS_ADAPTER *ioc, u16 smid)
+{
+       Mpi2RequestDescriptorUnion_t descriptor;
+       u64 *request = (u64 *)&descriptor;
+
+       descriptor.Default.RequestFlags =
+               MPI26_REQ_DESCRIPT_FLAGS_PCIE_ENCAPSULATED;
+       descriptor.Default.MSIxIndex =  _base_get_msix_index(ioc);
+       descriptor.Default.SMID = cpu_to_le16(smid);
+       descriptor.Default.LMID = 0;
+       descriptor.Default.DescriptorTypeDependent = 0;
+       _base_writeq(*request, &ioc->chip->RequestDescriptorPostLow,
+           &ioc->scsi_lookup_lock);
+}
+
 /**
  * _base_put_smid_default - Default, primarily used for config pages
  * @ioc: per adapter object
@@ -2883,6 +3149,27 @@ _base_put_smid_hi_priority_atomic(struct MPT3SAS_ADAPTER *ioc, u16 smid,
        writel(cpu_to_le32(*request), &ioc->chip->AtomicRequestDescriptorPost);
 }
 
+/**
+ * _base_put_smid_nvme_encap_atomic - send NVMe encapsulated request to
+ *   firmware using Atomic Request Descriptor
+ * @ioc: per adapter object
+ * @smid: system request message index
+ *
+ * Return nothing.
+ */
+static void
+_base_put_smid_nvme_encap_atomic(struct MPT3SAS_ADAPTER *ioc, u16 smid)
+{
+       Mpi26AtomicRequestDescriptor_t descriptor;
+       u32 *request = (u32 *)&descriptor;
+
+       descriptor.RequestFlags = MPI26_REQ_DESCRIPT_FLAGS_PCIE_ENCAPSULATED;
+       descriptor.MSIxIndex = _base_get_msix_index(ioc);
+       descriptor.SMID = cpu_to_le16(smid);
+
+       writel(cpu_to_le32(*request), &ioc->chip->AtomicRequestDescriptorPost);
+}
+
 /**
  * _base_put_smid_default - Default, primarily used for config pages
  * use Atomic Request Descriptor
@@ -5707,6 +5994,7 @@ mpt3sas_base_attach(struct MPT3SAS_ADAPTER *ioc)
                 */
                ioc->build_sg_scmd = &_base_build_sg_scmd_ieee;
                ioc->build_sg = &_base_build_sg_ieee;
+               ioc->build_nvme_prp = &_base_build_nvme_prp;
                ioc->build_zero_len_sge = &_base_build_zero_len_sge_ieee;
                ioc->sge_size_ieee = sizeof(Mpi2IeeeSgeSimple64_t);
 
@@ -5718,11 +6006,13 @@ mpt3sas_base_attach(struct MPT3SAS_ADAPTER *ioc)
                ioc->put_smid_scsi_io = &_base_put_smid_scsi_io_atomic;
                ioc->put_smid_fast_path = &_base_put_smid_fast_path_atomic;
                ioc->put_smid_hi_priority = &_base_put_smid_hi_priority_atomic;
+               ioc->put_smid_nvme_encap = &_base_put_smid_nvme_encap_atomic;
        } else {
                ioc->put_smid_default = &_base_put_smid_default;
                ioc->put_smid_scsi_io = &_base_put_smid_scsi_io;
                ioc->put_smid_fast_path = &_base_put_smid_fast_path;
                ioc->put_smid_hi_priority = &_base_put_smid_hi_priority;
+               ioc->put_smid_nvme_encap = &_base_put_smid_nvme_encap;
        }
 
 
@@ -5851,7 +6141,15 @@ mpt3sas_base_attach(struct MPT3SAS_ADAPTER *ioc)
        _base_unmask_events(ioc, MPI2_EVENT_LOG_ENTRY_ADDED);
        _base_unmask_events(ioc, MPI2_EVENT_TEMP_THRESHOLD);
        _base_unmask_events(ioc, MPI2_EVENT_ACTIVE_CABLE_EXCEPTION);
-
+       if (ioc->hba_mpi_version_belonged == MPI26_VERSION) {
+               if (ioc->is_gen35_ioc) {
+                       _base_unmask_events(ioc,
+                               MPI2_EVENT_PCIE_DEVICE_STATUS_CHANGE);
+                       _base_unmask_events(ioc, MPI2_EVENT_PCIE_ENUMERATION);
+                       _base_unmask_events(ioc,
+                               MPI2_EVENT_PCIE_TOPOLOGY_CHANGE_LIST);
+               }
+       }
        r = _base_make_ioc_operational(ioc);
        if (r)
                goto out_free_resources;