Bump upstreams
[netconf.git] / netconf / sal-netconf-connector / src / main / java / org / opendaylight / netconf / sal / connect / netconf / schema / mapping / NetconfMessageTransformer.java
index 10603017c2e909c7a2371993761d9435b0bf977b..da5d3caef263443702164f629a3334df151e9d7d 100644 (file)
@@ -7,30 +7,47 @@
  */
 package org.opendaylight.netconf.sal.connect.netconf.schema.mapping;
 
+import static com.google.common.base.Preconditions.checkArgument;
+import static com.google.common.base.Preconditions.checkNotNull;
+import static java.util.Objects.requireNonNull;
 import static org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil.CREATE_SUBSCRIPTION_RPC_QNAME;
 import static org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil.IETF_NETCONF_NOTIFICATIONS;
-import static org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil.NETCONF_RPC_REPLY_NODEID;
 import static org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil.NETCONF_URI;
-import static org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil.toPath;
 
+import com.google.common.annotations.Beta;
 import com.google.common.annotations.VisibleForTesting;
-import com.google.common.base.Preconditions;
+import com.google.common.collect.ImmutableList;
+import com.google.common.collect.ImmutableMap;
 import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.ImmutableSet.Builder;
+import com.google.common.collect.Iterables;
 import com.google.common.collect.Maps;
 import com.google.common.collect.Multimap;
 import com.google.common.collect.Multimaps;
+import com.google.common.collect.Streams;
 import java.io.IOException;
-import java.net.URI;
 import java.net.URISyntaxException;
 import java.time.Instant;
+import java.util.AbstractMap;
+import java.util.ArrayDeque;
+import java.util.ArrayList;
 import java.util.Collection;
 import java.util.Collections;
+import java.util.Deque;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.List;
 import java.util.Map;
+import java.util.Map.Entry;
+import java.util.Optional;
 import java.util.Set;
+import java.util.function.Function;
+import java.util.stream.Collectors;
 import javax.xml.stream.XMLStreamException;
 import javax.xml.transform.dom.DOMResult;
 import javax.xml.transform.dom.DOMSource;
+import org.checkerframework.checker.lock.qual.GuardedBy;
+import org.eclipse.jdt.annotation.NonNull;
+import org.opendaylight.mdsal.common.api.LogicalDatastoreType;
 import org.opendaylight.mdsal.dom.api.DOMActionResult;
 import org.opendaylight.mdsal.dom.api.DOMDataTreeIdentifier;
 import org.opendaylight.mdsal.dom.api.DOMEvent;
@@ -41,13 +58,18 @@ import org.opendaylight.mdsal.dom.spi.SimpleDOMActionResult;
 import org.opendaylight.netconf.api.NetconfMessage;
 import org.opendaylight.netconf.api.xml.MissingNameSpaceException;
 import org.opendaylight.netconf.api.xml.XmlElement;
-import org.opendaylight.netconf.sal.connect.api.MessageTransformer;
+import org.opendaylight.netconf.sal.connect.api.ActionTransformer;
+import org.opendaylight.netconf.sal.connect.api.NotificationTransformer;
+import org.opendaylight.netconf.sal.connect.api.RpcTransformer;
 import org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil;
 import org.opendaylight.netconf.sal.connect.util.MessageCounter;
+import org.opendaylight.yangtools.rfc8528.data.api.MountPointContext;
 import org.opendaylight.yangtools.yang.common.QName;
 import org.opendaylight.yangtools.yang.common.Revision;
-import org.opendaylight.yangtools.yang.common.RpcError;
-import org.opendaylight.yangtools.yang.common.YangConstants;
+import org.opendaylight.yangtools.yang.common.RpcResult;
+import org.opendaylight.yangtools.yang.common.XMLNamespace;
+import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
+import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.InstanceIdentifierBuilder;
 import org.opendaylight.yangtools.yang.data.api.schema.ContainerNode;
 import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
 import org.opendaylight.yangtools.yang.data.api.schema.stream.NormalizedNodeStreamWriter;
@@ -58,82 +80,99 @@ import org.opendaylight.yangtools.yang.data.impl.schema.NormalizedNodeResult;
 import org.opendaylight.yangtools.yang.data.util.DataSchemaContextTree;
 import org.opendaylight.yangtools.yang.model.api.ActionDefinition;
 import org.opendaylight.yangtools.yang.model.api.ActionNodeContainer;
+import org.opendaylight.yangtools.yang.model.api.CaseSchemaNode;
+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.EffectiveModelContext;
+import org.opendaylight.yangtools.yang.model.api.InputSchemaNode;
+import org.opendaylight.yangtools.yang.model.api.ListSchemaNode;
+import org.opendaylight.yangtools.yang.model.api.Module;
 import org.opendaylight.yangtools.yang.model.api.NotificationDefinition;
 import org.opendaylight.yangtools.yang.model.api.OperationDefinition;
 import org.opendaylight.yangtools.yang.model.api.RpcDefinition;
