net/mlx5: rename RxQ verbs to general RxQ object
[dpdk.git] / drivers / net / mlx5 / mlx5_rxtx.h
index 26f845c..eb20a07 100644 (file)
@@ -29,6 +29,7 @@
 #include <rte_spinlock.h>
 #include <rte_io.h>
 #include <rte_bus_pci.h>
+#include <rte_malloc.h>
 
 #include "mlx5_utils.h"
 #include "mlx5.h"
@@ -140,13 +141,23 @@ struct mlx5_rxq_data {
        uint32_t tunnel; /* Tunnel information. */
 } __rte_cache_aligned;
 
-/* Verbs Rx queue elements. */
-struct mlx5_rxq_ibv {
-       LIST_ENTRY(mlx5_rxq_ibv) next; /* Pointer to the next element. */
+enum mlx5_rxq_obj_type {
+       MLX5_RXQ_OBJ_TYPE_IBV,          /* mlx5_rxq_obj with ibv_wq. */
+       MLX5_RXQ_OBJ_TYPE_DEVX_RQ,      /* mlx5_rxq_obj with mlx5_devx_rq. */
+};
+
+/* Verbs/DevX Rx queue elements. */
+struct mlx5_rxq_obj {
+       LIST_ENTRY(mlx5_rxq_obj) next; /* Pointer to the next element. */
        rte_atomic32_t refcnt; /* Reference counter. */
        struct mlx5_rxq_ctrl *rxq_ctrl; /* Back pointer to parent. */
        struct ibv_cq *cq; /* Completion Queue. */
-       struct ibv_wq *wq; /* Work Queue. */
+       enum mlx5_rxq_obj_type type;
+       RTE_STD_C11
+       union {
+               struct ibv_wq *wq; /* Work Queue. */
+               struct mlx5_devx_obj *rq; /* DevX object for Rx Queue. */
+       };
        struct ibv_comp_channel *channel;
 };
 
@@ -155,12 +166,13 @@ struct mlx5_rxq_ctrl {
        struct mlx5_rxq_data rxq; /* Data path structure. */
        LIST_ENTRY(mlx5_rxq_ctrl) next; /* Pointer to the next element. */
        rte_atomic32_t refcnt; /* Reference counter. */
-       struct mlx5_rxq_ibv *ibv; /* Verbs elements. */
+       struct mlx5_rxq_obj *obj; /* Verbs/DevX elements. */
        struct mlx5_priv *priv; /* Back pointer to private data. */
        unsigned int socket; /* CPU socket ID for allocations. */
        unsigned int irq:1; /* Whether IRQ is enabled. */
        uint32_t flow_mark_n; /* Number of Mark/Flag flows using this Queue. */
        uint32_t flow_tunnels_n[MLX5_FLOW_TUNNEL]; /* Tunnels counters. */
+       uint32_t wqn; /* WQ number. */
        uint16_t dump_file_n; /* Number of dump files. */
 };
 
@@ -187,37 +199,61 @@ struct mlx5_hrxq {
        uint8_t rss_key[]; /* Hash key. */
 };
 
+/* TX queue send local data. */
+__extension__
+struct mlx5_txq_local {
+       struct mlx5_wqe *wqe_last; /* last sent WQE pointer. */
+       struct rte_mbuf *mbuf; /* first mbuf to process. */
+       uint16_t pkts_copy; /* packets copied to elts. */
+       uint16_t pkts_sent; /* packets sent. */
+       uint16_t elts_free; /* available elts remain. */
+       uint16_t wqe_free; /* available wqe remain. */
+       uint16_t mbuf_off; /* data offset in current mbuf. */
+       uint16_t mbuf_nseg; /* number of remaining mbuf. */
+};
+
 /* TX queue descriptor. */
 __extension__
 struct mlx5_txq_data {
        uint16_t elts_head; /* Current counter in (*elts)[]. */
        uint16_t elts_tail; /* Counter of first element awaiting completion. */
-       uint16_t elts_comp; /* Counter since last completion request. */
-       uint16_t mpw_comp; /* WQ index since last completion request. */
+       uint16_t elts_comp; /* elts index since last completion request. */
+       uint16_t elts_s; /* Number of mbuf elements. */
+       uint16_t elts_m; /* Mask for mbuf elements indices. */
+       /* Fields related to elts mbuf storage. */
+       uint16_t wqe_ci; /* Consumer index for work queue. */
+       uint16_t wqe_pi; /* Producer index for work queue. */
+       uint16_t wqe_s; /* Number of WQ elements. */
+       uint16_t wqe_m; /* Mask Number for WQ elements. */
+       uint16_t wqe_comp; /* WQE index since last completion request. */
+       uint16_t wqe_thres; /* WQE threshold to request completion in CQ. */
+       /* WQ related fields. */
        uint16_t cq_ci; /* Consumer index for completion queue. */
 #ifndef NDEBUG
-       uint16_t cq_pi; /* Producer index for completion queue. */
+       uint16_t cq_pi; /* Counter of issued CQE "always" requests. */
 #endif
-       uint16_t wqe_ci; /* Consumer index for work queue. */
-       uint16_t wqe_pi; /* Producer index for work queue. */
-       uint16_t elts_n:4; /* (*elts)[] length (in log2). */
+       uint16_t cqe_s; /* Number of CQ elements. */
+       uint16_t cqe_m; /* Mask for CQ indices. */
+       /* CQ related fields. */
+       uint16_t elts_n:4; /* elts[] length (in log2). */
        uint16_t cqe_n:4; /* Number of CQ elements (in log2). */
-       uint16_t wqe_n:4; /* Number of of WQ elements (in log2). */
+       uint16_t wqe_n:4; /* Number of WQ elements (in log2). */
        uint16_t tso_en:1; /* When set hardware TSO is enabled. */
        uint16_t tunnel_en:1;
        /* When set TX offload for tunneled packets are supported. */
        uint16_t swp_en:1; /* Whether SW parser is enabled. */
-       uint16_t mpw_hdr_dseg:1; /* Enable DSEGs in the title WQEBB. */
-       uint16_t max_inline; /* Multiple of RTE_CACHE_LINE_SIZE to inline. */
-       uint16_t inline_max_packet_sz; /* Max packet size for inlining. */
+       uint16_t vlan_en:1; /* VLAN insertion in WQE is supported. */
+       uint16_t inlen_send; /* Ordinary send data inline size. */
+       uint16_t inlen_empw; /* eMPW max packet size to inline. */
+       uint16_t inlen_mode; /* Minimal data length to inline. */
        uint32_t qp_num_8s; /* QP number shifted by 8. */
        uint64_t offloads; /* Offloads for Tx Queue. */
        struct mlx5_mr_ctrl mr_ctrl; /* MR control descriptor. */
-       volatile struct mlx5_cqe (*cqes)[]; /* Completion queue. */
-       volatile void *wqes; /* Work queue (use volatile to write into). */
+       struct mlx5_wqe *wqes; /* Work queue. */
+       struct mlx5_wqe *wqes_end; /* Work queue array limit. */
+       volatile struct mlx5_cqe *cqes; /* Completion queue. */
        volatile uint32_t *qp_db; /* Work queue doorbell. */
        volatile uint32_t *cq_db; /* Completion queue doorbell. */
-       struct rte_mbuf *(*elts)[]; /* TX elements. */
        uint16_t port_id; /* Port ID of device. */
        uint16_t idx; /* Queue index. */
        struct mlx5_txq_stats stats; /* TX queue counters. */
@@ -225,6 +261,8 @@ struct mlx5_txq_data {
        rte_spinlock_t *uar_lock;
        /* UAR access lock required for 32bit implementations */
 #endif
+       struct rte_mbuf *elts[0];
+       /* Storage for queued packets, must be the last field. */
 } __rte_cache_aligned;
 
 /* Verbs Rx queue elements. */
@@ -238,7 +276,6 @@ struct mlx5_txq_ibv {
 
 /* TX queue control descriptor. */
 struct mlx5_txq_ctrl {
-       struct mlx5_txq_data txq; /* Data path structure. */
        LIST_ENTRY(mlx5_txq_ctrl) next; /* Pointer to the next element. */
        rte_atomic32_t refcnt; /* Reference counter. */
        unsigned int socket; /* CPU socket ID for allocations. */
@@ -248,6 +285,9 @@ struct mlx5_txq_ctrl {
        struct mlx5_priv *priv; /* Back pointer to private data. */
        off_t uar_mmap_offset; /* UAR mmap offset for non-primary process. */
        void *bf_reg; /* BlueFlame register from Verbs. */
+       uint16_t dump_file_n; /* Number of dump files. */
+       struct mlx5_txq_data txq; /* Data path structure. */
+       /* Must be the last field in the structure, contains elts[]. */
 };
 
 #define MLX5_TX_BFREG(txq) \
@@ -270,8 +310,8 @@ int mlx5_rx_intr_vec_enable(struct rte_eth_dev *dev);
 void mlx5_rx_intr_vec_disable(struct rte_eth_dev *dev);
 int mlx5_rx_intr_enable(struct rte_eth_dev *dev, uint16_t rx_queue_id);
 int mlx5_rx_intr_disable(struct rte_eth_dev *dev, uint16_t rx_queue_id);
-struct mlx5_rxq_ibv *mlx5_rxq_ibv_new(struct rte_eth_dev *dev, uint16_t idx);
-int mlx5_rxq_ibv_verify(struct rte_eth_dev *dev);
+struct mlx5_rxq_obj *mlx5_rxq_obj_new(struct rte_eth_dev *dev, uint16_t idx);
+int mlx5_rxq_obj_verify(struct rte_eth_dev *dev);
 struct mlx5_rxq_ctrl *mlx5_rxq_new(struct rte_eth_dev *dev, uint16_t idx,
                                   uint16_t desc, unsigned int socket,
                                   const struct rte_eth_rxconf *conf,
@@ -294,8 +334,9 @@ int mlx5_hrxq_release(struct rte_eth_dev *dev, struct mlx5_hrxq *hxrq);
 int mlx5_hrxq_ibv_verify(struct rte_eth_dev *dev);
 struct mlx5_hrxq *mlx5_hrxq_drop_new(struct rte_eth_dev *dev);
 void mlx5_hrxq_drop_release(struct rte_eth_dev *dev);
-uint64_t mlx5_get_rx_port_offloads(void);
+uint64_t mlx5_get_rx_port_offloads(struct rte_eth_dev *dev);
 uint64_t mlx5_get_rx_queue_offloads(struct rte_eth_dev *dev);
+int mlx5_lro_on(struct rte_eth_dev *dev);
 
 /* mlx5_txq.c */
 
@@ -326,14 +367,9 @@ extern uint8_t mlx5_swp_types_table[];
 void mlx5_set_ptype_table(void);
 void mlx5_set_cksum_table(void);
 void mlx5_set_swp_types_table(void);
-uint16_t mlx5_tx_burst(void *dpdk_txq, struct rte_mbuf **pkts,
-                      uint16_t pkts_n);
-uint16_t mlx5_tx_burst_mpw(void *dpdk_txq, struct rte_mbuf **pkts,
-                          uint16_t pkts_n);
-uint16_t mlx5_tx_burst_mpw_inline(void *dpdk_txq, struct rte_mbuf **pkts,
-                                 uint16_t pkts_n);
-uint16_t mlx5_tx_burst_empw(void *dpdk_txq, struct rte_mbuf **pkts,
-                           uint16_t pkts_n);
+__rte_noinline uint16_t mlx5_tx_error_cqe_handle
+                               (struct mlx5_txq_data *restrict txq,
+                                volatile struct mlx5_err_cqe *err_cqe);
 uint16_t mlx5_rx_burst(void *dpdk_rxq, struct rte_mbuf **pkts, uint16_t pkts_n);
 void mlx5_rxq_initialize(struct mlx5_rxq_data *rxq);
 __rte_noinline int mlx5_rx_err_handle(struct mlx5_rxq_data *rxq,
@@ -351,16 +387,12 @@ int mlx5_tx_descriptor_status(void *tx_queue, uint16_t offset);
 uint32_t mlx5_rx_queue_count(struct rte_eth_dev *dev, uint16_t rx_queue_id);
 void mlx5_dump_debug_information(const char *path, const char *title,
                                 const void *buf, unsigned int len);
+int mlx5_queue_state_modify_primary(struct rte_eth_dev *dev,
+                       const struct mlx5_mp_arg_queue_state_modify *sm);
 
 /* Vectorized version of mlx5_rxtx.c */
-int mlx5_check_raw_vec_tx_support(struct rte_eth_dev *dev);
-int mlx5_check_vec_tx_support(struct rte_eth_dev *dev);
 int mlx5_rxq_check_vec_support(struct mlx5_rxq_data *rxq_data);
 int mlx5_check_vec_rx_support(struct rte_eth_dev *dev);
-uint16_t mlx5_tx_burst_raw_vec(void *dpdk_txq, struct rte_mbuf **pkts,
-                              uint16_t pkts_n);
-uint16_t mlx5_tx_burst_vec(void *dpdk_txq, struct rte_mbuf **pkts,
-                          uint16_t pkts_n);
 uint16_t mlx5_rx_burst_vec(void *dpdk_txq, struct rte_mbuf **pkts,
                           uint16_t pkts_n);
 
@@ -470,107 +502,6 @@ check_cqe(volatile struct mlx5_cqe *cqe, const uint16_t cqes_n,
        return MLX5_CQE_STATUS_SW_OWN;
 }
 
-/**
- * Return the address of the WQE.
- *
- * @param txq
- *   Pointer to TX queue structure.
- * @param  wqe_ci
- *   WQE consumer index.
- *
- * @return
- *   WQE address.
- */
-static inline uintptr_t *
-tx_mlx5_wqe(struct mlx5_txq_data *txq, uint16_t ci)
-{
-       ci &= ((1 << txq->wqe_n) - 1);
-       return (uintptr_t *)((uintptr_t)txq->wqes + ci * MLX5_WQE_SIZE);
-}
-
-/**
- * Manage TX completions.
- *
- * When sending a burst, mlx5_tx_burst() posts several WRs.
- *
- * @param txq
- *   Pointer to TX queue structure.
- */
-static __rte_always_inline void
-mlx5_tx_complete(struct mlx5_txq_data *txq)
-{
-       const uint16_t elts_n = 1 << txq->elts_n;
-       const uint16_t elts_m = elts_n - 1;
-       const unsigned int cqe_n = 1 << txq->cqe_n;
-       const unsigned int cqe_cnt = cqe_n - 1;
-       uint16_t elts_free = txq->elts_tail;
-       uint16_t elts_tail;
-       uint16_t cq_ci = txq->cq_ci;
-       volatile struct mlx5_cqe *cqe = NULL;
-       volatile struct mlx5_wqe_ctrl *ctrl;
-       struct rte_mbuf *m, *free[elts_n];
-       struct rte_mempool *pool = NULL;
-       unsigned int blk_n = 0;
-
-       cqe = &(*txq->cqes)[cq_ci & cqe_cnt];
-       if (unlikely(check_cqe(cqe, cqe_n, cq_ci)))
-               return;
-#ifndef NDEBUG
-       if ((MLX5_CQE_OPCODE(cqe->op_own) == MLX5_CQE_RESP_ERR) ||
-           (MLX5_CQE_OPCODE(cqe->op_own) == MLX5_CQE_REQ_ERR)) {
-               if (!check_cqe_seen(cqe)) {
-                       DRV_LOG(ERR, "unexpected error CQE, Tx stopped");
-                       rte_hexdump(stderr, "MLX5 TXQ:",
-                                   (const void *)((uintptr_t)txq->wqes),
-                                   ((1 << txq->wqe_n) *
-                                    MLX5_WQE_SIZE));
-               }
-               return;
-       }
-#endif /* NDEBUG */
-       ++cq_ci;
-       rte_cio_rmb();
-       txq->wqe_pi = rte_be_to_cpu_16(cqe->wqe_counter);
-       ctrl = (volatile struct mlx5_wqe_ctrl *)
-               tx_mlx5_wqe(txq, txq->wqe_pi);
-       elts_tail = ctrl->ctrl3;
-       assert((elts_tail & elts_m) < (1 << txq->wqe_n));
-       /* Free buffers. */
-       while (elts_free != elts_tail) {
-               m = rte_pktmbuf_prefree_seg((*txq->elts)[elts_free++ & elts_m]);
-               if (likely(m != NULL)) {
-                       if (likely(m->pool == pool)) {
-                               free[blk_n++] = m;
-                       } else {
-                               if (likely(pool != NULL))
-                                       rte_mempool_put_bulk(pool,
-                                                            (void *)free,
-                                                            blk_n);
-                               free[0] = m;
-                               pool = m->pool;
-                               blk_n = 1;
-                       }
-               }
-       }
-       if (blk_n)
-               rte_mempool_put_bulk(pool, (void *)free, blk_n);
-#ifndef NDEBUG
-       elts_free = txq->elts_tail;
-       /* Poisoning. */
-       while (elts_free != elts_tail) {
-               memset(&(*txq->elts)[elts_free & elts_m],
-                      0x66,
-                      sizeof((*txq->elts)[elts_free & elts_m]));
-               ++elts_free;
-       }
-#endif
-       txq->cq_ci = cq_ci;
-       txq->elts_tail = elts_tail;
-       /* Update the consumer index. */
-       rte_compiler_barrier();
-       *txq->cq_db = rte_cpu_to_be_32(cq_ci);
-}
-
 /**
  * Get Memory Pool (MP) from mbuf. If mbuf is indirect, the pool from which the
  * cloned mbuf is allocated is returned instead.
@@ -688,147 +619,4 @@ mlx5_tx_dbrec(struct mlx5_txq_data *txq, volatile struct mlx5_wqe *wqe)
        mlx5_tx_dbrec_cond_wmb(txq, wqe, 1);
 }
 
-/**
- * Convert mbuf to Verb SWP.
- *
- * @param txq_data
- *   Pointer to the Tx queue.
- * @param buf
- *   Pointer to the mbuf.
- * @param offsets
- *   Pointer to the SWP header offsets.
- * @param swp_types
- *   Pointer to the SWP header types.
- */
-static __rte_always_inline void
-txq_mbuf_to_swp(struct mlx5_txq_data *txq, struct rte_mbuf *buf,
-               uint8_t *offsets, uint8_t *swp_types)
-{
-       const uint64_t vlan = buf->ol_flags & PKT_TX_VLAN_PKT;
-       const uint64_t tunnel = buf->ol_flags & PKT_TX_TUNNEL_MASK;
-       const uint64_t tso = buf->ol_flags & PKT_TX_TCP_SEG;
-       const uint64_t csum_flags = buf->ol_flags & PKT_TX_L4_MASK;
-       const uint64_t inner_ip =
-               buf->ol_flags & (PKT_TX_IPV4 | PKT_TX_IPV6);
-       const uint64_t ol_flags_mask = PKT_TX_L4_MASK | PKT_TX_IPV6 |
-                                      PKT_TX_OUTER_IPV6;
-       uint16_t idx;
-       uint16_t off;
-
-       if (likely(!txq->swp_en || (tunnel != PKT_TX_TUNNEL_UDP &&
-                                   tunnel != PKT_TX_TUNNEL_IP)))
-               return;
-       /*
-        * The index should have:
-        * bit[0:1] = PKT_TX_L4_MASK
-        * bit[4] = PKT_TX_IPV6
-        * bit[8] = PKT_TX_OUTER_IPV6
-        * bit[9] = PKT_TX_OUTER_UDP
-        */
-       idx = (buf->ol_flags & ol_flags_mask) >> 52;
-       if (tunnel == PKT_TX_TUNNEL_UDP)
-               idx |= 1 << 9;
-       *swp_types = mlx5_swp_types_table[idx];
-       /*
-        * Set offsets for SW parser. Since ConnectX-5, SW parser just
-        * complements HW parser. SW parser starts to engage only if HW parser
-        * can't reach a header. For the older devices, HW parser will not kick
-        * in if any of SWP offsets is set. Therefore, all of the L3 offsets
-        * should be set regardless of HW offload.
-        */
-       off = buf->outer_l2_len + (vlan ? sizeof(struct rte_vlan_hdr) : 0);
-       offsets[1] = off >> 1; /* Outer L3 offset. */
-       off += buf->outer_l3_len;
-       if (tunnel == PKT_TX_TUNNEL_UDP)
-               offsets[0] = off >> 1; /* Outer L4 offset. */
-       if (inner_ip) {
-               off += buf->l2_len;
-               offsets[3] = off >> 1; /* Inner L3 offset. */
-               if (csum_flags == PKT_TX_TCP_CKSUM || tso ||
-                   csum_flags == PKT_TX_UDP_CKSUM) {
-                       off += buf->l3_len;
-                       offsets[2] = off >> 1; /* Inner L4 offset. */
-               }
-       }
-}
-
-/**
- * Convert the Checksum offloads to Verbs.
- *
- * @param buf
- *   Pointer to the mbuf.
- *
- * @return
- *   Converted checksum flags.
- */
-static __rte_always_inline uint8_t
-txq_ol_cksum_to_cs(struct rte_mbuf *buf)
-{
-       uint32_t idx;
-       uint8_t is_tunnel = !!(buf->ol_flags & PKT_TX_TUNNEL_MASK);
-       const uint64_t ol_flags_mask = PKT_TX_TCP_SEG | PKT_TX_L4_MASK |
-                                      PKT_TX_IP_CKSUM | PKT_TX_OUTER_IP_CKSUM;
-
-       /*
-        * The index should have:
-        * bit[0] = PKT_TX_TCP_SEG
-        * bit[2:3] = PKT_TX_UDP_CKSUM, PKT_TX_TCP_CKSUM
-        * bit[4] = PKT_TX_IP_CKSUM
-        * bit[8] = PKT_TX_OUTER_IP_CKSUM
-        * bit[9] = tunnel
-        */
-       idx = ((buf->ol_flags & ol_flags_mask) >> 50) | (!!is_tunnel << 9);
-       return mlx5_cksum_table[idx];
-}
-
-/**
- * Count the number of contiguous single segment packets.
- *
- * @param pkts
- *   Pointer to array of packets.
- * @param pkts_n
- *   Number of packets.
- *
- * @return
- *   Number of contiguous single segment packets.
- */
-static __rte_always_inline unsigned int
-txq_count_contig_single_seg(struct rte_mbuf **pkts, uint16_t pkts_n)
-{
-       unsigned int pos;
-
-       if (!pkts_n)
-               return 0;
-       /* Count the number of contiguous single segment packets. */
-       for (pos = 0; pos < pkts_n; ++pos)
-               if (NB_SEGS(pkts[pos]) > 1)
-                       break;
-       return pos;
-}
-
-/**
- * Count the number of contiguous multi-segment packets.
- *
- * @param pkts
- *   Pointer to array of packets.
- * @param pkts_n
- *   Number of packets.
- *
- * @return
- *   Number of contiguous multi-segment packets.
- */
-static __rte_always_inline unsigned int
-txq_count_contig_multi_seg(struct rte_mbuf **pkts, uint16_t pkts_n)
-{
-       unsigned int pos;
-
-       if (!pkts_n)
-               return 0;
-       /* Count the number of contiguous multi-segment packets. */
-       for (pos = 0; pos < pkts_n; ++pos)
-               if (NB_SEGS(pkts[pos]) == 1)
-                       break;
-       return pos;
-}
-
 #endif /* RTE_PMD_MLX5_RXTX_H_ */