summaryrefslogtreecommitdiffstats
path: root/infra/data-impl/src/main/java/io
diff options
context:
space:
mode:
Diffstat (limited to 'infra/data-impl/src/main/java/io')
-rw-r--r--infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModifiableDataTreeDelegator.java6
-rw-r--r--infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModificationDiff.java296
2 files changed, 201 insertions, 101 deletions
diff --git a/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModifiableDataTreeDelegator.java b/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModifiableDataTreeDelegator.java
index 7f8b53919..213208064 100644
--- a/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModifiableDataTreeDelegator.java
+++ b/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModifiableDataTreeDelegator.java
@@ -46,6 +46,7 @@ import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTree;
import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeCandidate;
import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeCandidateNode;
+import org.opendaylight.yangtools.yang.model.api.SchemaContext;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
@@ -62,6 +63,7 @@ public final class ModifiableDataTreeDelegator extends ModifiableDataTreeManager
private final org.opendaylight.controller.md.sal.binding.api.DataBroker contextBroker;
// TODO HONEYCOMB-161 what to use instead of deprecated BindingNormalizedNodeSerializer ?
private final BindingNormalizedNodeSerializer serializer;
+ private final SchemaContext schema;
/**
* Creates configuration data tree instance.
@@ -73,12 +75,14 @@ public final class ModifiableDataTreeDelegator extends ModifiableDataTreeManager
*/
public ModifiableDataTreeDelegator(@Nonnull final BindingNormalizedNodeSerializer serializer,
@Nonnull final DataTree dataTree,
+ @Nonnull final SchemaContext schema,
@Nonnull final WriterRegistry writerRegistry,
@Nonnull final org.opendaylight.controller.md.sal.binding.api.DataBroker contextBroker) {
super(dataTree);
this.contextBroker = checkNotNull(contextBroker, "contextBroker should not be null");
this.serializer = checkNotNull(serializer, "serializer should not be null");
this.writerRegistry = checkNotNull(writerRegistry, "writerRegistry should not be null");
+ this.schema = checkNotNull(schema, "schema should not be null");
}
@Override
@@ -115,7 +119,7 @@ public final class ModifiableDataTreeDelegator extends ModifiableDataTreeManager
rootPath, rootNode, rootNode.getDataBefore(), rootNode.getDataAfter());
final ModificationDiff modificationDiff =
- ModificationDiff.recursivelyFromCandidateRoot(rootNode);
+ ModificationDiff.recursivelyFromCandidateRoot(rootNode, schema);
LOG.debug("ConfigDataTree.modify() diff: {}", modificationDiff);
// Distinguish between updates (create + update) and deletes
diff --git a/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModificationDiff.java b/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModificationDiff.java
index e78bb876b..723bb88ad 100644
--- a/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModificationDiff.java
+++ b/infra/data-impl/src/main/java/io/fd/honeycomb/data/impl/ModificationDiff.java
@@ -18,31 +18,50 @@ package io.fd.honeycomb.data.impl;
import static com.google.common.base.Preconditions.checkArgument;
import static com.google.common.base.Preconditions.checkNotNull;
+import static org.opendaylight.yangtools.yang.data.api.schema.tree.ModificationType.APPEARED;
+import static org.opendaylight.yangtools.yang.data.api.schema.tree.ModificationType.DELETE;
+import static org.opendaylight.yangtools.yang.data.api.schema.tree.ModificationType.DISAPPEARED;
+import static org.opendaylight.yangtools.yang.data.api.schema.tree.ModificationType.WRITE;
import com.google.common.collect.ImmutableMap;
import java.util.Collections;
import java.util.EnumSet;
import java.util.HashMap;
+import java.util.List;
import java.util.Map;
+import java.util.Optional;
+import java.util.stream.Collectors;
+import java.util.stream.Stream;
import javax.annotation.Nonnull;
import javax.annotation.Nullable;
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
-import org.opendaylight.yangtools.yang.data.api.schema.AugmentationNode;
-import org.opendaylight.yangtools.yang.data.api.schema.ChoiceNode;
-import org.opendaylight.yangtools.yang.data.api.schema.LeafNode;
import org.opendaylight.yangtools.yang.data.api.schema.MixinNode;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
import org.opendaylight.yangtools.yang.data.api.schema.tree.DataTreeCandidateNode;
import org.opendaylight.yangtools.yang.data.api.schema.tree.ModificationType;
+import org.opendaylight.yangtools.yang.model.api.AugmentationSchema;
+import org.opendaylight.yangtools.yang.model.api.AugmentationTarget;
+import org.opendaylight.yangtools.yang.model.api.ChoiceSchemaNode;
+import org.opendaylight.yangtools.yang.model.api.ContainerSchemaNode;
+import org.opendaylight.yangtools.yang.model.api.DataNodeContainer;
+import org.opendaylight.yangtools.yang.model.api.DataSchemaNode;
+import org.opendaylight.yangtools.yang.model.api.LeafSchemaNode;
+import org.opendaylight.yangtools.yang.model.api.ListSchemaNode;
+import org.opendaylight.yangtools.yang.model.api.SchemaContext;
+import org.opendaylight.yangtools.yang.model.api.SchemaNode;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
/**
* Recursively collects and provides all unique and non-null modifications (modified normalized nodes).
*/
final class ModificationDiff {
+ private static final Logger LOG = LoggerFactory.getLogger(ModificationDiff.class);
+
private static final ModificationDiff EMPTY_DIFF = new ModificationDiff(Collections.emptyMap());
- private static final EnumSet VALID_MODIFICATIONS = EnumSet.of(ModificationType.WRITE, ModificationType.DELETE);
- private static final EnumSet IGNORED_MODIFICATIONS = EnumSet.of(ModificationType.APPEARED, ModificationType.DISAPPEARED);
+ private static final EnumSet VALID_MODIFICATIONS = EnumSet.of(WRITE, DELETE);
+ private static final EnumSet IGNORED_MODIFICATIONS = EnumSet.of(APPEARED, DISAPPEARED);
private final Map<YangInstanceIdentifier, NormalizedNodeUpdate> updates;
@@ -71,16 +90,17 @@ final class ModificationDiff {
return new ModificationDiff(join(updates, other.updates));
}
- private static Map<YangInstanceIdentifier, NormalizedNodeUpdate> join(Map<YangInstanceIdentifier, NormalizedNodeUpdate> first,
- Map<YangInstanceIdentifier, NormalizedNodeUpdate> second) {
+ private static Map<YangInstanceIdentifier, NormalizedNodeUpdate> join(
+ Map<YangInstanceIdentifier, NormalizedNodeUpdate> first,
+ Map<YangInstanceIdentifier, NormalizedNodeUpdate> second) {
final Map<YangInstanceIdentifier, NormalizedNodeUpdate> merged = new HashMap<>();
merged.putAll(first);
merged.putAll(second);
return merged;
}
- private static ModificationDiff create(YangInstanceIdentifier id, DataTreeCandidateNode candidate) {
- return new ModificationDiff(ImmutableMap.of(id, NormalizedNodeUpdate.create(id, candidate)));
+ private static ModificationDiff create(Modification modification) {
+ return new ModificationDiff(ImmutableMap.of(modification.getId(), NormalizedNodeUpdate.create(modification)));
}
/**
@@ -88,140 +108,98 @@ final class ModificationDiff {
* are complex nodes which direct leaves were not modified.
*/
@Nonnull
- static ModificationDiff recursivelyFromCandidate(@Nonnull final YangInstanceIdentifier yangIid,
- @Nonnull final DataTreeCandidateNode currentCandidate) {
+ static ModificationDiff recursivelyFromCandidate(@Nonnull final Modification modification) {
// recursively process child nodes for exact modifications
- return recursivelyChildrenFromCandidate(yangIid, currentCandidate)
+ return recursivelyChildrenFromCandidate(modification)
// also add modification on current level, if elligible
- .merge(isModification(currentCandidate)
- ? ModificationDiff.create(yangIid, currentCandidate)
+ .merge(isModification(modification)
+ ? ModificationDiff.create(modification)
: EMPTY_DIFF);
}
/**
- * Same as {@link #recursivelyFromCandidate(YangInstanceIdentifier, DataTreeCandidateNode)} but does not process
- * the root node for modifications, since it's the artificial data root, that has no child leaves but always is
- * marked as SUBTREE_MODIFIED.
+ * Same as {@link #recursivelyFromCandidate(Modification)} but does
+ * not process the root node for modifications, since it's the artificial data root, that has no child leaves but
+ * always is marked as SUBTREE_MODIFIED.
*/
@Nonnull
- static ModificationDiff recursivelyFromCandidateRoot(@Nonnull final DataTreeCandidateNode currentCandidate) {
- return recursivelyChildrenFromCandidate(YangInstanceIdentifier.EMPTY, currentCandidate);
+ static ModificationDiff recursivelyFromCandidateRoot(@Nonnull final DataTreeCandidateNode currentCandidate,
+ @Nonnull final SchemaContext ctx) {
+ return recursivelyChildrenFromCandidate(new Modification(YangInstanceIdentifier.EMPTY, currentCandidate, ctx));
}
/**
* Check whether current node was modified. {@link MixinNode}s are ignored
* and only nodes which direct leaves(or choices) are modified are considered a modification.
*/
- private static Boolean isModification(@Nonnull final DataTreeCandidateNode currentCandidate) {
+ private static Boolean isModification(@Nonnull final Modification modification) {
// Disappear is not a modification
- if (IGNORED_MODIFICATIONS.contains(currentCandidate.getModificationType())) {
+ if (IGNORED_MODIFICATIONS.contains(modification.getModificationType())) {
return false;
// Mixin nodes are not considered modifications
- } else if (isMixin(currentCandidate) && !isAugment(currentCandidate)) {
+ } else if (modification.isMixin() && !modification.is(AugmentationSchema.class)) {
return false;
} else {
- return isCurrentModified(currentCandidate);
+ return isCurrentModified(modification);
}
}
- private static Boolean isCurrentModified(final @Nonnull DataTreeCandidateNode currentCandidate) {
+ private static Boolean isCurrentModified(@Nonnull final Modification modification) {
// First check if it's an empty presence node
- if (isEmptyPresenceNode(currentCandidate)) {
- return true;
- }
+ final boolean emptyPresenceNode = isEmptyPresenceNode(modification);
// Check if there are any modified leaves and if so, consider current node as modified
- final Boolean directLeavesModified = currentCandidate.getChildNodes().stream()
- .filter(ModificationDiff::isLeaf)
+ final Boolean directLeavesModified = emptyPresenceNode
+ || modification.streamChildren()
+ .filter(child -> child.is(LeafSchemaNode.class))
// For some reason, we get modifications on unmodified list keys
// and that messes up our modifications collection here, so we need to skip
- .filter(ModificationDiff::isBeforeAndAfterDifferent)
+ .filter(Modification::isBeforeAndAfterDifferent)
.filter(child -> VALID_MODIFICATIONS.contains(child.getModificationType()))
.findFirst()
.isPresent();
- return directLeavesModified
- // Also check choices (choices do not exist in BA world and if anything within a choice was modified,
- // consider its parent as being modified)
- || currentCandidate.getChildNodes().stream()
- .filter(ModificationDiff::isChoice)
- // Recursively check each choice if there was any change to it
- .filter(ModificationDiff::isCurrentModified)
- .findFirst()
- .isPresent();
+ // Also as fallback check choices (choices do not exist in BA world and if anything within a choice was modified,
+ // consider its parent as being modified)
+ final boolean modified = directLeavesModified
+ || modification.streamChildren()
+ .filter(child -> child.is(ChoiceSchemaNode.class))
+ // Recursively check each choice if there was any change to it
+ .filter(ModificationDiff::isCurrentModified)
+ .findFirst()
+ .isPresent();
+
+ if (modified) {
+ LOG.debug("Modification detected as {} at {}",
+ modification.getModificationType(), modification.getId());
+ }
+
+ return modified;
}
/**
* Check if new data are empty but still to be considered as a modification, meaning it's presence has a meaning
* e.g. containers with presence statement.
*/
- private static boolean isEmptyPresenceNode(final @Nonnull DataTreeCandidateNode currentCandidate) {
- return currentCandidate.getChildNodes().isEmpty()
- && VALID_MODIFICATIONS.contains(currentCandidate.getModificationType());
+ private static boolean isEmptyPresenceNode(@Nonnull final Modification modification) {
+ return modification.is(ContainerSchemaNode.class)
+ && ((ContainerSchemaNode) modification.getSchemaNode()).isPresenceContainer()
+ && modification.getChildNodes().isEmpty()
+ && VALID_MODIFICATIONS.contains(modification.getModificationType());
}
/**
* Process all non-leaf child nodes recursively, creating aggregated {@link ModificationDiff}.
*/
- private static ModificationDiff recursivelyChildrenFromCandidate(final @Nonnull YangInstanceIdentifier yangIid,
- final @Nonnull DataTreeCandidateNode currentCandidate) {
+ private static ModificationDiff recursivelyChildrenFromCandidate(@Nonnull final Modification modification) {
// recursively process child nodes for specific modifications
- return currentCandidate.getChildNodes().stream()
- // not interested in modifications to leaves
- .filter(child -> !isLeaf(child))
- .map(candidate -> recursivelyFromCandidate(yangIid.node(candidate.getIdentifier()), candidate))
+ return modification.streamChildren()
+ .filter(child -> !child.is(LeafSchemaNode.class))
+ .map(ModificationDiff::recursivelyFromCandidate)
.reduce(ModificationDiff::merge)
.orElse(EMPTY_DIFF);
}
- /**
- * Check whether candidate.before and candidate.after is different. If not return false.
- */
- private static boolean isBeforeAndAfterDifferent(@Nonnull final DataTreeCandidateNode candidateNode) {
- if (candidateNode.getDataBefore().isPresent()) {
- return !candidateNode.getDataBefore().get().equals(candidateNode.getDataAfter().orNull());
- }
-
- // considering not a modification if data after is also null
- return candidateNode.getDataAfter().isPresent();
- }
-
- /**
- * Check whether candidate node is for a leaf type node.
- */
- private static boolean isLeaf(final DataTreeCandidateNode candidateNode) {
- // orNull intentional, some candidate nodes have both data after and data before null
- return candidateNode.getDataAfter().orNull() instanceof LeafNode<?>
- || candidateNode.getDataBefore().orNull() instanceof LeafNode<?>;
- }
-
- /**
- * Check whether candidate node is for a Mixin type node.
- */
- private static boolean isMixin(final DataTreeCandidateNode candidateNode) {
- // orNull intentional, some candidate nodes have both data after and data before null
- return candidateNode.getDataAfter().orNull() instanceof MixinNode
- || candidateNode.getDataBefore().orNull() instanceof MixinNode;
- }
-
- /**
- * Check whether candidate node is for an Augmentation type node.
- */
- private static boolean isAugment(final DataTreeCandidateNode candidateNode) {
- // orNull intentional, some candidate nodes have both data after and data before null
- return candidateNode.getDataAfter().orNull() instanceof AugmentationNode
- || candidateNode.getDataBefore().orNull() instanceof AugmentationNode;
- }
-
- /**
- * Check whether candidate node is for a Choice type node.
- */
- private static boolean isChoice(final DataTreeCandidateNode candidateNode) {
- // orNull intentional, some candidate nodes have both data after and data before null
- return candidateNode.getDataAfter().orNull() instanceof ChoiceNode
- || candidateNode.getDataBefore().orNull() instanceof ChoiceNode;
- }
-
@Override
public String toString() {
return "ModificationDiff{updates=" + updates + '}';
@@ -262,15 +240,19 @@ final class ModificationDiff {
return id;
}
- static NormalizedNodeUpdate create(@Nonnull final YangInstanceIdentifier id,
- @Nonnull final DataTreeCandidateNode candidate) {
- return create(id, candidate.getDataBefore().orNull(), candidate.getDataAfter().orNull());
+ static NormalizedNodeUpdate create(@Nonnull final Modification modification) {
+ final com.google.common.base.Optional<NormalizedNode<?, ?>> beforeData =
+ modification.getDataBefore();
+ final com.google.common.base.Optional<NormalizedNode<?, ?>> afterData =
+ modification.getDataAfter();
+ checkArgument(beforeData.isPresent() || afterData.isPresent(),
+ "Both before and after data are null for $s", modification.getId());
+ return NormalizedNodeUpdate.create(modification.getId(), beforeData.orNull(), afterData.orNull());
}
static NormalizedNodeUpdate create(@Nonnull final YangInstanceIdentifier id,
@Nullable final NormalizedNode<?, ?> dataBefore,
@Nullable final NormalizedNode<?, ?> dataAfter) {
- checkArgument(!(dataBefore == null && dataAfter == null), "Both before and after data are null");
return new NormalizedNodeUpdate(id, dataBefore, dataAfter);
}
@@ -303,4 +285,118 @@ final class ModificationDiff {
}
}
+ /**
+ * Intermediate representation of a modification + its schema.
+ */
+ private static final class Modification {
+ private final YangInstanceIdentifier id;
+ private final DataTreeCandidateNode dataCandidate;
+ // Using Object as type for schema node since it's the only type that's a parent to all schema node types from
+ // yangtools. The hierarchy does not use e.g. SchemaNode class for all types
+ private final Object schemaNode;
+
+ Modification(final YangInstanceIdentifier id,
+ final DataTreeCandidateNode dataCandidate,
+ final Object schemaNode) {
+ this.id = id;
+ this.dataCandidate = dataCandidate;
+ this.schemaNode = schemaNode;
+ }
+
+ Stream<Modification> streamChildren() {
+ return dataCandidate.getChildNodes().stream()
+ .map(child -> new Modification(id.node(child.getIdentifier()), child, schemaChild(schemaNode, child.getIdentifier())));
+ }
+
+ List<Modification> getChildNodes() {
+ return streamChildren().collect(Collectors.toList());
+ }
+
+ YangInstanceIdentifier getId() {
+ return id;
+ }
+
+ ModificationType getModificationType() {
+ return dataCandidate.getModificationType();
+ }
+
+ com.google.common.base.Optional<NormalizedNode<?, ?>> getDataBefore() {
+ return dataCandidate.getDataBefore();
+ }
+
+ com.google.common.base.Optional<NormalizedNode<?, ?>> getDataAfter() {
+ return dataCandidate.getDataAfter();
+ }
+
+ Object getSchemaNode() {
+ return schemaNode;
+ }
+
+ boolean is(final Class<?> schemaType) {
+ return schemaType.isAssignableFrom(schemaNode.getClass());
+ }
+
+ boolean isMixin() {
+ // Checking whether node is a mixin is not performed on schema, but on data since mixin is
+ // only a NormalizedNode concept, not a schema concept
+ return dataCandidate.getDataBefore().orNull() instanceof MixinNode ||
+ dataCandidate.getDataAfter().orNull() instanceof MixinNode;
+ }
+
+ private boolean isBeforeAndAfterDifferent() {
+ if (dataCandidate.getDataBefore().isPresent()) {
+ return !dataCandidate.getDataBefore().get().equals(dataCandidate.getDataAfter().orNull());
+ }
+
+ // considering not a modification if data after is also null
+ return dataCandidate.getDataAfter().isPresent();
+ }
+
+ /**
+ * Find next schema node in hierarchy.
+ */
+ private Object schemaChild(final Object schema, final YangInstanceIdentifier.PathArgument identifier) {
+ Object found = null;
+
+ if (identifier instanceof YangInstanceIdentifier.AugmentationIdentifier) {
+ if (schema instanceof AugmentationTarget) {
+ // Find matching augmentation
+ found = ((AugmentationTarget) schema).getAvailableAugmentations().stream()
+ .filter(aug -> identifier.equals(new YangInstanceIdentifier.AugmentationIdentifier(
+ aug.getChildNodes().stream()
+ .map(SchemaNode::getQName)
+ .collect(Collectors.toSet()))))
+ .findFirst()
+ .orElse(null);
+ }
+ } else if (schema instanceof DataNodeContainer) {
+ // Special handling for list aggregator nodes. If we are at list aggregator node e.g. MapNode and
+ // we are searching for schema for a list entry e.g. MapEntryNode just return the same schema
+ if (schema instanceof ListSchemaNode &&
+ ((SchemaNode) schema).getQName().equals(identifier.getNodeType())) {
+ found = schema;
+ } else {
+ found = ((DataNodeContainer) schema).getDataChildByName(identifier.getNodeType());
+ }
+ } else if (schema instanceof ChoiceSchemaNode) {
+ // For choices, iterate through all the cases
+ final Optional<DataSchemaNode> maybeChild = ((ChoiceSchemaNode) schema).getCases().stream()
+ .flatMap(cas -> cas.getChildNodes().stream())
+ .filter(child -> child.getQName().equals(identifier.getNodeType()))
+ .findFirst();
+ if (maybeChild.isPresent()) {
+ found = maybeChild.get();
+ }
+ }
+
+ return checkNotNull(found, "Unable to find child node in: %s identifiable by: %s", schema, identifier);
+ }
+
+ @Override
+ public String toString() {
+ return "Modification{" +
+ "id=" + id +
+ '}';
+ }
+ }
}
background-color: #fff0f0 } /* Literal.String.Doc */ .highlight .s2 { color: #dd2200; background-color: #fff0f0 } /* Literal.String.Double */ .highlight .se { color: #0044dd; background-color: #fff0f0 } /* Literal.String.Escape */ .highlight .sh { color: #dd2200; background-color: #fff0f0 } /* Literal.String.Heredoc */ .highlight .si { color: #3333bb; background-color: #fff0f0 } /* Literal.String.Interpol */ .highlight .sx { color: #22bb22; background-color: #f0fff0 } /* Literal.String.Other */ .highlight .sr { color: #008800; background-color: #fff0ff } /* Literal.String.Regex */ .highlight .s1 { color: #dd2200; background-color: #fff0f0 } /* Literal.String.Single */ .highlight .ss { color: #aa6600; background-color: #fff0f0 } /* Literal.String.Symbol */ .highlight .bp { color: #003388 } /* Name.Builtin.Pseudo */ .highlight .fm { color: #0066bb; font-weight: bold } /* Name.Function.Magic */ .highlight .vc { color: #336699 } /* Name.Variable.Class */ .highlight .vg { color: #dd7700 } /* Name.Variable.Global */ .highlight .vi { color: #3333bb } /* Name.Variable.Instance */ .highlight .vm { color: #336699 } /* Name.Variable.Magic */ .highlight .il { color: #0000DD; font-weight: bold } /* Literal.Number.Integer.Long */ }
/*-
 *   BSD LICENSE
 *
 *   Copyright(c) 2010-2016 Intel Corporation. All rights reserved.
 *   All rights reserved.
 *
 *   Redistribution and use in source and binary forms, with or without
 *   modification, are permitted provided that the following conditions
 *   are met:
 *
 *     * Redistributions of source code must retain the above copyright
 *       notice, this list of conditions and the following disclaimer.
 *     * Redistributions in binary form must reproduce the above copyright
 *       notice, this list of conditions and the following disclaimer in
 *       the documentation and/or other materials provided with the
 *       distribution.
 *     * Neither the name of Intel Corporation nor the names of its
 *       contributors may be used to endorse or promote products derived
 *       from this software without specific prior written permission.
 *
 *   THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS
 *   "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT
 *   LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR
 *   A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT
 *   OWNER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
 *   SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
 *   LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE,
 *   DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY
 *   THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT
 *   (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
 *   OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 */

#ifndef __INCLUDE_APP_H__
#define __INCLUDE_APP_H__

#include <stdint.h>
#include <string.h>

#include <rte_common.h>
#include <rte_mempool.h>
#include <rte_ring.h>
#include <rte_sched.h>
#include <cmdline_parse.h>

#include <rte_ethdev.h>

#include "cpu_core_map.h"
#include "pipeline.h"

#define APP_PARAM_NAME_SIZE                      PIPELINE_NAME_SIZE
#define APP_LINK_PCI_BDF_SIZE                    16
struct app_mempool_params {
	char *name;
	uint32_t parsed;
	uint32_t buffer_size;
	uint32_t pool_size;
	uint32_t cache_size;
	uint32_t cpu_socket_id;
};

struct app_link_params {
	char *name;
	uint32_t parsed;
	uint32_t pmd_id; /* Generated based on port mask */
	uint32_t arp_q; /* 0 = Disabled (packets go to default queue 0) */
	uint32_t tcp_syn_q; /* 0 = Disabled (pkts go to default queue) */
	uint32_t ip_local_q; /* 0 = Disabled (pkts go to default queue 0) */
	uint32_t tcp_local_q; /* 0 = Disabled (pkts go to default queue 0) */
	uint32_t udp_local_q; /* 0 = Disabled (pkts go to default queue 0) */
	uint32_t sctp_local_q; /* 0 = Disabled (pkts go to default queue 0) */
	uint32_t state; /* DOWN = 0, UP = 1 */
	uint32_t ip; /* 0 = Invalid */
	uint32_t depth; /* Valid only when IP is valid */
	uint64_t mac_addr; /* Read from HW */
	char pci_bdf[APP_LINK_PCI_BDF_SIZE];

	struct rte_eth_conf conf;
	uint8_t promisc;
};

struct app_pktq_hwq_in_params {
	char *name;
	uint32_t parsed;
	uint32_t mempool_id; /* Position in the app->mempool_params */
	uint32_t size;
	uint32_t burst;

	struct rte_eth_rxconf conf;
};

struct app_pktq_hwq_out_params {
	char *name;
	uint32_t parsed;
	uint32_t size;
	uint32_t burst;
	uint32_t dropless;
	uint64_t n_retries;
	struct rte_eth_txconf conf;
};

struct app_pktq_swq_params {
	char *name;
	uint32_t parsed;
	uint32_t size;
	uint32_t burst_read;
	uint32_t burst_write;
	uint32_t dropless;
	uint64_t n_retries;
	uint32_t cpu_socket_id;
	uint32_t ipv4_frag;
	uint32_t ipv6_frag;
	uint32_t ipv4_ras;
	uint32_t ipv6_ras;
	uint32_t mtu;
	uint32_t metadata_size;
	uint32_t mempool_direct_id;
	uint32_t mempool_indirect_id;
};

#ifndef APP_FILE_NAME_SIZE
#define APP_FILE_NAME_SIZE                       256
#endif

#ifndef APP_MAX_SCHED_SUBPORTS
#define APP_MAX_SCHED_SUBPORTS                   8
#endif

#ifndef APP_MAX_SCHED_PIPES
#define APP_MAX_SCHED_PIPES                      4096
#endif

struct app_pktq_tm_params {
	char *name;
	uint32_t parsed;
	const char *file_name;
	struct rte_sched_port_params sched_port_params;
	struct rte_sched_subport_params
		sched_subport_params[APP_MAX_SCHED_SUBPORTS];
	struct rte_sched_pipe_params
		sched_pipe_profiles[RTE_SCHED_PIPE_PROFILES_PER_PORT];
	int sched_pipe_to_profile[APP_MAX_SCHED_SUBPORTS * APP_MAX_SCHED_PIPES];
	uint32_t burst_read;
	uint32_t burst_write;
};

struct app_pktq_source_params {
	char *name;
	uint32_t parsed;
	uint32_t mempool_id; /* Position in the app->mempool_params array */
	uint32_t burst;
	char *file_name; /* Full path of PCAP file to be copied to mbufs */
	uint32_t n_bytes_per_pkt;
};

struct app_pktq_sink_params {
	char *name;
	uint8_t parsed;
	char *file_name; /* Full path of PCAP file to be copied to mbufs */
	uint32_t n_pkts_to_dump;
};

struct app_msgq_params {
	char *name;
	uint32_t parsed;
	uint32_t size;
	uint32_t cpu_socket_id;
};

enum app_pktq_in_type {
	APP_PKTQ_IN_HWQ,
	APP_PKTQ_IN_SWQ,
	APP_PKTQ_IN_TM,
	APP_PKTQ_IN_SOURCE,
};

struct app_pktq_in_params {
	enum app_pktq_in_type type;
	uint32_t id; /* Position in the appropriate app array */
};

enum app_pktq_out_type {
	APP_PKTQ_OUT_HWQ,
	APP_PKTQ_OUT_SWQ,
	APP_PKTQ_OUT_TM,
	APP_PKTQ_OUT_SINK,
};

struct app_pktq_out_params {
	enum app_pktq_out_type type;
	uint32_t id; /* Position in the appropriate app array */
};

#ifndef APP_PIPELINE_TYPE_SIZE
#define APP_PIPELINE_TYPE_SIZE                   64
#endif

#define APP_MAX_PIPELINE_PKTQ_IN                 PIPELINE_MAX_PORT_IN
#define APP_MAX_PIPELINE_PKTQ_OUT                PIPELINE_MAX_PORT_OUT
#define APP_MAX_PIPELINE_MSGQ_IN                 PIPELINE_MAX_MSGQ_IN
#define APP_MAX_PIPELINE_MSGQ_OUT                PIPELINE_MAX_MSGQ_OUT

#define APP_MAX_PIPELINE_ARGS                    PIPELINE_MAX_ARGS

struct app_pipeline_params {
	char *name;
	uint8_t parsed;

	char type[APP_PIPELINE_TYPE_SIZE];

	uint32_t socket_id;
	uint32_t core_id;
	uint32_t hyper_th_id;

	struct app_pktq_in_params pktq_in[APP_MAX_PIPELINE_PKTQ_IN];
	struct app_pktq_out_params pktq_out[APP_MAX_PIPELINE_PKTQ_OUT];
	uint32_t msgq_in[APP_MAX_PIPELINE_MSGQ_IN];
	uint32_t msgq_out[APP_MAX_PIPELINE_MSGQ_OUT];

	uint32_t n_pktq_in;
	uint32_t n_pktq_out;
	uint32_t n_msgq_in;
	uint32_t n_msgq_out;

	uint32_t timer_period;

	char *args_name[APP_MAX_PIPELINE_ARGS];
	char *args_value[APP_MAX_PIPELINE_ARGS];
	uint32_t n_args;
};

struct app_pipeline_data {
	void *be;
	void *fe;
	struct pipeline_type *ptype;
	uint64_t timer_period;
	uint32_t enabled;
};

struct app_thread_pipeline_data {
	uint32_t pipeline_id;
	void *be;
	pipeline_be_op_run f_run;
	pipeline_be_op_timer f_timer;
	uint64_t timer_period;
	uint64_t deadline;
};

#ifndef APP_MAX_THREAD_PIPELINES
#define APP_MAX_THREAD_PIPELINES                 16
#endif

#ifndef APP_THREAD_TIMER_PERIOD
#define APP_THREAD_TIMER_PERIOD                  1
#endif

struct app_thread_data {
	struct app_thread_pipeline_data regular[APP_MAX_THREAD_PIPELINES];
	struct app_thread_pipeline_data custom[APP_MAX_THREAD_PIPELINES];

	uint32_t n_regular;
	uint32_t n_custom;

	uint64_t timer_period;
	uint64_t thread_req_deadline;

	uint64_t deadline;

	struct rte_ring *msgq_in;
	struct rte_ring *msgq_out;

	uint64_t headroom_time;
	uint64_t headroom_cycles;
	double headroom_ratio;
};

#ifndef APP_MAX_LINKS
#define APP_MAX_LINKS                            16
#endif

struct app_eal_params {
	/* Map lcore set to physical cpu set */
	char *coremap;

	/* Core ID that is used as master */
	uint32_t master_lcore_present;
	uint32_t master_lcore;

	/* Number of memory channels */
	uint32_t channels_present;
	uint32_t channels;

	/* Memory to allocate (see also --socket-mem) */
	uint32_t memory_present;
	uint32_t memory;

	/* Force number of memory ranks (don't detect) */
	uint32_t ranks_present;
	uint32_t ranks;

	/* Add a PCI device in black list. */
	char *pci_blacklist[APP_MAX_LINKS];

	/* Add a PCI device in white list. */
	char *pci_whitelist[APP_MAX_LINKS];

	/* Add a virtual device. */
	char *vdev[APP_MAX_LINKS];

	 /* Use VMware TSC map instead of native RDTSC */
	uint32_t vmware_tsc_map_present;
	int vmware_tsc_map;

	 /* Type of this process (primary|secondary|auto) */
	char *proc_type;

	 /* Set syslog facility */
	char *syslog;

	/* Set default log level */
	uint32_t log_level_present;
	uint32_t log_level;

	/* Display version information on startup */
	uint32_t version_present;
	int version;

	/* This help */
	uint32_t help_present;
	int help;

	 /* Use malloc instead of hugetlbfs */
	uint32_t no_huge_present;
	int no_huge;

	/* Disable PCI */
	uint32_t no_pci_present;
	int no_pci;

	/* Disable HPET */
	uint32_t no_hpet_present;
	int no_hpet;

	/* No shared config (mmap'd files) */
	uint32_t no_shconf_present;
	int no_shconf;

	/* Add driver */
	char *add_driver;

	/*  Memory to allocate on sockets (comma separated values)*/
	char *socket_mem;

	/* Directory where hugetlbfs is mounted */
	char *huge_dir;

	/* Prefix for hugepage filenames */
	char *file_prefix;

	/* Base virtual address */
	char *base_virtaddr;

	/* Create /dev/uioX (usually done by hotplug) */
	uint32_t create_uio_dev_present;
	int create_uio_dev;

	/* Interrupt mode for VFIO (legacy|msi|msix) */
	char *vfio_intr;

	/* Support running on Xen dom0 without hugetlbfs */
	uint32_t xen_dom0_present;
	int xen_dom0;
};

#ifndef APP_APPNAME_SIZE
#define APP_APPNAME_SIZE                         256
#endif

#ifndef APP_MAX_MEMPOOLS
#define APP_MAX_MEMPOOLS                         8
#endif

#ifndef APP_LINK_MAX_HWQ_IN
#define APP_LINK_MAX_HWQ_IN                      64
#endif

#ifndef APP_LINK_MAX_HWQ_OUT
#define APP_LINK_MAX_HWQ_OUT                     64
#endif

#define APP_MAX_HWQ_IN                     (APP_MAX_LINKS * APP_LINK_MAX_HWQ_IN)

#define APP_MAX_HWQ_OUT                   (APP_MAX_LINKS * APP_LINK_MAX_HWQ_OUT)

#ifndef APP_MAX_PKTQ_SWQ
#define APP_MAX_PKTQ_SWQ                         256
#endif

#define APP_MAX_PKTQ_TM                          APP_MAX_LINKS

#ifndef APP_MAX_PKTQ_SOURCE
#define APP_MAX_PKTQ_SOURCE                      16
#endif

#ifndef APP_MAX_PKTQ_SINK
#define APP_MAX_PKTQ_SINK                        16
#endif

#ifndef APP_MAX_MSGQ
#define APP_MAX_MSGQ                             64
#endif

#ifndef APP_MAX_PIPELINES
#define APP_MAX_PIPELINES                        64
#endif

#ifndef APP_EAL_ARGC
#define APP_EAL_ARGC                             32
#endif

#ifndef APP_MAX_PIPELINE_TYPES
#define APP_MAX_PIPELINE_TYPES                   64
#endif

#ifndef APP_MAX_THREADS
#define APP_MAX_THREADS                          RTE_MAX_LCORE
#endif

#ifndef APP_MAX_CMDS
#define APP_MAX_CMDS                             64
#endif

#ifndef APP_THREAD_HEADROOM_STATS_COLLECT
#define APP_THREAD_HEADROOM_STATS_COLLECT        1
#endif

struct app_params {
	/* Config */
	char app_name[APP_APPNAME_SIZE];
	const char *config_file;
	const char *script_file;
	const char *parser_file;
	const char *output_file;
	const char *preproc;
	const char *preproc_args;
	uint64_t port_mask;
	uint32_t log_level;

	struct app_eal_params eal_params;
	struct app_mempool_params mempool_params[APP_MAX_MEMPOOLS];
	struct app_link_params link_params[APP_MAX_LINKS];
	struct app_pktq_hwq_in_params hwq_in_params[APP_MAX_HWQ_IN];
	struct app_pktq_hwq_out_params hwq_out_params[APP_MAX_HWQ_OUT];
	struct app_pktq_swq_params swq_params[APP_MAX_PKTQ_SWQ];
	struct app_pktq_tm_params tm_params[APP_MAX_PKTQ_TM];
	struct app_pktq_source_params source_params[APP_MAX_PKTQ_SOURCE];
	struct app_pktq_sink_params sink_params[APP_MAX_PKTQ_SINK];
	struct app_msgq_params msgq_params[APP_MAX_MSGQ];
	struct app_pipeline_params pipeline_params[APP_MAX_PIPELINES];

	uint32_t n_mempools;
	uint32_t n_links;
	uint32_t n_pktq_hwq_in;
	uint32_t n_pktq_hwq_out;
	uint32_t n_pktq_swq;
	uint32_t n_pktq_tm;
	uint32_t n_pktq_source;
	uint32_t n_pktq_sink;
	uint32_t n_msgq;
	uint32_t n_pipelines;

	/* Init */
	char *eal_argv[1 + APP_EAL_ARGC];
	struct cpu_core_map *core_map;
	uint64_t core_mask;
	struct rte_mempool *mempool[APP_MAX_MEMPOOLS];
	struct rte_ring *swq[APP_MAX_PKTQ_SWQ];
	struct rte_sched_port *tm[APP_MAX_PKTQ_TM];
	struct rte_ring *msgq[APP_MAX_MSGQ];
	struct pipeline_type pipeline_type[APP_MAX_PIPELINE_TYPES];
	struct app_pipeline_data pipeline_data[APP_MAX_PIPELINES];
	struct app_thread_data thread_data[APP_MAX_THREADS];
	cmdline_parse_ctx_t cmds[APP_MAX_CMDS + 1];

	int eal_argc;
	uint32_t n_pipeline_types;
	uint32_t n_cmds;
};

#define APP_PARAM_VALID(obj) ((obj)->name != NULL)

#define APP_PARAM_COUNT(obj_array, n_objs)				\
{									\
	size_t i;							\
									\
	n_objs = 0;							\
	for (i = 0; i < RTE_DIM(obj_array); i++)			\
		if (APP_PARAM_VALID(&((obj_array)[i])))			\
			n_objs++;					\
}

#define APP_PARAM_FIND(obj_array, key)					\
({									\
	ssize_t obj_idx;						\
	const ssize_t obj_count = RTE_DIM(obj_array);			\
									\
	for (obj_idx = 0; obj_idx < obj_count; obj_idx++) {		\
		if (!APP_PARAM_VALID(&((obj_array)[obj_idx])))		\
			continue;					\
									\
		if (strcmp(key, (obj_array)[obj_idx].name) == 0)	\
			break;						\
	}								\
	obj_idx < obj_count ? obj_idx : -ENOENT;			\
})

#define APP_PARAM_FIND_BY_ID(obj_array, prefix, id, obj)		\
do {									\
	char name[APP_PARAM_NAME_SIZE];					\
	ssize_t pos;							\
									\
	sprintf(name, prefix "%" PRIu32, id);				\
	pos = APP_PARAM_FIND(obj_array, name);				\
	obj = (pos < 0) ? NULL : &((obj_array)[pos]);			\
} while (0)

#define APP_PARAM_GET_ID(obj, prefix, id)				\
do									\
	sscanf(obj->name, prefix "%" SCNu32, &id);				\
while (0)								\

#define APP_PARAM_ADD(obj_array, obj_name)				\
({									\
	ssize_t obj_idx;						\
	const ssize_t obj_count = RTE_DIM(obj_array);			\
									\
	obj_idx = APP_PARAM_FIND(obj_array, obj_name);			\
	if (obj_idx < 0) {						\
		for (obj_idx = 0; obj_idx < obj_count; obj_idx++) {	\
			if (!APP_PARAM_VALID(&((obj_array)[obj_idx])))	\
				break;					\
		}							\
									\
		if (obj_idx < obj_count) {				\
			(obj_array)[obj_idx].name = strdup(obj_name);   \
			if ((obj_array)[obj_idx].name == NULL)          \
				obj_idx = -EINVAL;			\
		} else							\
			obj_idx = -ENOMEM;				\
	}								\
	obj_idx;							\
})

#define	APP_CHECK(exp, fmt, ...)					\
do {									\
	if (!(exp)) {							\
		fprintf(stderr, fmt "\n", ## __VA_ARGS__);		\
		abort();						\
	}								\
} while (0)

enum app_log_level {
	APP_LOG_LEVEL_HIGH = 1,
	APP_LOG_LEVEL_LOW,
	APP_LOG_LEVELS
};

#define APP_LOG(app, level, fmt, ...)					\
do {									\
	if (app->log_level >= APP_LOG_LEVEL_ ## level)			\
		fprintf(stdout, "[APP] " fmt "\n", ## __VA_ARGS__);	\
} while (0)

static inline uint32_t
app_link_get_n_rxq(struct app_params *app, struct app_link_params *link)
{
	uint32_t n_rxq = 0, link_id, i;
	uint32_t n_pktq_hwq_in = RTE_MIN(app->n_pktq_hwq_in,
		RTE_DIM(app->hwq_in_params));

	APP_PARAM_GET_ID(link, "LINK", link_id);

	for (i = 0; i < n_pktq_hwq_in; i++) {
		struct app_pktq_hwq_in_params *p = &app->hwq_in_params[i];
		uint32_t rxq_link_id, rxq_queue_id;

		sscanf(p->name, "RXQ%" SCNu32 ".%" SCNu32,
			&rxq_link_id, &rxq_queue_id);
		if (rxq_link_id == link_id)
			n_rxq++;
	}

	return n_rxq;
}

static inline uint32_t
app_link_get_n_txq(struct app_params *app, struct app_link_params *link)
{
	uint32_t n_txq = 0, link_id, i;
	uint32_t n_pktq_hwq_out = RTE_MIN(app->n_pktq_hwq_out,
		RTE_DIM(app->hwq_out_params));

	APP_PARAM_GET_ID(link, "LINK", link_id);

	for (i = 0; i < n_pktq_hwq_out; i++) {
		struct app_pktq_hwq_out_params *p = &app->hwq_out_params[i];
		uint32_t txq_link_id, txq_queue_id;

		sscanf(p->name, "TXQ%" SCNu32 ".%" SCNu32,
			&txq_link_id, &txq_queue_id);
		if (txq_link_id == link_id)
			n_txq++;
	}

	return n_txq;
}

static inline uint32_t
app_rxq_get_readers(struct app_params *app, struct app_pktq_hwq_in_params *rxq)
{
	uint32_t pos = rxq - app->hwq_in_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_readers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_in = RTE_MIN(p->n_pktq_in, RTE_DIM(p->pktq_in));
		uint32_t j;

		for (j = 0; j < n_pktq_in; j++) {
			struct app_pktq_in_params *pktq = &p->pktq_in[j];

			if ((pktq->type == APP_PKTQ_IN_HWQ) &&
				(pktq->id == pos))
				n_readers++;
		}
	}

	return n_readers;
}

static inline uint32_t
app_swq_get_readers(struct app_params *app, struct app_pktq_swq_params *swq)
{
	uint32_t pos = swq - app->swq_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_readers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_in = RTE_MIN(p->n_pktq_in, RTE_DIM(p->pktq_in));
		uint32_t j;

		for (j = 0; j < n_pktq_in; j++) {
			struct app_pktq_in_params *pktq = &p->pktq_in[j];

			if ((pktq->type == APP_PKTQ_IN_SWQ) &&
				(pktq->id == pos))
				n_readers++;
		}
	}

	return n_readers;
}

static inline uint32_t
app_tm_get_readers(struct app_params *app, struct app_pktq_tm_params *tm)
{
	uint32_t pos = tm - app->tm_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_readers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_in = RTE_MIN(p->n_pktq_in, RTE_DIM(p->pktq_in));
		uint32_t j;

		for (j = 0; j < n_pktq_in; j++) {
			struct app_pktq_in_params *pktq = &p->pktq_in[j];

			if ((pktq->type == APP_PKTQ_IN_TM) &&
				(pktq->id == pos))
				n_readers++;
		}
	}

	return n_readers;
}

static inline uint32_t
app_source_get_readers(struct app_params *app,
struct app_pktq_source_params *source)
{
	uint32_t pos = source - app->source_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_readers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_in = RTE_MIN(p->n_pktq_in, RTE_DIM(p->pktq_in));
		uint32_t j;

		for (j = 0; j < n_pktq_in; j++) {
			struct app_pktq_in_params *pktq = &p->pktq_in[j];

			if ((pktq->type == APP_PKTQ_IN_SOURCE) &&
				(pktq->id == pos))
				n_readers++;
		}
	}

	return n_readers;
}

static inline uint32_t
app_msgq_get_readers(struct app_params *app, struct app_msgq_params *msgq)
{
	uint32_t pos = msgq - app->msgq_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_readers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_msgq_in = RTE_MIN(p->n_msgq_in, RTE_DIM(p->msgq_in));
		uint32_t j;

		for (j = 0; j < n_msgq_in; j++)
			if (p->msgq_in[j] == pos)
				n_readers++;
	}

	return n_readers;
}

static inline uint32_t
app_txq_get_writers(struct app_params *app, struct app_pktq_hwq_out_params *txq)
{
	uint32_t pos = txq - app->hwq_out_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_writers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_out = RTE_MIN(p->n_pktq_out,
			RTE_DIM(p->pktq_out));
		uint32_t j;

		for (j = 0; j < n_pktq_out; j++) {
			struct app_pktq_out_params *pktq = &p->pktq_out[j];

			if ((pktq->type == APP_PKTQ_OUT_HWQ) &&
				(pktq->id == pos))
				n_writers++;
		}
	}

	return n_writers;
}

static inline uint32_t
app_swq_get_writers(struct app_params *app, struct app_pktq_swq_params *swq)
{
	uint32_t pos = swq - app->swq_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_writers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_out = RTE_MIN(p->n_pktq_out,
			RTE_DIM(p->pktq_out));
		uint32_t j;

		for (j = 0; j < n_pktq_out; j++) {
			struct app_pktq_out_params *pktq = &p->pktq_out[j];

			if ((pktq->type == APP_PKTQ_OUT_SWQ) &&
				(pktq->id == pos))
				n_writers++;
		}
	}

	return n_writers;
}

static inline uint32_t
app_tm_get_writers(struct app_params *app, struct app_pktq_tm_params *tm)
{
	uint32_t pos = tm - app->tm_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_writers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_out = RTE_MIN(p->n_pktq_out,
			RTE_DIM(p->pktq_out));
		uint32_t j;

		for (j = 0; j < n_pktq_out; j++) {
			struct app_pktq_out_params *pktq = &p->pktq_out[j];

			if ((pktq->type == APP_PKTQ_OUT_TM) &&
				(pktq->id == pos))
				n_writers++;
		}
	}

	return n_writers;
}

static inline uint32_t
app_sink_get_writers(struct app_params *app, struct app_pktq_sink_params *sink)
{
	uint32_t pos = sink - app->sink_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_writers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_pktq_out = RTE_MIN(p->n_pktq_out,
			RTE_DIM(p->pktq_out));
		uint32_t j;

		for (j = 0; j < n_pktq_out; j++) {
			struct app_pktq_out_params *pktq = &p->pktq_out[j];

			if ((pktq->type == APP_PKTQ_OUT_SINK) &&
				(pktq->id == pos))
				n_writers++;
		}
	}

	return n_writers;
}

static inline uint32_t
app_msgq_get_writers(struct app_params *app, struct app_msgq_params *msgq)
{
	uint32_t pos = msgq - app->msgq_params;
	uint32_t n_pipelines = RTE_MIN(app->n_pipelines,
		RTE_DIM(app->pipeline_params));
	uint32_t n_writers = 0, i;

	for (i = 0; i < n_pipelines; i++) {
		struct app_pipeline_params *p = &app->pipeline_params[i];
		uint32_t n_msgq_out = RTE_MIN(p->n_msgq_out,
			RTE_DIM(p->msgq_out));
		uint32_t j;

		for (j = 0; j < n_msgq_out; j++)
			if (p->msgq_out[j] == pos)
				n_writers++;
	}

	return n_writers;
}

static inline struct app_link_params *
app_get_link_for_rxq(struct app_params *app, struct app_pktq_hwq_in_params *p)
{
	char link_name[APP_PARAM_NAME_SIZE];
	ssize_t link_param_idx;
	uint32_t rxq_link_id, rxq_queue_id;

	sscanf(p->name, "RXQ%" SCNu32 ".%" SCNu32,
		&rxq_link_id, &rxq_queue_id);
	sprintf(link_name, "LINK%" PRIu32, rxq_link_id);
	link_param_idx = APP_PARAM_FIND(app->link_params, link_name);
	APP_CHECK((link_param_idx >= 0),
		"Cannot find %s for %s", link_name, p->name);

	return &app->link_params[link_param_idx];
}

static inline struct app_link_params *
app_get_link_for_txq(struct app_params *app, struct app_pktq_hwq_out_params *p)
{
	char link_name[APP_PARAM_NAME_SIZE];
	ssize_t link_param_idx;
	uint32_t txq_link_id, txq_queue_id;

	sscanf(p->name, "TXQ%" SCNu32 ".%" SCNu32,
		&txq_link_id, &txq_queue_id);
	sprintf(link_name, "LINK%" PRIu32, txq_link_id);
	link_param_idx = APP_PARAM_FIND(app->link_params, link_name);
	APP_CHECK((link_param_idx >= 0),
		"Cannot find %s for %s", link_name, p->name);

	return &app->link_params[link_param_idx];
}

static inline struct app_link_params *
app_get_link_for_tm(struct app_params *app, struct app_pktq_tm_params *p_tm)
{
	char link_name[APP_PARAM_NAME_SIZE];
	uint32_t link_id;
	ssize_t link_param_idx;

	sscanf(p_tm->name, "TM%" PRIu32, &link_id);
	sprintf(link_name, "LINK%" PRIu32, link_id);
	link_param_idx = APP_PARAM_FIND(app->link_params, link_name);
	APP_CHECK((link_param_idx >= 0),
		"Cannot find %s for %s", link_name, p_tm->name);

	return &app->link_params[link_param_idx];
}

int app_config_init(struct app_params *app);

int app_config_args(struct app_params *app,
	int argc, char **argv);

int app_config_preproc(struct app_params *app);

int app_config_parse(struct app_params *app,
	const char *file_name);

int app_config_parse_tm(struct app_params *app);

void app_config_save(struct app_params *app,
	const char *file_name);

int app_config_check(struct app_params *app);

int app_init(struct app_params *app);

int app_thread(void *arg);

int app_pipeline_type_register(struct app_params *app,
	struct pipeline_type *ptype);

struct pipeline_type *app_pipeline_type_find(struct app_params *app,
	char *name);

void app_link_up_internal(struct app_params *app,
	struct app_link_params *cp);

void app_link_down_internal(struct app_params *app,
	struct app_link_params *cp);

#endif