doc: add maintainer role about replying questions
[dpdk.git] / test / test / test_eventdev_octeontx.c
index 9bcbdc6..033744f 100644 (file)
@@ -74,6 +74,30 @@ seqn_list_init(void)
        seqn_list_index = 0;
 }
 
+static inline int
+seqn_list_update(int val)
+{
+       if (seqn_list_index >= NUM_PACKETS)
+               return TEST_FAILED;
+
+       seqn_list[seqn_list_index++] = val;
+       rte_smp_wmb();
+       return TEST_SUCCESS;
+}
+
+static inline int
+seqn_list_check(int limit)
+{
+       int i;
+
+       for (i = 0; i < limit; i++) {
+               if (seqn_list[i] != i) {
+                       printf("Seqn mismatch %d %d\n", seqn_list[i], i);
+                       return TEST_FAILED;
+               }
+       }
+       return TEST_SUCCESS;
+}
 
 struct test_core_param {
        rte_atomic32_t *total_events;
@@ -220,6 +244,12 @@ eventdev_setup_priority(void)
        return _eventdev_setup(TEST_EVENTDEV_SETUP_PRIORITY);
 }
 
+static inline int
+eventdev_setup_dequeue_timeout(void)
+{
+       return _eventdev_setup(TEST_EVENTDEV_SETUP_DEQUEUE_TIMEOUT);
+}
+
 static inline void
 eventdev_teardown(void)
 {
@@ -696,6 +726,594 @@ test_queue_to_port_single_link(void)
        return TEST_SUCCESS;
 }
 