-import org.opendaylight.yangtools.yang.model.api.SchemaContext;
 import org.opendaylight.yangtools.yang.model.api.SchemaNode;
-import org.opendaylight.yangtools.yang.model.api.SchemaPath;
+import org.opendaylight.yangtools.yang.model.api.stmt.SchemaNodeIdentifier.Absolute;
+import org.opendaylight.yangtools.yang.model.util.SchemaInferenceStack;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.w3c.dom.Document;
 import org.w3c.dom.Element;
+import org.w3c.dom.Node;
+import org.w3c.dom.NodeList;
 import org.xml.sax.SAXException;
 
-public class NetconfMessageTransformer implements MessageTransformer<NetconfMessage> {
-
+public class NetconfMessageTransformer
+        implements ActionTransformer, NotificationTransformer, RpcTransformer<ContainerNode, DOMRpcResult> {
     private static final Logger LOG = LoggerFactory.getLogger(NetconfMessageTransformer.class);
 
-    private static final ImmutableSet<URI> BASE_OR_NOTIFICATION_NS = ImmutableSet.of(
+    private static final ImmutableSet<XMLNamespace> BASE_OR_NOTIFICATION_NS = ImmutableSet.of(
         NETCONF_URI,
         IETF_NETCONF_NOTIFICATIONS.getNamespace(),
         CREATE_SUBSCRIPTION_RPC_QNAME.getNamespace());
 
-    private final SchemaContext schemaContext;
+    private final MountPointContext mountContext;
+    private final DataSchemaContextTree contextTree;
     private final BaseSchema baseSchema;
     private final MessageCounter counter;
-    private final Map<QName, RpcDefinition> mappedRpcs;
-    private final Multimap<QName, NotificationDefinition> mappedNotifications;
+    private final ImmutableMap<QName, ? extends RpcDefinition> mappedRpcs;
+    private final Multimap<QName, ? extends NotificationDefinition> mappedNotifications;
     private final boolean strictParsing;
-    private final Set<ActionDefinition> actions;
-
-    public NetconfMessageTransformer(final SchemaContext schemaContext, final boolean strictParsing) {
-        this(schemaContext, strictParsing, BaseSchema.BASE_NETCONF_CTX);
-    }
+    private final ImmutableMap<Absolute, ActionDefinition> actions;
 
-    public NetconfMessageTransformer(final SchemaContext schemaContext, final boolean strictParsing,
+    public NetconfMessageTransformer(final MountPointContext mountContext, final boolean strictParsing,
                                      final BaseSchema baseSchema) {
-        this.counter = new MessageCounter();
-        this.schemaContext = schemaContext;
-        this.mappedRpcs = Maps.uniqueIndex(schemaContext.getOperations(), SchemaNode::getQName);
-        this.actions = getActions();
-        this.mappedNotifications = Multimaps.index(schemaContext.getNotifications(),
+        counter = new MessageCounter();
+        this.mountContext = requireNonNull(mountContext);
+
+        final EffectiveModelContext schemaContext = mountContext.getEffectiveModelContext();
+        contextTree = DataSchemaContextTree.from(schemaContext);
+
+        mappedRpcs = Maps.uniqueIndex(schemaContext.getOperations(), SchemaNode::getQName);
+        actions = getActions(schemaContext);
+
+        // RFC6020 normal notifications
+        mappedNotifications = Multimaps.index(schemaContext.getNotifications(),
             node -> node.getQName().withoutRevision());
         this.baseSchema = baseSchema;
         this.strictParsing = strictParsing;
     }
 
     @VisibleForTesting
-    Set<ActionDefinition> getActions() {
-        Builder<ActionDefinition> builder = ImmutableSet.builder();
-        for (DataSchemaNode dataSchemaNode : schemaContext.getChildNodes()) {
-            if (dataSchemaNode instanceof ActionNodeContainer) {
-                findAction(dataSchemaNode, builder);
-            }
-        }
+    static ImmutableMap<Absolute, ActionDefinition> getActions(final EffectiveModelContext schemaContext) {
+        final var builder = ImmutableMap.<Absolute, ActionDefinition>builder();
+        findAction(schemaContext, new ArrayDeque<QName>(), builder);
         return builder.build();
     }
 
-    private void findAction(final DataSchemaNode dataSchemaNode, final Builder<ActionDefinition> builder) {
+    private static void findAction(final DataSchemaNode dataSchemaNode, final Deque<QName> path,
+            final ImmutableMap.Builder<Absolute, ActionDefinition> builder) {
         if (dataSchemaNode instanceof ActionNodeContainer) {
-            final ActionNodeContainer containerSchemaNode = (ActionNodeContainer) dataSchemaNode;
-            for (ActionDefinition actionDefinition : containerSchemaNode.getActions()) {
-                builder.add(actionDefinition);
+            for (ActionDefinition actionDefinition : ((ActionNodeContainer) dataSchemaNode).getActions()) {
+                path.addLast(actionDefinition.getQName());
+                builder.put(Absolute.of(path), actionDefinition);
+                path.removeLast();
             }
         }
         if (dataSchemaNode instanceof DataNodeContainer) {
             for (DataSchemaNode innerDataSchemaNode : ((DataNodeContainer) dataSchemaNode).getChildNodes()) {
-                findAction(innerDataSchemaNode, builder);
+                path.addLast(innerDataSchemaNode.getQName());
+                findAction(innerDataSchemaNode, path, builder);
+                path.removeLast();
+            }
+        } else if (dataSchemaNode instanceof ChoiceSchemaNode) {
+            for (CaseSchemaNode caze : ((ChoiceSchemaNode) dataSchemaNode).getCases()) {
+                path.addLast(caze.getQName());
+                findAction(caze, path, builder);
+                path.removeLast();
             }
         }
     }
 
     @Override
     public synchronized DOMNotification toNotification(final NetconfMessage message) {
-        final Map.Entry<Instant, XmlElement> stripped = NetconfMessageTransformUtil.stripNotification(message);
+        final Entry<Instant, XmlElement> stripped = NetconfMessageTransformUtil.stripNotification(message);
         final QName notificationNoRev;
         try {
             notificationNoRev = QName.create(
@@ -142,77 +181,190 @@ public class NetconfMessageTransformer implements MessageTransformer<NetconfMess
             throw new IllegalArgumentException(
                     "Unable to parse notification " + message + ", cannot find namespace", e);
         }
-        final Collection<NotificationDefinition> notificationDefinitions = mappedNotifications.get(notificationNoRev);
-        Preconditions.checkArgument(notificationDefinitions.size() > 0,
-                "Unable to parse notification %s, unknown notification. Available notifications: %s",
-                notificationDefinitions, mappedNotifications.keySet());
 
-        final NotificationDefinition mostRecentNotification = getMostRecentNotification(notificationDefinitions);
+        final var matchingTopLevel = mappedNotifications.get(notificationNoRev);
+        final var element = stripped.getValue().getDomElement();
+        if (!matchingTopLevel.isEmpty()) {
+            final var notification = getMostRecentNotification(matchingTopLevel);
+            // FIXME: we really should have a pre-constructed identifier here
+            return new NetconfDeviceNotification(toNotification(Absolute.of(notification.getQName()), element),
+                stripped.getKey());
+        }
 
-        final ContainerSchemaNode notificationAsContainerSchemaNode =
-                NetconfMessageTransformUtil.createSchemaForNotification(mostRecentNotification);
+        final var nestedInfo = findNestedNotification(message, element)
+            .orElseThrow(() -> new IllegalArgumentException("Unable to parse notification for " + element
+                + ". Available notifications: " + mappedNotifications.keySet()));
+        final var schemaPath = nestedInfo.schemaPath;
+        return new NetconfDeviceTreeNotification(toNotification(schemaPath, nestedInfo.element), schemaPath,
+            stripped.getKey(), nestedInfo.instancePath);
+    }
 
-        final Element element = stripped.getValue().getDomElement();
-        final ContainerNode content;
+    @GuardedBy("this")
+    private ContainerNode toNotification(final Absolute notificationPath, final Element element) {
+        final NormalizedNodeResult resultHolder = new NormalizedNodeResult();
         try {
-            final NormalizedNodeResult resultHolder = new NormalizedNodeResult();
             final NormalizedNodeStreamWriter writer = ImmutableNormalizedNodeStreamWriter.from(resultHolder);
-            final XmlParserStream xmlParser = XmlParserStream.create(writer, schemaContext,
-                    notificationAsContainerSchemaNode, strictParsing);
+            final XmlParserStream xmlParser = XmlParserStream.create(writer, mountContext,
+                    SchemaInferenceStack.of(mountContext.getEffectiveModelContext(), notificationPath).toInference(),
+                    strictParsing);
             xmlParser.traverse(new DOMSource(element));
-            content = (ContainerNode) resultHolder.getResult();
         } catch (XMLStreamException | URISyntaxException | IOException | SAXException
                 | UnsupportedOperationException e) {
             throw new IllegalArgumentException(String.format("Failed to parse notification %s", element), e);
         }
-        return new NetconfDeviceNotification(content, stripped.getKey());
+        return (ContainerNode) resultHolder.getResult();
+    }
+
+    private Optional<NestedNotificationInfo> findNestedNotification(final NetconfMessage message,
+            final Element element) {
+        final Iterator<? extends Module> modules = mountContext.getEffectiveModelContext()
+                .findModules(XMLNamespace.of(element.getNamespaceURI())).iterator();
+        if (!modules.hasNext()) {
+            throw new IllegalArgumentException(
+                    "Unable to parse notification " + message + ", cannot find top level module");
+        }
+        final Module module = modules.next();
+        final QName topLevelNodeQName = QName.create(element.getNamespaceURI(), element.getLocalName());
+        for (DataSchemaNode childNode : module.getChildNodes()) {
+            if (topLevelNodeQName.isEqualWithoutRevision(childNode.getQName())) {
+                return Optional.of(traverseXmlNodeContainingNotification(element, childNode, new ArrayList<>(),
+                    YangInstanceIdentifier.builder()));
+            }
+        }
+        return Optional.empty();
+    }
+
+    // FIXME: this method is using QNames which are not bound to a Revision. Why is that?
+    // FIXME: furthermore this does not handle the entirety of schema layout: notably missing a choice/case schema nodes
+    private NestedNotificationInfo traverseXmlNodeContainingNotification(final Node xmlNode,
+            final SchemaNode schemaNode, final List<QName> schemaBuilder,
+            final InstanceIdentifierBuilder instanceBuilder) {
+        if (schemaNode instanceof ContainerSchemaNode containerSchema) {
+            instanceBuilder.node(QName.create(xmlNode.getNamespaceURI(), xmlNode.getLocalName()));
+            schemaBuilder.add(containerSchema.getQName());
+
+            Entry<Node, SchemaNode> xmlContainerChildPair = findXmlContainerChildPair(xmlNode, containerSchema);
+            return traverseXmlNodeContainingNotification(xmlContainerChildPair.getKey(),
+                    xmlContainerChildPair.getValue(), schemaBuilder, instanceBuilder);
+        } else if (schemaNode instanceof ListSchemaNode listSchema) {
+            instanceBuilder.node(QName.create(xmlNode.getNamespaceURI(), xmlNode.getLocalName()));
+            schemaBuilder.add(listSchema.getQName());
+
+            Map<QName, Object> listKeys = findXmlListKeys(xmlNode, listSchema);
+            instanceBuilder.nodeWithKey(QName.create(xmlNode.getNamespaceURI(), xmlNode.getLocalName()), listKeys);
+
+            Entry<Node, SchemaNode> xmlListChildPair = findXmlListChildPair(xmlNode, listSchema);
+            return traverseXmlNodeContainingNotification(xmlListChildPair.getKey(),
+                    xmlListChildPair.getValue(), schemaBuilder, instanceBuilder);
+        } else if (schemaNode instanceof NotificationDefinition) {
+            // FIXME: this should not be here: it does not form a valid YangInstanceIdentifier
+            instanceBuilder.node(QName.create(xmlNode.getNamespaceURI(), xmlNode.getLocalName()));
+            schemaBuilder.add(schemaNode.getQName());
+
+            return new NestedNotificationInfo(Absolute.of(schemaBuilder),
+                    new DOMDataTreeIdentifier(LogicalDatastoreType.CONFIGURATION, instanceBuilder.build()), xmlNode);
+        }
+        throw new IllegalStateException("No notification found");
+    }
+
+    private static Entry<Node, SchemaNode> findXmlContainerChildPair(final Node xmlNode,
+            final ContainerSchemaNode container) {
+        final NodeList nodeList = xmlNode.getChildNodes();
+        final Map<QName, SchemaNode> childrenWithoutRevision =
+                Streams.concat(container.getChildNodes().stream(), container.getNotifications().stream())
+                    .collect(Collectors.toMap(child -> child.getQName().withoutRevision(), Function.identity()));
+
+        for (int i = 0; i < nodeList.getLength(); i++) {
+            Node currentNode = nodeList.item(i);
+            if (currentNode.getNodeType() == Node.ELEMENT_NODE) {
+                QName currentNodeQName = QName.create(currentNode.getNamespaceURI(), currentNode.getLocalName());
+                SchemaNode schemaChildNode = childrenWithoutRevision.get(currentNodeQName);
+                if (schemaChildNode != null) {
+                    return Map.entry(currentNode, schemaChildNode);
+                }
+            }
+        }
+        throw new IllegalStateException("No container child found.");
+    }
+
+    private static Map<QName, Object> findXmlListKeys(final Node xmlNode, final ListSchemaNode listSchemaNode) {
+        Map<QName, Object> listKeys = new HashMap<>();
+        NodeList nodeList = xmlNode.getChildNodes();
+        Set<QName> keyDefinitionsWithoutRevision = listSchemaNode.getKeyDefinition().stream()
+                .map(QName::withoutRevision).collect(Collectors.toSet());
+        for (int i = 0; i < nodeList.getLength(); i++) {
+            Node currentNode = nodeList.item(i);
+            if (currentNode.getNodeType() == Node.ELEMENT_NODE) {
+                QName currentNodeQName = QName.create(currentNode.getNamespaceURI(), currentNode.getLocalName());
+                if (keyDefinitionsWithoutRevision.contains(currentNodeQName)) {
+                    listKeys.put(currentNodeQName, currentNode.getFirstChild().getNodeValue());
+                }
+            }
+        }
+        if (listKeys.isEmpty()) {
+            throw new IllegalStateException("Notification cannot be contained in list without key statement.");
+        }
+        return listKeys;
+    }
+
+    private static Entry<Node, SchemaNode> findXmlListChildPair(final Node xmlNode, final ListSchemaNode list) {
+        final NodeList nodeList = xmlNode.getChildNodes();
+        for (int i = 0; i < nodeList.getLength(); i++) {
+            Node currentNode = nodeList.item(i);
+            if (currentNode.getNodeType() == Node.ELEMENT_NODE) {
+                QName currentNodeQName = QName.create(currentNode.getNamespaceURI(), currentNode.getLocalName());
+                for (SchemaNode childNode : Iterables.concat(list.getChildNodes(), list.getNotifications())) {
+                    if (!list.getKeyDefinition().contains(childNode.getQName())
+                            && currentNodeQName.isEqualWithoutRevision(childNode.getQName())) {
+                        return new AbstractMap.SimpleEntry<>(currentNode, childNode);
+                    }
+                }
+            }
+        }
+        throw new IllegalStateException("No list child found.");
     }
 
     private static NotificationDefinition getMostRecentNotification(
-            final Collection<NotificationDefinition> notificationDefinitions) {
+            final Collection<? extends NotificationDefinition> notificationDefinitions) {
         return Collections.max(notificationDefinitions, (o1, o2) ->
             Revision.compare(o1.getQName().getRevision(), o2.getQName().getRevision()));
     }
 
     @Override
-    public NetconfMessage toRpcRequest(final SchemaPath rpc, final NormalizedNode<?, ?> payload) {
+    public NetconfMessage toRpcRequest(final QName rpc, final ContainerNode payload) {
         // In case no input for rpc is defined, we can simply construct the payload here
-        final QName rpcQName = rpc.getLastComponent();
 
         // Determine whether a base netconf operation is being invoked
         // and also check if the device exposed model for base netconf.
         // If no, use pre built base netconf operations model
-        final boolean needToUseBaseCtx = mappedRpcs.get(rpcQName) == null && isBaseOrNotificationRpc(rpcQName);
-        final Map<QName, RpcDefinition> currentMappedRpcs;
+        final boolean needToUseBaseCtx = mappedRpcs.get(rpc) == null && isBaseOrNotificationRpc(rpc);
+        final ImmutableMap<QName, ? extends RpcDefinition> currentMappedRpcs;
         if (needToUseBaseCtx) {
             currentMappedRpcs = baseSchema.getMappedRpcs();
         } else {
             currentMappedRpcs = mappedRpcs;
         }
 
-        final RpcDefinition mappedRpc = Preconditions.checkNotNull(currentMappedRpcs.get(rpcQName),
-                "Unknown rpc %s, available rpcs: %s", rpcQName, currentMappedRpcs.keySet());
+        final RpcDefinition mappedRpc = checkNotNull(currentMappedRpcs.get(rpc),
+                "Unknown rpc %s, available rpcs: %s", rpc, currentMappedRpcs.keySet());
         if (mappedRpc.getInput().getChildNodes().isEmpty()) {
-            return new NetconfMessage(NetconfMessageTransformUtil
-                    .prepareDomResultForRpcRequest(rpcQName, counter).getNode().getOwnerDocument());
+            return new NetconfMessage(NetconfMessageTransformUtil.prepareDomResultForRpcRequest(rpc, counter)
+                .getNode().getOwnerDocument());
         }
 
-        Preconditions.checkNotNull(payload, "Transforming an rpc with input: %s, payload cannot be null", rpcQName);
-
-        Preconditions.checkArgument(payload instanceof ContainerNode,
-                "Transforming an rpc with input: %s, payload has to be a container, but was: %s", rpcQName, payload);
-        // Set the path to the input of rpc for the node stream writer
-        final SchemaPath rpcInput = rpc.createChild(YangConstants.operationInputQName(rpcQName.getModule()));
-        final DOMResult result = NetconfMessageTransformUtil.prepareDomResultForRpcRequest(rpcQName, counter);
+        checkNotNull(payload, "Transforming an rpc with input: %s, payload cannot be null", rpc);
 
+        final DOMResult result = NetconfMessageTransformUtil.prepareDomResultForRpcRequest(rpc, counter);
         try {
             // If the schema context for netconf device does not contain model for base netconf operations,
             // use default pre build context with just the base model
             // This way operations like lock/unlock are supported even if the source for base model was not provided
-            SchemaContext ctx = needToUseBaseCtx ? baseSchema.getSchemaContext() : schemaContext;
-            NetconfMessageTransformUtil.writeNormalizedRpc((ContainerNode) payload, result, rpcInput, ctx);
+            final EffectiveModelContext ctx = needToUseBaseCtx ? baseSchema.getEffectiveModelContext()
+                    : mountContext.getEffectiveModelContext();
+            NetconfMessageTransformUtil.writeNormalizedOperationInput(payload, result, Absolute.of(rpc),
+                ctx);
         } catch (final XMLStreamException | IOException | IllegalStateException e) {
-            throw new IllegalStateException("Unable to serialize " + rpcInput, e);
+            throw new IllegalStateException("Unable to serialize input of " + rpc, e);
         }
 
         final Document node = result.getNode().getOwnerDocument();
@@ -221,46 +373,31 @@ public class NetconfMessageTransformer implements MessageTransformer<NetconfMess
     }
 
     @Override
-    public NetconfMessage toActionRequest(SchemaPath action, final DOMDataTreeIdentifier domDataTreeIdentifier,
-            final NormalizedNode<?, ?> payload) {
-        ActionDefinition actionDefinition = null;
-        SchemaPath schemaPath = action;
-        for (ActionDefinition actionDef : actions) {
-            if (actionDef.getPath().getLastComponent().equals(action.getLastComponent())) {
-                actionDefinition = actionDef;
-                schemaPath = actionDef.getPath();
-            }
-        }
-        Preconditions.checkNotNull(actionDefinition, "Action does not exist: %s", action.getLastComponent());
-
-        if (actionDefinition.getInput().getChildNodes().isEmpty()) {
-            return new NetconfMessage(NetconfMessageTransformUtil.prepareDomResultForActionRequest(
-                    DataSchemaContextTree.from(schemaContext), domDataTreeIdentifier, action, counter,
-                    actionDefinition.getQName().getLocalName())
-                    .getNode().getOwnerDocument());
+    public NetconfMessage toActionRequest(final Absolute action, final DOMDataTreeIdentifier domDataTreeIdentifier,
+            final NormalizedNode payload) {
+        final ActionDefinition actionDef = actions.get(action);
+        checkArgument(actionDef != null, "Action does not exist: %s", action);
+
+        final InputSchemaNode inputDef = actionDef.getInput();
+        if (inputDef.getChildNodes().isEmpty()) {
+            return new NetconfMessage(NetconfMessageTransformUtil.prepareDomResultForActionRequest(contextTree,
+                domDataTreeIdentifier, counter, actionDef.getQName()).getNode().getOwnerDocument());
         }
 
-        Preconditions.checkNotNull(payload, "Transforming an action with input: %s, payload cannot be null",
-                action.getLastComponent());
-        Preconditions.checkArgument(payload instanceof ContainerNode,
-                "Transforming an rpc with input: %s, payload has to be a container, but was: %s",
-                action.getLastComponent(), payload);
-        // Set the path to the input of rpc for the node stream writer
-        action = action.createChild(QName.create(action.getLastComponent(), "input").intern());
-        final DOMResult result = NetconfMessageTransformUtil.prepareDomResultForActionRequest(
-                DataSchemaContextTree.from(schemaContext), domDataTreeIdentifier, action, counter,
-                actionDefinition.getQName().getLocalName());
+        checkNotNull(payload, "Transforming an action with input: %s, payload cannot be null", action);
+        checkArgument(payload instanceof ContainerNode,
+                "Transforming an action with input: %s, payload has to be a container, but was: %s", action, payload);
 
+        final DOMResult result = NetconfMessageTransformUtil.prepareDomResultForActionRequest(contextTree,
+            domDataTreeIdentifier, counter, actionDef.getQName());
         try {
-            NetconfMessageTransformUtil.writeNormalizedRpc((ContainerNode) payload, result,
-                    schemaPath.createChild(QName.create(action.getLastComponent(), "input").intern()), schemaContext);
+            NetconfMessageTransformUtil.writeNormalizedOperationInput((ContainerNode) payload, result, action,
+                mountContext.getEffectiveModelContext());
         } catch (final XMLStreamException | IOException | IllegalStateException e) {
-            throw new IllegalStateException("Unable to serialize " + action, e);
+            throw new IllegalStateException("Unable to serialize input of " + action, e);
         }
 
-        final Document node = result.getNode().getOwnerDocument();
-
-        return new NetconfMessage(node);
+        return new NetconfMessage(result.getNode().getOwnerDocument());
     }
 
     private static boolean isBaseOrNotificationRpc(final QName rpc) {
@@ -268,104 +405,111 @@ public class NetconfMessageTransformer implements MessageTransformer<NetconfMess
     }
 
     @Override
-    public synchronized DOMRpcResult toRpcResult(final NetconfMessage message, final SchemaPath rpc) {
-        final NormalizedNode<?, ?> normalizedNode;
-        final QName rpcQName = rpc.getLastComponent();
-        if (NetconfMessageTransformUtil.isDataRetrievalOperation(rpcQName)) {
-            final Element xmlData = NetconfMessageTransformUtil.getDataSubtree(message.getDocument());
-            final ContainerSchemaNode schemaForDataRead =
-                    NetconfMessageTransformUtil.createSchemaForDataRead(schemaContext);
-            final ContainerNode dataNode;
-
-            try {
-                final NormalizedNodeResult resultHolder = new NormalizedNodeResult();
-                final NormalizedNodeStreamWriter writer = ImmutableNormalizedNodeStreamWriter.from(resultHolder);
-                final XmlParserStream xmlParser = XmlParserStream.create(writer, schemaContext, schemaForDataRead,
-                        strictParsing);
-                xmlParser.traverse(new DOMSource(xmlData));
-                dataNode = (ContainerNode) resultHolder.getResult();
-            } catch (XMLStreamException | URISyntaxException | IOException | SAXException e) {
-                throw new IllegalArgumentException(String.format("Failed to parse data response %s", xmlData), e);
-            }
+    public synchronized DOMRpcResult toRpcResult(final RpcResult<NetconfMessage> resultPayload, final QName rpc) {
+        if (!resultPayload.isSuccessful()) {
+            return new DefaultDOMRpcResult(resultPayload.getErrors());
+        }
 
+        final var message = resultPayload.getResult();
+        final ContainerNode normalizedNode;
+        if (NetconfMessageTransformUtil.isDataRetrievalOperation(rpc)) {
             normalizedNode = Builders.containerBuilder()
-                    .withNodeIdentifier(NETCONF_RPC_REPLY_NODEID)
-                    .withChild(dataNode).build();
+                    .withNodeIdentifier(NetconfMessageTransformUtil.NETCONF_RPC_REPLY_NODEID)
+                    .withChild(Builders.anyXmlBuilder()
+                        .withNodeIdentifier(NetconfMessageTransformUtil.NETCONF_DATA_NODEID)
+                        .withValue(new DOMSource(NetconfMessageTransformUtil.getDataSubtree(message.getDocument())))
+                        .build())
+                    .build();
         } else {
-
-            Map<QName, RpcDefinition> currentMappedRpcs = mappedRpcs;
-
             // Determine whether a base netconf operation is being invoked
             // and also check if the device exposed model for base netconf.
             // If no, use pre built base netconf operations model
-            final boolean needToUseBaseCtx = mappedRpcs.get(rpcQName) == null && isBaseOrNotificationRpc(rpcQName);
-            if (needToUseBaseCtx) {
+            final ImmutableMap<QName, ? extends RpcDefinition> currentMappedRpcs;
+            if (mappedRpcs.get(rpc) == null && isBaseOrNotificationRpc(rpc)) {
                 currentMappedRpcs = baseSchema.getMappedRpcs();
+            } else {
+                currentMappedRpcs = mappedRpcs;
             }
 
-            final RpcDefinition rpcDefinition = currentMappedRpcs.get(rpcQName);
-            Preconditions.checkArgument(rpcDefinition != null,
-                    "Unable to parse response of %s, the rpc is unknown", rpcQName);
+            final RpcDefinition rpcDefinition = currentMappedRpcs.get(rpc);
+            checkArgument(rpcDefinition != null, "Unable to parse response of %s, the rpc is unknown", rpc);
 
             // In case no input for rpc is defined, we can simply construct the payload here
-            normalizedNode = parseResult(message, rpcDefinition);
+            normalizedNode = parseResult(message, Absolute.of(rpc), rpcDefinition);
         }
         return new DefaultDOMRpcResult(normalizedNode);
     }
 
     @Override
-    public DOMActionResult toActionResult(final SchemaPath action, final NetconfMessage message) {
-        ActionDefinition actionDefinition = null;
-        for (ActionDefinition actionDef : actions) {
-            if (actionDef.getPath().getLastComponent().equals(action.getLastComponent())) {
-                actionDefinition = actionDef;
-            }
-        }
-        Preconditions.checkNotNull(actionDefinition, "Action does not exist: %s", action);
-        ContainerNode normalizedNode = (ContainerNode) parseResult(message, actionDefinition);
+    public DOMActionResult toActionResult(final Absolute action, final NetconfMessage message) {
+        final ActionDefinition actionDefinition = actions.get(action);
+        checkArgument(actionDefinition != null, "Action does not exist: %s", action);
+        final ContainerNode normalizedNode = parseResult(message, action, actionDefinition);
 
         if (normalizedNode == null) {
-            return new SimpleDOMActionResult(Collections.<RpcError>emptyList());
+            return new SimpleDOMActionResult(List.of());
         } else {
-            return new SimpleDOMActionResult(normalizedNode, Collections.<RpcError>emptyList());
+            return new SimpleDOMActionResult(normalizedNode, List.of());
         }
     }
 
-    private NormalizedNode<?, ?> parseResult(final NetconfMessage message,
-            final OperationDefinition operationDefinition) {
-        if (operationDefinition.getOutput().getChildNodes().isEmpty()) {
-            Preconditions.checkArgument(XmlElement.fromDomDocument(
-                message.getDocument()).getOnlyChildElementWithSameNamespaceOptionally("ok").isPresent(),
-                "Unexpected content in response of rpc: %s, %s", operationDefinition.getQName(), message);
+    private ContainerNode parseResult(final NetconfMessage message, final Absolute operationPath,
+            final OperationDefinition operationDef) {
+        final Optional<XmlElement> okResponseElement = XmlElement.fromDomDocument(message.getDocument())
+                .getOnlyChildElementWithSameNamespaceOptionally("ok");
+        final var operOutput = operationDef.getOutput();
+        if (operOutput.getChildNodes().isEmpty()) {
+            checkArgument(okResponseElement.isPresent(), "Unexpected content in response of operation: %s, %s",
+                operationDef.getQName(), message);
             return null;
-        } else {
-            final Element element = message.getDocument().getDocumentElement();
-            try {
-                final NormalizedNodeResult resultHolder = new NormalizedNodeResult();
-                final NormalizedNodeStreamWriter writer = ImmutableNormalizedNodeStreamWriter.from(resultHolder);
-                final XmlParserStream xmlParser = XmlParserStream.create(writer, schemaContext,
-                        operationDefinition.getOutput(), strictParsing);
-                xmlParser.traverse(new DOMSource(element));
-                return resultHolder.getResult();
-            } catch (XMLStreamException | URISyntaxException | IOException | SAXException e) {
-                throw new IllegalArgumentException(String.format("Failed to parse RPC response %s", element), e);
-            }
         }
+        if (okResponseElement.isPresent()) {
+            // FIXME: could be an action as well
+            LOG.debug("Received response <ok/> for RPC with defined Output");
+            return null;
+        }
+
+        final var operSteps = operationPath.getNodeIdentifiers();
+        final var outputPath = Absolute.of(ImmutableList.<QName>builderWithExpectedSize(operSteps.size() + 1)
+            .addAll(operSteps)
+            .add(operOutput.getQName())
+            .build());
+        // FIXME: we should have a cached inference here, or XMLParserStream should accept Absolute instead
+        final var inference = SchemaInferenceStack.of(mountContext.getEffectiveModelContext(), outputPath)
+            .toInference();
+
+        final NormalizedNodeResult resultHolder = new NormalizedNodeResult();
+        final Element element = message.getDocument().getDocumentElement();
+        try {
+            final NormalizedNodeStreamWriter writer = ImmutableNormalizedNodeStreamWriter.from(resultHolder);
+            final XmlParserStream xmlParser = XmlParserStream.create(writer, mountContext, inference, strictParsing);
+            xmlParser.traverse(new DOMSource(element));
+        } catch (XMLStreamException | URISyntaxException | IOException | SAXException e) {
+            throw new IllegalArgumentException(String.format("Failed to parse RPC response %s", element), e);
+        }
+        return (ContainerNode) resultHolder.getResult();
     }
 
-    static class NetconfDeviceNotification implements DOMNotification, DOMEvent {
+    @Beta
+    public static class NetconfDeviceNotification implements DOMNotification, DOMEvent {
         private final ContainerNode content;
-        private final SchemaPath schemaPath;
+        private final Absolute schemaPath;
         private final Instant eventTime;
 
         NetconfDeviceNotification(final ContainerNode content, final Instant eventTime) {
             this.content = content;
             this.eventTime = eventTime;
-            this.schemaPath = toPath(content.getNodeType());
+            schemaPath = Absolute.of(content.getIdentifier().getNodeType());
+        }
+
+        NetconfDeviceNotification(final ContainerNode content, final Absolute schemaPath, final Instant eventTime) {
+            this.content = content;
+            this.eventTime = eventTime;
+            this.schemaPath = schemaPath;
         }
 
         @Override
-        public SchemaPath getType() {
+        public Absolute getType() {
             return schemaPath;
         }
 
@@ -379,4 +523,33 @@ public class NetconfMessageTransformer implements MessageTransformer<NetconfMess
             return eventTime;
         }
     }
+
+    @Beta
+    public static class NetconfDeviceTreeNotification extends NetconfDeviceNotification {
+        private final DOMDataTreeIdentifier domDataTreeIdentifier;
+
+        NetconfDeviceTreeNotification(final ContainerNode content, final Absolute schemaPath, final Instant eventTime,
+                final DOMDataTreeIdentifier domDataTreeIdentifier) {
+            super(content, schemaPath, eventTime);
+            this.domDataTreeIdentifier = domDataTreeIdentifier;
+        }
+
+        public DOMDataTreeIdentifier getDomDataTreeIdentifier() {
+            return domDataTreeIdentifier;
+        }
+    }
+
+    private static final class NestedNotificationInfo {
+        final @NonNull DOMDataTreeIdentifier instancePath;
+        final @NonNull Absolute schemaPath;
+        final @NonNull Element element;
+
+        NestedNotificationInfo(final Absolute schemaPath, final DOMDataTreeIdentifier instancePath,
+                final Node documentNode) {
+            this.schemaPath = requireNonNull(schemaPath);
+            this.instancePath = requireNonNull(instancePath);
+            checkArgument(documentNode instanceof Element, "Unexpected document node %s", documentNode);
+            element = (Element) documentNode;
+        }
+    }
 }