+static int
+validate_queue_to_port_multi_link(uint32_t index, uint8_t port,
+                       struct rte_event *ev)
+{
+       RTE_SET_USED(index);
+       TEST_ASSERT_EQUAL(port, (ev->queue_id & 0x1),
+                               "queue mismatch enq=%d deq =%d",
+                               port, ev->queue_id);
+       return 0;
+}
+
+/*
+ * Link all even number of queues to port 0 and all odd number of queues to
+ * port 1 and verify the link connection on dequeue
+ */
+static int
+test_queue_to_port_multi_link(void)
+{
+       int ret, port0_events = 0, port1_events = 0;
+       uint8_t nr_queues, nr_ports, queue, port;
+
+       nr_queues = rte_event_queue_count(evdev);
+       nr_ports = rte_event_port_count(evdev);
+
+       if (nr_ports < 2) {
+               printf("%s: Not enough ports to test ports=%d\n",
+                               __func__, nr_ports);
+               return TEST_SUCCESS;
+       }
+
+       /* Unlink all connections that created in eventdev_setup */
+       for (port = 0; port < nr_ports; port++) {
+               ret = rte_event_port_unlink(evdev, port, NULL, 0);
+               TEST_ASSERT(ret >= 0, "Failed to unlink all queues port=%d",
+                                       port);
+       }
+
+       const unsigned int total_events = MAX_EVENTS / nr_queues;
+
+       /* Link all even number of queues to port0 and odd numbers to port 1*/
+       for (queue = 0; queue < nr_queues; queue++) {
+               port = queue & 0x1;
+               ret = rte_event_port_link(evdev, port, &queue, NULL, 1);
+               TEST_ASSERT(ret == 1, "Failed to link queue=%d to port=%d",
+                                       queue, port);
+
+               ret = inject_events(
+                       0x100 /*flow_id */,
+                       rte_rand() % (RTE_EVENT_TYPE_CPU + 1) /* event_type */,
+                       rte_rand() % 256 /* sub_event_type */,
+                       rte_rand() % (RTE_SCHED_TYPE_PARALLEL + 1),
+                       queue /* queue */,
+                       port /* port */,
+                       total_events /* events */);
+               if (ret)
+                       return TEST_FAILED;
+
+               if (port == 0)
+                       port0_events += total_events;
+               else
+                       port1_events += total_events;
+       }
+
+       ret = consume_events(0 /* port */, port0_events,
+                               validate_queue_to_port_multi_link);
+       if (ret)
+               return TEST_FAILED;
+       ret = consume_events(1 /* port */, port1_events,
+                               validate_queue_to_port_multi_link);
+       if (ret)
+               return TEST_FAILED;
+
+       return TEST_SUCCESS;
+}
+
+static int
+worker_flow_based_pipeline(void *arg)
+{
+       struct test_core_param *param = arg;
+       struct rte_event ev;
+       uint16_t valid_event;
+       uint8_t port = param->port;
+       uint8_t new_sched_type = param->sched_type;
+       rte_atomic32_t *total_events = param->total_events;
+       uint64_t dequeue_tmo_ticks = param->dequeue_tmo_ticks;
+
+       while (rte_atomic32_read(total_events) > 0) {
+               valid_event = rte_event_dequeue_burst(evdev, port, &ev, 1,
+                                       dequeue_tmo_ticks);
+               if (!valid_event)
+                       continue;
+
+               /* Events from stage 0 */
+               if (ev.sub_event_type == 0) {
+                       /* Move to atomic flow to maintain the ordering */
+                       ev.flow_id = 0x2;
+                       ev.event_type = RTE_EVENT_TYPE_CPU;
+                       ev.sub_event_type = 1; /* stage 1 */
+                       ev.sched_type = new_sched_type;
+                       ev.op = RTE_EVENT_OP_FORWARD;
+                       rte_event_enqueue_burst(evdev, port, &ev, 1);
+               } else if (ev.sub_event_type == 1) { /* Events from stage 1*/
+                       if (seqn_list_update(ev.mbuf->seqn) == TEST_SUCCESS) {
+                               rte_pktmbuf_free(ev.mbuf);
+                               rte_atomic32_sub(total_events, 1);
+                       } else {
+                               printf("Failed to update seqn_list\n");
+                               return TEST_FAILED;
+                       }
+               } else {
+                       printf("Invalid ev.sub_event_type = %d\n",
+                                       ev.sub_event_type);
+                       return TEST_FAILED;
+               }
+       }
+       return 0;
+}
+
+static int
+test_multiport_flow_sched_type_test(uint8_t in_sched_type,
+                       uint8_t out_sched_type)
+{
+       const unsigned int total_events = MAX_EVENTS;
+       uint8_t nr_ports;
+       int ret;
+
+       nr_ports = RTE_MIN(rte_event_port_count(evdev), rte_lcore_count() - 1);
+
+       if (!nr_ports) {
+               printf("%s: Not enough ports=%d or workers=%d\n", __func__,
+                       rte_event_port_count(evdev), rte_lcore_count() - 1);
+               return TEST_SUCCESS;
+       }
+
+       /* Injects events with m->seqn=0 to total_events */
+       ret = inject_events(
+               0x1 /*flow_id */,
+               RTE_EVENT_TYPE_CPU /* event_type */,
+               0 /* sub_event_type (stage 0) */,
+               in_sched_type,
+               0 /* queue */,
+               0 /* port */,
+               total_events /* events */);
+       if (ret)
+               return TEST_FAILED;
+
+       ret = launch_workers_and_wait(worker_flow_based_pipeline,
+                                       worker_flow_based_pipeline,
+                                       total_events, nr_ports, out_sched_type);
+       if (ret)
+               return TEST_FAILED;
+
+       if (in_sched_type != RTE_SCHED_TYPE_PARALLEL &&
+                       out_sched_type == RTE_SCHED_TYPE_ATOMIC) {
+               /* Check the events order maintained or not */
+               return seqn_list_check(total_events);
+       }
+       return TEST_SUCCESS;
+}
+
+
+/* Multi port ordered to atomic transaction */
+static int
+test_multi_port_flow_ordered_to_atomic(void)
+{
+       /* Ingress event order test */
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_ORDERED,
+                               RTE_SCHED_TYPE_ATOMIC);
+}
+
+static int
+test_multi_port_flow_ordered_to_ordered(void)
+{
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_ORDERED,
+                               RTE_SCHED_TYPE_ORDERED);
+}
+
+static int
+test_multi_port_flow_ordered_to_parallel(void)
+{
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_ORDERED,
+                               RTE_SCHED_TYPE_PARALLEL);
+}
+
+static int
+test_multi_port_flow_atomic_to_atomic(void)
+{
+       /* Ingress event order test */
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_ATOMIC,
+                               RTE_SCHED_TYPE_ATOMIC);
+}
+
+static int
+test_multi_port_flow_atomic_to_ordered(void)
+{
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_ATOMIC,
+                               RTE_SCHED_TYPE_ORDERED);
+}
+
+static int
+test_multi_port_flow_atomic_to_parallel(void)
+{
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_ATOMIC,
+                               RTE_SCHED_TYPE_PARALLEL);
+}
+
+static int
+test_multi_port_flow_parallel_to_atomic(void)
+{
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_PARALLEL,
+                               RTE_SCHED_TYPE_ATOMIC);
+}
+
+static int
+test_multi_port_flow_parallel_to_ordered(void)
+{
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_PARALLEL,
+                               RTE_SCHED_TYPE_ORDERED);
+}
+
+static int
+test_multi_port_flow_parallel_to_parallel(void)
+{
+       return test_multiport_flow_sched_type_test(RTE_SCHED_TYPE_PARALLEL,
+                               RTE_SCHED_TYPE_PARALLEL);
+}
+
+static int
+worker_group_based_pipeline(void *arg)
+{
+       struct test_core_param *param = arg;
+       struct rte_event ev;
+       uint16_t valid_event;
+       uint8_t port = param->port;
+       uint8_t new_sched_type = param->sched_type;
+       rte_atomic32_t *total_events = param->total_events;
+       uint64_t dequeue_tmo_ticks = param->dequeue_tmo_ticks;
+
+       while (rte_atomic32_read(total_events) > 0) {
+               valid_event = rte_event_dequeue_burst(evdev, port, &ev, 1,
+                                       dequeue_tmo_ticks);
+               if (!valid_event)
+                       continue;
+
+               /* Events from stage 0(group 0) */
+               if (ev.queue_id == 0) {
+                       /* Move to atomic flow to maintain the ordering */
+                       ev.flow_id = 0x2;
+                       ev.event_type = RTE_EVENT_TYPE_CPU;
+                       ev.sched_type = new_sched_type;
+                       ev.queue_id = 1; /* Stage 1*/
+                       ev.op = RTE_EVENT_OP_FORWARD;
+                       rte_event_enqueue_burst(evdev, port, &ev, 1);
+               } else if (ev.queue_id == 1) { /* Events from stage 1(group 1)*/
+                       if (seqn_list_update(ev.mbuf->seqn) == TEST_SUCCESS) {
+                               rte_pktmbuf_free(ev.mbuf);
+                               rte_atomic32_sub(total_events, 1);
+                       } else {
+                               printf("Failed to update seqn_list\n");
+                               return TEST_FAILED;
+                       }
+               } else {
+                       printf("Invalid ev.queue_id = %d\n", ev.queue_id);
+                       return TEST_FAILED;
+               }
+       }
+
+
+       return 0;
+}
+
+static int
+test_multiport_queue_sched_type_test(uint8_t in_sched_type,
+                       uint8_t out_sched_type)
+{
+       const unsigned int total_events = MAX_EVENTS;
+       uint8_t nr_ports;
+       int ret;
+
+       nr_ports = RTE_MIN(rte_event_port_count(evdev), rte_lcore_count() - 1);
+
+       if (rte_event_queue_count(evdev) < 2 ||  !nr_ports) {
+               printf("%s: Not enough queues=%d ports=%d or workers=%d\n",
+                        __func__, rte_event_queue_count(evdev),
+                       rte_event_port_count(evdev), rte_lcore_count() - 1);
+               return TEST_SUCCESS;
+       }
+
+       /* Injects events with m->seqn=0 to total_events */
+       ret = inject_events(
+               0x1 /*flow_id */,
+               RTE_EVENT_TYPE_CPU /* event_type */,
+               0 /* sub_event_type (stage 0) */,
+               in_sched_type,
+               0 /* queue */,
+               0 /* port */,
+               total_events /* events */);
+       if (ret)
+               return TEST_FAILED;
+
+       ret = launch_workers_and_wait(worker_group_based_pipeline,
+                                       worker_group_based_pipeline,
+                                       total_events, nr_ports, out_sched_type);
+       if (ret)
+               return TEST_FAILED;
+
+       if (in_sched_type != RTE_SCHED_TYPE_PARALLEL &&
+                       out_sched_type == RTE_SCHED_TYPE_ATOMIC) {
+               /* Check the events order maintained or not */
+               return seqn_list_check(total_events);
+       }
+       return TEST_SUCCESS;
+}
+
+static int
+test_multi_port_queue_ordered_to_atomic(void)
+{
+       /* Ingress event order test */
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_ORDERED,
+                               RTE_SCHED_TYPE_ATOMIC);
+}
+
+static int
+test_multi_port_queue_ordered_to_ordered(void)
+{
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_ORDERED,
+                               RTE_SCHED_TYPE_ORDERED);
+}
+
+static int
+test_multi_port_queue_ordered_to_parallel(void)
+{
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_ORDERED,
+                               RTE_SCHED_TYPE_PARALLEL);
+}
+
+static int
+test_multi_port_queue_atomic_to_atomic(void)
+{
+       /* Ingress event order test */
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_ATOMIC,
+                               RTE_SCHED_TYPE_ATOMIC);
+}
+
+static int
+test_multi_port_queue_atomic_to_ordered(void)
+{
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_ATOMIC,
+                               RTE_SCHED_TYPE_ORDERED);
+}
+
+static int
+test_multi_port_queue_atomic_to_parallel(void)
+{
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_ATOMIC,
+                               RTE_SCHED_TYPE_PARALLEL);
+}
+
+static int
+test_multi_port_queue_parallel_to_atomic(void)
+{
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_PARALLEL,
+                               RTE_SCHED_TYPE_ATOMIC);
+}
+
+static int
+test_multi_port_queue_parallel_to_ordered(void)
+{
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_PARALLEL,
+                               RTE_SCHED_TYPE_ORDERED);
+}
+
+static int
+test_multi_port_queue_parallel_to_parallel(void)
+{
+       return test_multiport_queue_sched_type_test(RTE_SCHED_TYPE_PARALLEL,
+                               RTE_SCHED_TYPE_PARALLEL);
+}
+
+static int
+worker_flow_based_pipeline_max_stages_rand_sched_type(void *arg)
+{
+       struct test_core_param *param = arg;
+       struct rte_event ev;
+       uint16_t valid_event;
+       uint8_t port = param->port;
+       rte_atomic32_t *total_events = param->total_events;
+
+       while (rte_atomic32_read(total_events) > 0) {
+               valid_event = rte_event_dequeue_burst(evdev, port, &ev, 1, 0);
+               if (!valid_event)
+                       continue;
+
+               if (ev.sub_event_type == 255) { /* last stage */
+                       rte_pktmbuf_free(ev.mbuf);
+                       rte_atomic32_sub(total_events, 1);
+               } else {
+                       ev.event_type = RTE_EVENT_TYPE_CPU;
+                       ev.sub_event_type++;
+                       ev.sched_type =
+                               rte_rand() % (RTE_SCHED_TYPE_PARALLEL + 1);
+                       ev.op = RTE_EVENT_OP_FORWARD;
+                       rte_event_enqueue_burst(evdev, port, &ev, 1);
+               }
+       }
+       return 0;
+}
+
+static int
+launch_multi_port_max_stages_random_sched_type(int (*fn)(void *))
+{
+       uint8_t nr_ports;
+       int ret;
+
+       nr_ports = RTE_MIN(rte_event_port_count(evdev), rte_lcore_count() - 1);
+
+       if (!nr_ports) {
+               printf("%s: Not enough ports=%d or workers=%d\n", __func__,
+                       rte_event_port_count(evdev), rte_lcore_count() - 1);
+               return TEST_SUCCESS;
+       }
+
+       /* Injects events with m->seqn=0 to total_events */
+       ret = inject_events(
+               0x1 /*flow_id */,
+               RTE_EVENT_TYPE_CPU /* event_type */,
+               0 /* sub_event_type (stage 0) */,
+               rte_rand() % (RTE_SCHED_TYPE_PARALLEL + 1) /* sched_type */,
+               0 /* queue */,
+               0 /* port */,
+               MAX_EVENTS /* events */);
+       if (ret)
+               return TEST_FAILED;
+
+       return launch_workers_and_wait(fn, fn, MAX_EVENTS, nr_ports,
+                                        0xff /* invalid */);
+}
+
+/* Flow based pipeline with maximum stages with random sched type */
+static int
+test_multi_port_flow_max_stages_random_sched_type(void)
+{
+       return launch_multi_port_max_stages_random_sched_type(
+               worker_flow_based_pipeline_max_stages_rand_sched_type);
+}
+
+static int
+worker_queue_based_pipeline_max_stages_rand_sched_type(void *arg)
+{
+       struct test_core_param *param = arg;
+       struct rte_event ev;
+       uint16_t valid_event;
+       uint8_t port = param->port;
+       uint8_t nr_queues = rte_event_queue_count(evdev);
+       rte_atomic32_t *total_events = param->total_events;
+
+       while (rte_atomic32_read(total_events) > 0) {
+               valid_event = rte_event_dequeue_burst(evdev, port, &ev, 1, 0);
+               if (!valid_event)
+                       continue;
+
+               if (ev.queue_id == nr_queues - 1) { /* last stage */
+                       rte_pktmbuf_free(ev.mbuf);
+                       rte_atomic32_sub(total_events, 1);
+               } else {
+                       ev.event_type = RTE_EVENT_TYPE_CPU;
+                       ev.queue_id++;
+                       ev.sched_type =
+                               rte_rand() % (RTE_SCHED_TYPE_PARALLEL + 1);
+                       ev.op = RTE_EVENT_OP_FORWARD;
+                       rte_event_enqueue_burst(evdev, port, &ev, 1);
+               }
+       }
+       return 0;
+}
+
+/* Queue based pipeline with maximum stages with random sched type */
+static int
+test_multi_port_queue_max_stages_random_sched_type(void)
+{
+       return launch_multi_port_max_stages_random_sched_type(
+               worker_queue_based_pipeline_max_stages_rand_sched_type);
+}
+
+static int
+worker_mixed_pipeline_max_stages_rand_sched_type(void *arg)
+{
+       struct test_core_param *param = arg;
+       struct rte_event ev;
+       uint16_t valid_event;
+       uint8_t port = param->port;
+       uint8_t nr_queues = rte_event_queue_count(evdev);
+       rte_atomic32_t *total_events = param->total_events;
+
+       while (rte_atomic32_read(total_events) > 0) {
+               valid_event = rte_event_dequeue_burst(evdev, port, &ev, 1, 0);
+               if (!valid_event)
+                       continue;
+
+               if (ev.queue_id == nr_queues - 1) { /* Last stage */
+                       rte_pktmbuf_free(ev.mbuf);
+                       rte_atomic32_sub(total_events, 1);
+               } else {
+                       ev.event_type = RTE_EVENT_TYPE_CPU;
+                       ev.queue_id++;
+                       ev.sub_event_type = rte_rand() % 256;
+                       ev.sched_type =
+                               rte_rand() % (RTE_SCHED_TYPE_PARALLEL + 1);
+                       ev.op = RTE_EVENT_OP_FORWARD;
+                       rte_event_enqueue_burst(evdev, port, &ev, 1);
+               }
+       }
+       return 0;
+}
+
+/* Queue and flow based pipeline with maximum stages with random sched type */
+static int
+test_multi_port_mixed_max_stages_random_sched_type(void)
+{
+       return launch_multi_port_max_stages_random_sched_type(
+               worker_mixed_pipeline_max_stages_rand_sched_type);
+}
+
+static int
+worker_ordered_flow_producer(void *arg)
+{
+       struct test_core_param *param = arg;
+       uint8_t port = param->port;
+       struct rte_mbuf *m;
+       int counter = 0;
+
+       while (counter < NUM_PACKETS) {
+               m = rte_pktmbuf_alloc(eventdev_test_mempool);
+               if (m == NULL)
+                       continue;
+
+               m->seqn = counter++;
+
+               struct rte_event ev = {.event = 0, .u64 = 0};
+
+               ev.flow_id = 0x1; /* Generate a fat flow */
+               ev.sub_event_type = 0;
+               /* Inject the new event */
+               ev.op = RTE_EVENT_OP_NEW;
+               ev.event_type = RTE_EVENT_TYPE_CPU;
+               ev.sched_type = RTE_SCHED_TYPE_ORDERED;
+               ev.queue_id = 0;
+               ev.mbuf = m;
+               rte_event_enqueue_burst(evdev, port, &ev, 1);
+       }
+
+       return 0;
+}
+
+static inline int
+test_producer_consumer_ingress_order_test(int (*fn)(void *))
+{
+       uint8_t nr_ports;
+
+       nr_ports = RTE_MIN(rte_event_port_count(evdev), rte_lcore_count() - 1);
+
+       if (rte_lcore_count() < 3 || nr_ports < 2) {
+               printf("### Not enough cores for %s test.\n", __func__);
+               return TEST_SUCCESS;
+       }
+
+       launch_workers_and_wait(worker_ordered_flow_producer, fn,
+                               NUM_PACKETS, nr_ports, RTE_SCHED_TYPE_ATOMIC);
+       /* Check the events order maintained or not */
+       return seqn_list_check(NUM_PACKETS);
+}
+
+/* Flow based producer consumer ingress order test */
+static int
+test_flow_producer_consumer_ingress_order_test(void)
+{
+       return test_producer_consumer_ingress_order_test(
+                               worker_flow_based_pipeline);
+}
+
+/* Queue based producer consumer ingress order test */
+static int
+test_queue_producer_consumer_ingress_order_test(void)
+{
+       return test_producer_consumer_ingress_order_test(
+                               worker_group_based_pipeline);
+}
+
 static struct unit_test_suite eventdev_octeontx_testsuite  = {
        .suite_name = "eventdev octeontx unit test suite",
        .setup = testsuite_setup,
@@ -715,6 +1333,59 @@ static struct unit_test_suite eventdev_octeontx_testsuite  = {
                        test_multi_queue_enq_multi_port_deq),
                TEST_CASE_ST(eventdev_setup, eventdev_teardown,
                        test_queue_to_port_single_link),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_queue_to_port_multi_link),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_ordered_to_atomic),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_ordered_to_ordered),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_ordered_to_parallel),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_atomic_to_atomic),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_atomic_to_ordered),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_atomic_to_parallel),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_parallel_to_atomic),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_parallel_to_ordered),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_parallel_to_parallel),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_ordered_to_atomic),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_ordered_to_ordered),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_ordered_to_parallel),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_atomic_to_atomic),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_atomic_to_ordered),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_atomic_to_parallel),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_parallel_to_atomic),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_parallel_to_ordered),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_parallel_to_parallel),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_flow_max_stages_random_sched_type),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_queue_max_stages_random_sched_type),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_multi_port_mixed_max_stages_random_sched_type),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_flow_producer_consumer_ingress_order_test),
+               TEST_CASE_ST(eventdev_setup, eventdev_teardown,
+                       test_queue_producer_consumer_ingress_order_test),
+               /* Tests with dequeue timeout */
+               TEST_CASE_ST(eventdev_setup_dequeue_timeout, eventdev_teardown,
+                       test_multi_port_flow_ordered_to_atomic),
+               TEST_CASE_ST(eventdev_setup_dequeue_timeout, eventdev_teardown,
+                       test_multi_port_queue_ordered_to_atomic),
                TEST_CASES_END() /**< NULL terminate unit test array */
        }
 };