X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?p=controller.git;a=blobdiff_plain;f=opendaylight%2Fmd-sal%2Fsal-rest-connector%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fcontroller%2Fsal%2Frestconf%2Fimpl%2FRestconfImpl.java;h=5f5b9bafe10239dc9eb3df60e6435b916b54bd8a;hp=f44ce951550b3cd01c940739568f197cd0e8e6fd;hb=06e889c9c78457590b6a0b62d89a6b9f44242a9f;hpb=64db87e8fb5de25e68ba824ec2eaa17e3f217c96 diff --git a/opendaylight/md-sal/sal-rest-connector/src/main/java/org/opendaylight/controller/sal/restconf/impl/RestconfImpl.java b/opendaylight/md-sal/sal-rest-connector/src/main/java/org/opendaylight/controller/sal/restconf/impl/RestconfImpl.java index f44ce95155..5f5b9bafe1 100644 --- a/opendaylight/md-sal/sal-rest-connector/src/main/java/org/opendaylight/controller/sal/restconf/impl/RestconfImpl.java +++ b/opendaylight/md-sal/sal-rest-connector/src/main/java/org/opendaylight/controller/sal/restconf/impl/RestconfImpl.java @@ -18,6 +18,8 @@ import com.google.common.base.Throwables; import com.google.common.collect.ImmutableList; import com.google.common.collect.Iterables; import com.google.common.collect.Lists; +import com.google.common.util.concurrent.CheckedFuture; +import com.google.common.util.concurrent.Futures; import java.math.BigInteger; import java.net.URI; import java.net.URISyntaxException; @@ -32,7 +34,10 @@ import java.util.Iterator; import java.util.List; import java.util.Map; import java.util.Set; +import java.util.concurrent.CancellationException; +import java.util.concurrent.ExecutionException; import javax.ws.rs.core.Response; +import javax.ws.rs.core.Response.ResponseBuilder; import javax.ws.rs.core.Response.Status; import javax.ws.rs.core.UriBuilder; import javax.ws.rs.core.UriInfo; @@ -43,6 +48,10 @@ import org.opendaylight.controller.md.sal.common.api.data.OptimisticLockFailedEx import org.opendaylight.controller.md.sal.common.api.data.TransactionCommitFailedException; import org.opendaylight.controller.md.sal.common.impl.util.compat.DataNormalizer; import org.opendaylight.controller.md.sal.dom.api.DOMMountPoint; +import org.opendaylight.controller.md.sal.dom.api.DOMRpcException; +import org.opendaylight.controller.md.sal.dom.api.DOMRpcResult; +import org.opendaylight.controller.md.sal.dom.api.DOMRpcService; +import org.opendaylight.controller.md.sal.dom.spi.DefaultDOMRpcResult; import org.opendaylight.controller.sal.rest.api.Draft02; import org.opendaylight.controller.sal.rest.api.RestconfService; import org.opendaylight.controller.sal.restconf.impl.RestconfError.ErrorTag; @@ -58,7 +67,6 @@ import org.opendaylight.yangtools.yang.common.QName; import org.opendaylight.yangtools.yang.common.QNameModule; import org.opendaylight.yangtools.yang.common.RpcResult; import org.opendaylight.yangtools.yang.data.api.CompositeNode; -import org.opendaylight.yangtools.yang.data.api.MutableCompositeNode; import org.opendaylight.yangtools.yang.data.api.Node; import org.opendaylight.yangtools.yang.data.api.SimpleNode; import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier; @@ -67,6 +75,7 @@ import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.NodeIdent import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.NodeIdentifierWithPredicates; import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.PathArgument; import org.opendaylight.yangtools.yang.data.api.schema.ContainerNode; +import org.opendaylight.yangtools.yang.data.api.schema.DataContainerChild; import org.opendaylight.yangtools.yang.data.api.schema.LeafSetEntryNode; import org.opendaylight.yangtools.yang.data.api.schema.MapEntryNode; import org.opendaylight.yangtools.yang.data.api.schema.MapNode; @@ -76,9 +85,11 @@ import org.opendaylight.yangtools.yang.data.composite.node.schema.cnsn.parser.Cn import org.opendaylight.yangtools.yang.data.impl.ImmutableCompositeNode; import org.opendaylight.yangtools.yang.data.impl.NodeFactory; import org.opendaylight.yangtools.yang.data.impl.schema.Builders; +import org.opendaylight.yangtools.yang.data.impl.schema.ImmutableNodes; import org.opendaylight.yangtools.yang.data.impl.schema.builder.api.CollectionNodeBuilder; import org.opendaylight.yangtools.yang.data.impl.schema.builder.api.DataContainerNodeAttrBuilder; import org.opendaylight.yangtools.yang.data.impl.schema.builder.api.ListNodeBuilder; +import org.opendaylight.yangtools.yang.data.impl.schema.builder.impl.ImmutableContainerNodeBuilder; import org.opendaylight.yangtools.yang.model.api.AnyXmlSchemaNode; import org.opendaylight.yangtools.yang.model.api.ContainerSchemaNode; import org.opendaylight.yangtools.yang.model.api.DataNodeContainer; @@ -90,6 +101,7 @@ import org.opendaylight.yangtools.yang.model.api.ListSchemaNode; import org.opendaylight.yangtools.yang.model.api.Module; 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.TypeDefinition; import org.opendaylight.yangtools.yang.model.api.type.IdentityrefTypeDefinition; @@ -285,47 +297,69 @@ public class RestconfImpl implements RestconfService { } @Override - public StructuredData getAvailableStreams(final UriInfo uriInfo) { + public NormalizedNodeContext getAvailableStreams(final UriInfo uriInfo) { + final SchemaContext schemaContext = controllerContext.getGlobalSchema(); final Set availableStreams = Notificator.getStreamNames(); - - final List> streamsAsData = new ArrayList>(); final Module restconfModule = getRestconfModule(); final DataSchemaNode streamSchemaNode = controllerContext.getRestconfModuleRestConfSchemaNode(restconfModule, Draft02.RestConfModule.STREAM_LIST_SCHEMA_NODE); + Preconditions.checkState(streamSchemaNode instanceof ListSchemaNode); + + final CollectionNodeBuilder listStreamsBuilder = Builders + .mapBuilder((ListSchemaNode) streamSchemaNode); + for (final String streamName : availableStreams) { - streamsAsData.add(toStreamCompositeNode(streamName, streamSchemaNode)); + listStreamsBuilder.withChild(toStreamEntryNode(streamName, streamSchemaNode)); } - final DataSchemaNode streamsSchemaNode = controllerContext.getRestconfModuleRestConfSchemaNode(restconfModule, - Draft02.RestConfModule.STREAMS_CONTAINER_SCHEMA_NODE); - final QName qName = streamsSchemaNode.getQName(); - final CompositeNode streamsNode = NodeFactory.createImmutableCompositeNode(qName, null, streamsAsData); - return new StructuredData(streamsNode, streamsSchemaNode, null, parsePrettyPrintParameter(uriInfo)); + final DataSchemaNode streamsContainerSchemaNode = controllerContext.getRestconfModuleRestConfSchemaNode( + restconfModule, Draft02.RestConfModule.STREAMS_CONTAINER_SCHEMA_NODE); + Preconditions.checkState(streamsContainerSchemaNode instanceof ContainerSchemaNode); + + final DataContainerNodeAttrBuilder streamsContainerBuilder = + Builders.containerBuilder((ContainerSchemaNode) streamsContainerSchemaNode); + streamsContainerBuilder.withChild(listStreamsBuilder.build()); + + + return new NormalizedNodeContext(new InstanceIdentifierContext(null, streamsContainerSchemaNode, null, + schemaContext), streamsContainerBuilder.build()); } @Override - public StructuredData getOperations(final UriInfo uriInfo) { + public NormalizedNodeContext getOperations(final UriInfo uriInfo) { final Set allModules = controllerContext.getAllModules(); - return operationsFromModulesToStructuredData(allModules, null, parsePrettyPrintParameter(uriInfo)); + return operationsFromModulesToNormalizedContext(allModules, null); } @Override - public StructuredData getOperations(final String identifier, final UriInfo uriInfo) { + public NormalizedNodeContext getOperations(final String identifier, final UriInfo uriInfo) { Set modules = null; DOMMountPoint mountPoint = null; if (identifier.contains(ControllerContext.MOUNT)) { final InstanceIdentifierContext mountPointIdentifier = controllerContext.toMountPointIdentifier(identifier); mountPoint = mountPointIdentifier.getMountPoint(); modules = controllerContext.getAllModules(mountPoint); + } else { - throw new RestconfDocumentedException( - "URI has bad format. If operations behind mount point should be showed, URI has to end with " - + ControllerContext.MOUNT, ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE); + final String errMsg = "URI has bad format. If operations behind mount point should be showed, URI has to end with "; + throw new RestconfDocumentedException(errMsg + ControllerContext.MOUNT, ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE); } - return operationsFromModulesToStructuredData(modules, mountPoint, parsePrettyPrintParameter(uriInfo)); + return operationsFromModulesToNormalizedContext(modules, mountPoint); } + private NormalizedNodeContext operationsFromModulesToNormalizedContext(final Set modules, + final DOMMountPoint mountPoint) { + + // FIXME find best way to change restconf-netconf yang schema for provide this functionality + final String errMsg = "We are not able support view operations functionality yet."; + throw new RestconfDocumentedException(errMsg, ErrorType.APPLICATION, ErrorTag.OPERATION_NOT_SUPPORTED); + } + + /** + * @deprecated method will be removed in Lithium release + */ + @Deprecated private StructuredData operationsFromModulesToStructuredData(final Set modules, final DOMMountPoint mountPoint, final boolean prettyPrint) { final List> operationsAsData = new ArrayList>(); @@ -401,6 +435,15 @@ public class RestconfImpl implements RestconfService { } } + /** + * @deprecated method will be removed for Lithium release + * so, please use toStreamEntryNode method + * + * @param streamName + * @param streamSchemaNode + * @return + */ + @Deprecated private CompositeNode toStreamCompositeNode(final String streamName, final DataSchemaNode streamSchemaNode) { final List> streamNodeValues = new ArrayList>(); List instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( @@ -430,11 +473,20 @@ public class RestconfImpl implements RestconfService { instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( ((DataNodeContainer) streamSchemaNode), "events"); final DataSchemaNode eventsSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); - streamNodeValues.add(NodeFactory. createImmutableSimpleNode(eventsSchemaNode.getQName(), null, "")); + streamNodeValues.add(NodeFactory.createImmutableSimpleNode(eventsSchemaNode.getQName(), null, "")); return NodeFactory.createImmutableCompositeNode(streamSchemaNode.getQName(), null, streamNodeValues); } + /** + * @deprecated method will be removed for Lithium release + * so, please use toModuleEntryNode method + * + * @param module + * @param moduleSchemaNode + * @return + */ + @Deprecated private CompositeNode toModuleCompositeNode(final Module module, final DataSchemaNode moduleSchemaNode) { final List> moduleNodeValues = new ArrayList>(); List instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( @@ -473,20 +525,103 @@ public class RestconfImpl implements RestconfService { } @Override - public StructuredData invokeRpc(final String identifier, final CompositeNode payload, final UriInfo uriInfo) { - final RpcExecutor rpc = resolveIdentifierInInvokeRpc(identifier); - final QName rpcName = rpc.getRpcDefinition().getQName(); - final URI rpcNamespace = rpcName.getNamespace(); - if (Objects.equal(rpcNamespace.toString(), SAL_REMOTE_NAMESPACE) - && Objects.equal(rpcName.getLocalName(), SAL_REMOTE_RPC_SUBSRCIBE)) { - return invokeSalRemoteRpcSubscribeRPC(payload, rpc.getRpcDefinition(), parsePrettyPrintParameter(uriInfo)); + public NormalizedNodeContext invokeRpc(final String identifier, final NormalizedNodeContext payload, final UriInfo uriInfo) { + final SchemaPath type = payload.getInstanceIdentifierContext().getSchemaNode().getPath(); + final URI namespace = payload.getInstanceIdentifierContext().getSchemaNode().getQName().getNamespace(); + final CheckedFuture response; + final DOMMountPoint mountPoint = payload.getInstanceIdentifierContext().getMountPoint(); + final SchemaContext schemaContext; + if (identifier.contains(MOUNT_POINT_MODULE_NAME) && mountPoint != null) { + final Optional mountRpcServices = mountPoint.getService(DOMRpcService.class); + if ( ! mountRpcServices.isPresent()) { + throw new RestconfDocumentedException("Rpc service is missing."); + } + schemaContext = mountPoint.getSchemaContext(); + response = mountRpcServices.get().invokeRpc(type, payload.getData()); + } else { + if (namespace.toString().equals(SAL_REMOTE_NAMESPACE)) { + response = invokeSalRemoteRpcSubscribeRPC(payload); + } else { + response = broker.invokeRpc(type, payload.getData()); + } + schemaContext = controllerContext.getGlobalSchema(); } - validateInput(rpc.getRpcDefinition().getInput(), payload); + final DOMRpcResult result = checkRpcResponse(response); + + RpcDefinition resultNodeSchema = null; + final NormalizedNode resultData = result.getResult(); + if (result != null && result.getResult() != null) { + resultNodeSchema = (RpcDefinition) payload.getInstanceIdentifierContext().getSchemaNode(); + } - return callRpc(rpc, payload, parsePrettyPrintParameter(uriInfo)); + return new NormalizedNodeContext(new InstanceIdentifierContext(null, + resultNodeSchema, mountPoint, schemaContext), resultData); } + private DOMRpcResult checkRpcResponse(final CheckedFuture response) { + if (response == null) { + return null; + } + try { + final DOMRpcResult retValue = response.get(); + if (retValue.getErrors() == null || retValue.getErrors().isEmpty()) { + return retValue; + } + throw new RestconfDocumentedException("RpcError message", null, retValue.getErrors()); + } + catch (final InterruptedException e) { + throw new RestconfDocumentedException( + "The operation was interrupted while executing and did not complete.", ErrorType.RPC, + ErrorTag.PARTIAL_OPERATION); + } + catch (final ExecutionException e) { + Throwable cause = e.getCause(); + if (cause instanceof CancellationException) { + throw new RestconfDocumentedException("The operation was cancelled while executing.", ErrorType.RPC, + ErrorTag.PARTIAL_OPERATION); + } else if (cause != null) { + while (cause.getCause() != null) { + cause = cause.getCause(); + } + + if (cause instanceof IllegalArgumentException) { + throw new RestconfDocumentedException(cause.getMessage(), ErrorType.PROTOCOL, + ErrorTag.INVALID_VALUE); + } + + throw new RestconfDocumentedException("The operation encountered an unexpected error while executing.", + cause); + } else { + throw new RestconfDocumentedException("The operation encountered an unexpected error while executing.", + e); + } + } + } + + private void validateInput(final SchemaNode inputSchema, final NormalizedNodeContext payload) { + if (inputSchema != null && payload.getData() == null) { + // expected a non null payload + throw new RestconfDocumentedException("Input is required.", ErrorType.PROTOCOL, ErrorTag.MALFORMED_MESSAGE); + } else if (inputSchema == null && payload.getData() != null) { + // did not expect any input + throw new RestconfDocumentedException("No input expected.", ErrorType.PROTOCOL, ErrorTag.MALFORMED_MESSAGE); + } + // else + // { + // TODO: Validate "mandatory" and "config" values here??? Or should those be + // those be + // validate in a more central location inside MD-SAL core. + // } + } + + /** + * @deprecated method will be removed for Lithium release + * + * @param inputSchema + * @param payload + */ + @Deprecated private void validateInput(final DataSchemaNode inputSchema, final Node payload) { if (inputSchema != null && payload == null) { // expected a non null payload @@ -503,12 +638,12 @@ public class RestconfImpl implements RestconfService { // } } - private StructuredData invokeSalRemoteRpcSubscribeRPC(final CompositeNode payload, final RpcDefinition rpc, - final boolean prettyPrint) { - final CompositeNode value = this.normalizeNode(payload, rpc.getInput(), null); - final SimpleNode pathNode = value == null ? null : value.getFirstSimpleByName(QName.create( - rpc.getQName(), "path")); - final Object pathValue = pathNode == null ? null : pathNode.getValue(); + private CheckedFuture invokeSalRemoteRpcSubscribeRPC(final NormalizedNodeContext payload) { + final ContainerNode value = (ContainerNode) payload.getData(); + final QName rpcQName = payload.getInstanceIdentifierContext().getSchemaNode().getQName(); + final Optional> path = value.getChild(new NodeIdentifier( + QName.create(payload.getInstanceIdentifierContext().getSchemaNode().getQName(), "path"))); + final Object pathValue = path.isPresent() ? path.get().getValue() : null; if (!(pathValue instanceof YangInstanceIdentifier)) { throw new RestconfDocumentedException("Instance identifier was not normalized correctly.", @@ -518,7 +653,7 @@ public class RestconfImpl implements RestconfService { final YangInstanceIdentifier pathIdentifier = ((YangInstanceIdentifier) pathValue); String streamName = null; if (!Iterables.isEmpty(pathIdentifier.getPathArguments())) { - final String fullRestconfIdentifier = controllerContext.toFullRestconfIdentifier(pathIdentifier); + final String fullRestconfIdentifier = controllerContext.toFullRestconfIdentifier(pathIdentifier, null); LogicalDatastoreType datastore = parseEnumTypeParameter(value, LogicalDatastoreType.class, DATASTORE_PARAM_NAME); @@ -533,31 +668,96 @@ public class RestconfImpl implements RestconfService { if (Strings.isNullOrEmpty(streamName)) { throw new RestconfDocumentedException( - "Path is empty or contains data node which is not Container or List build-in type.", + "Path is empty or contains value node which is not Container or List build-in type.", ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE); } - final SimpleNode streamNameNode = NodeFactory. createImmutableSimpleNode( - QName.create(rpc.getOutput().getQName(), "stream-name"), null, streamName); - final List> output = new ArrayList>(); - output.add(streamNameNode); + final QName outputQname = QName.create(rpcQName, "output"); + final QName streamNameQname = QName.create(rpcQName, "stream-name"); - final MutableCompositeNode responseData = NodeFactory.createMutableCompositeNode(rpc.getOutput().getQName(), - null, output, null, null); + final ContainerNode output = ImmutableContainerNodeBuilder.create().withNodeIdentifier(new NodeIdentifier(outputQname)) + .withChild(ImmutableNodes.leafNode(streamNameQname, streamName)).build(); if (!Notificator.existListenerFor(streamName)) { - Notificator.createListener(pathIdentifier, streamName); + final YangInstanceIdentifier normalizedPathIdentifier = controllerContext.toNormalized(pathIdentifier); + Notificator.createListener(normalizedPathIdentifier, streamName); } - return new StructuredData(responseData, rpc.getOutput(), null, prettyPrint); + final DOMRpcResult defaultDOMRpcResult = new DefaultDOMRpcResult(output); + + return Futures.immediateCheckedFuture(defaultDOMRpcResult); } @Override - public StructuredData invokeRpc(final String identifier, final String noPayload, final UriInfo uriInfo) { + public NormalizedNodeContext invokeRpc(final String identifier, final String noPayload, final UriInfo uriInfo) { if (StringUtils.isNotBlank(noPayload)) { throw new RestconfDocumentedException("Content must be empty.", ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE); } - return invokeRpc(identifier, (CompositeNode) null, uriInfo); + + String identifierEncoded = null; + DOMMountPoint mountPoint = null; + final SchemaContext schemaContext; + if (identifier.contains(ControllerContext.MOUNT)) { + // mounted RPC call - look up mount instance. + final InstanceIdentifierContext mountPointId = controllerContext.toMountPointIdentifier(identifier); + mountPoint = mountPointId.getMountPoint(); + schemaContext = mountPoint.getSchemaContext(); + final int startOfRemoteRpcName = identifier.lastIndexOf(ControllerContext.MOUNT) + + ControllerContext.MOUNT.length() + 1; + final String remoteRpcName = identifier.substring(startOfRemoteRpcName); + identifierEncoded = remoteRpcName; + + } else if (identifier.indexOf("/") != CHAR_NOT_FOUND) { + final String slashErrorMsg = String.format("Identifier %n%s%ncan\'t contain slash " + + "character (/).%nIf slash is part of identifier name then use %%2F placeholder.", identifier); + throw new RestconfDocumentedException(slashErrorMsg, ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE); + } else { + identifierEncoded = identifier; + schemaContext = controllerContext.getGlobalSchema(); + } + + final String identifierDecoded = controllerContext.urlPathArgDecode(identifierEncoded); + + RpcDefinition rpc = null; + if (mountPoint == null) { + rpc = controllerContext.getRpcDefinition(identifierDecoded); + } else { + rpc = findRpc(mountPoint.getSchemaContext(), identifierDecoded); + } + + if (rpc == null) { + throw new RestconfDocumentedException("RPC does not exist.", ErrorType.RPC, ErrorTag.UNKNOWN_ELEMENT); + } + + if (rpc.getInput() != null) { + // FIXME : find a correct Error from specification + throw new IllegalStateException("RPC " + rpc + " does'n need input value!"); + } + + final CheckedFuture response; + if (mountPoint != null) { + final Optional mountRpcServices = mountPoint.getService(DOMRpcService.class); + if ( ! mountRpcServices.isPresent()) { + throw new RestconfDocumentedException("Rpc service is missing."); + } + response = mountRpcServices.get().invokeRpc(rpc.getPath(), null); + } else { + response = broker.invokeRpc(rpc.getPath(), null); + } + + final DOMRpcResult result = checkRpcResponse(response); + + DataSchemaNode resultNodeSchema = null; + NormalizedNode resultData = null; + if (result != null && result.getResult() != null) { + resultData = result.getResult(); + final ContainerSchemaNode rpcDataSchemaNode = + SchemaContextUtil.getRpcDataSchema(schemaContext, rpc.getOutput().getPath()); + resultNodeSchema = rpcDataSchemaNode.getDataChildByName(result.getResult().getNodeType()); + } + + return new NormalizedNodeContext(new InstanceIdentifierContext(null, resultNodeSchema, mountPoint, + schemaContext), resultData); } private RpcExecutor resolveIdentifierInInvokeRpc(final String identifier) { @@ -621,6 +821,10 @@ public class RestconfImpl implements RestconfService { return null; } + /** + * @deprecated method will be removed for Lithium release + */ + @Deprecated private StructuredData callRpc(final RpcExecutor rpcExecutor, final CompositeNode payload, final boolean prettyPrint) { if (rpcExecutor == null) { throw new RestconfDocumentedException("RPC does not exist.", ErrorType.RPC, ErrorTag.UNKNOWN_ELEMENT); @@ -666,15 +870,17 @@ public class RestconfImpl implements RestconfService { final InstanceIdentifierContext iiWithData = controllerContext.toInstanceIdentifier(identifier); final DOMMountPoint mountPoint = iiWithData.getMountPoint(); NormalizedNode data = null; - YangInstanceIdentifier normalizedII; + final YangInstanceIdentifier normalizedII = iiWithData.getInstanceIdentifier(); if (mountPoint != null) { - normalizedII = new DataNormalizer(mountPoint.getSchemaContext()).toNormalized(iiWithData - .getInstanceIdentifier()); data = broker.readConfigurationData(mountPoint, normalizedII); } else { - normalizedII = controllerContext.toNormalized(iiWithData.getInstanceIdentifier()); data = broker.readConfigurationData(normalizedII); } + if(data == null) { + throw new RestconfDocumentedException( + "Request could not be completed because the relevant data model content does not exist.", + ErrorType.APPLICATION, ErrorTag.DATA_MISSING); + } return new NormalizedNodeContext(iiWithData, data); } @@ -725,16 +931,17 @@ public class RestconfImpl implements RestconfService { final InstanceIdentifierContext iiWithData = controllerContext.toInstanceIdentifier(identifier); final DOMMountPoint mountPoint = iiWithData.getMountPoint(); NormalizedNode data = null; - YangInstanceIdentifier normalizedII; + final YangInstanceIdentifier normalizedII = iiWithData.getInstanceIdentifier(); if (mountPoint != null) { - normalizedII = new DataNormalizer(mountPoint.getSchemaContext()).toNormalized(iiWithData - .getInstanceIdentifier()); data = broker.readOperationalData(mountPoint, normalizedII); } else { - normalizedII = controllerContext.toNormalized(iiWithData.getInstanceIdentifier()); data = broker.readOperationalData(normalizedII); } - + if(data == null) { + throw new RestconfDocumentedException( + "Request could not be completed because the relevant data model content does not exist.", + ErrorType.APPLICATION, ErrorTag.DATA_MISSING); + } return new NormalizedNodeContext(iiWithData, data); } @@ -744,26 +951,17 @@ public class RestconfImpl implements RestconfService { } @Override - public Response updateConfigurationData(final String identifier, final Node payload) { - final InstanceIdentifierContext iiWithData = controllerContext.toInstanceIdentifier(identifier); + public Response updateConfigurationData(final String identifier, final NormalizedNodeContext payload) { + Preconditions.checkNotNull(identifier); + final InstanceIdentifierContext iiWithData = + (InstanceIdentifierContext) payload.getInstanceIdentifierContext(); validateInput(iiWithData.getSchemaNode(), payload); - - final DOMMountPoint mountPoint = iiWithData.getMountPoint(); validateTopLevelNodeName(payload, iiWithData.getInstanceIdentifier()); - final CompositeNode value = this.normalizeNode(payload, iiWithData.getSchemaNode(), mountPoint); - validateListKeysEqualityInPayloadAndUri(iiWithData, value); - final NormalizedNode datastoreNormalizedNode = compositeNodeToDatastoreNormalizedNode(value, - iiWithData.getSchemaNode()); + validateListKeysEqualityInPayloadAndUri(iiWithData, payload.getData()); - - YangInstanceIdentifier normalizedII; - if (mountPoint != null) { - normalizedII = new DataNormalizer(mountPoint.getSchemaContext()).toNormalized( - iiWithData.getInstanceIdentifier()); - } else { - normalizedII = controllerContext.toNormalized(iiWithData.getInstanceIdentifier()); - } + final DOMMountPoint mountPoint = iiWithData.getMountPoint(); + final YangInstanceIdentifier normalizedII = iiWithData.getInstanceIdentifier(); /* * There is a small window where another write transaction could be updating the same data @@ -782,11 +980,9 @@ public class RestconfImpl implements RestconfService { while(true) { try { if (mountPoint != null) { - broker.commitConfigurationDataPut(mountPoint, normalizedII, - datastoreNormalizedNode).checkedGet(); + broker.commitConfigurationDataPut(mountPoint, normalizedII, payload.getData()).checkedGet(); } else { - broker.commitConfigurationDataPut(normalizedII, - datastoreNormalizedNode).checkedGet(); + broker.commitConfigurationDataPut(normalizedII, payload.getData()).checkedGet(); } break; @@ -807,6 +1003,37 @@ public class RestconfImpl implements RestconfService { return Response.status(Status.OK).build(); } + private void validateTopLevelNodeName(final NormalizedNodeContext node, + final YangInstanceIdentifier identifier) { + + final String payloadName = node.getData().getNodeType().getLocalName(); + final Iterator pathArguments = identifier.getReversePathArguments().iterator(); + + //no arguments + if ( ! pathArguments.hasNext()) { + //no "data" payload + if ( ! node.getData().getNodeType().equals(NETCONF_BASE_QNAME)) { + throw new RestconfDocumentedException("Instance identifier has to contain at least one path argument", + ErrorType.PROTOCOL, ErrorTag.MALFORMED_MESSAGE); + } + //any arguments + } else { + final String identifierName = pathArguments.next().getNodeType().getLocalName(); + if ( ! payloadName.equals(identifierName)) { + throw new RestconfDocumentedException("Payload name (" + payloadName + + ") is different from identifier name (" + identifierName + ")", ErrorType.PROTOCOL, + ErrorTag.MALFORMED_MESSAGE); + } + } + } + + /** + * @deprecated method will be removed for Lithium release + * + * @param node + * @param identifier + */ + @Deprecated private void validateTopLevelNodeName(final Node node, final YangInstanceIdentifier identifier) { final String payloadName = getName(node); @@ -837,6 +1064,29 @@ public class RestconfImpl implements RestconfService { * if key values or key count in payload and URI isn't equal * */ + private void validateListKeysEqualityInPayloadAndUri(final InstanceIdentifierContext iiWithData, + final NormalizedNode payload) { + if (iiWithData.getSchemaNode() instanceof ListSchemaNode) { + final List keyDefinitions = ((ListSchemaNode) iiWithData.getSchemaNode()).getKeyDefinition(); + final PathArgument lastPathArgument = iiWithData.getInstanceIdentifier().getLastPathArgument(); + if (lastPathArgument instanceof NodeIdentifierWithPredicates) { + final Map uriKeyValues = ((NodeIdentifierWithPredicates) lastPathArgument) + .getKeyValues(); + isEqualUriAndPayloadKeyValues(uriKeyValues, payload, keyDefinitions); + } + } + } + + /** + * @deprecated method will be removed for Lithium release + * + * Validates whether keys in {@code payload} are equal to values of keys in {@code iiWithData} for list schema node + * + * @throws RestconfDocumentedException + * if key values or key count in payload and URI isn't equal + * + */ + @Deprecated private void validateListKeysEqualityInPayloadAndUri(final InstanceIdentifierContext iiWithData, final CompositeNode payload) { if (iiWithData.getSchemaNode() instanceof ListSchemaNode) { @@ -850,6 +1100,39 @@ public class RestconfImpl implements RestconfService { } } + private void isEqualUriAndPayloadKeyValues(final Map uriKeyValues, final NormalizedNode payload, + final List keyDefinitions) { + for (final QName keyDefinition : keyDefinitions) { + final Object uriKeyValue = uriKeyValues.get(keyDefinition); + // should be caught during parsing URI to InstanceIdentifier + if (uriKeyValue == null) { + final String errMsg = "Missing key " + keyDefinition + " in URI."; + throw new RestconfDocumentedException(errMsg, ErrorType.PROTOCOL, ErrorTag.DATA_MISSING); + } + // TODO thing about the possibility to fix +// final List> payloadKeyValues = payload.getSimpleNodesByName(keyDefinition.getLocalName()); +// if (payloadKeyValues.isEmpty()) { +// final String errMsg = "Missing key " + keyDefinition.getLocalName() + " in the message body."; +// throw new RestconfDocumentedException(errMsg, ErrorType.PROTOCOL, ErrorTag.DATA_MISSING); +// } +// +// final Object payloadKeyValue = payloadKeyValues.iterator().next().getValue(); +// if (!uriKeyValue.equals(payloadKeyValue)) { +// final String errMsg = "The value '" + uriKeyValue + "' for key '" + keyDefinition.getLocalName() + +// "' specified in the URI doesn't match the value '" + payloadKeyValue + "' specified in the message body. "; +// throw new RestconfDocumentedException(errMsg, ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE); +// } + } + } + + /** + * @deprecated method will be removed for Lithium release + * + * @param uriKeyValues + * @param payload + * @param keyDefinitions + */ + @Deprecated private void isEqualUriAndPayloadKeyValues(final Map uriKeyValues, final CompositeNode payload, final List keyDefinitions) { for (final QName keyDefinition : keyDefinitions) { @@ -876,104 +1159,63 @@ public class RestconfImpl implements RestconfService { } @Override - public Response createConfigurationData(final String identifier, final Node payload) { - if (payload == null) { - throw new RestconfDocumentedException("Input is required.", ErrorType.PROTOCOL, ErrorTag.MALFORMED_MESSAGE); - } - - final URI payloadNS = namespace(payload); - if (payloadNS == null) { - throw new RestconfDocumentedException( - "Data has bad format. Root element node must have namespace (XML format) or module name(JSON format)", - ErrorType.PROTOCOL, ErrorTag.UNKNOWN_NAMESPACE); - } - - InstanceIdentifierContext iiWithData = null; - CompositeNode value = null; - if (representsMountPointRootData(payload)) { - // payload represents mount point data and URI represents path to the mount point - - if (endsWithMountPoint(identifier)) { - throw new RestconfDocumentedException("URI has bad format. URI should be without \"" - + ControllerContext.MOUNT + "\" for POST operation.", ErrorType.PROTOCOL, - ErrorTag.INVALID_VALUE); + public Response createConfigurationData(final String identifier, final NormalizedNodeContext payload, final UriInfo uriInfo) { + return createConfigurationData(payload, uriInfo); + } + + // FIXME create RestconfIdetifierHelper and move this method there + private YangInstanceIdentifier checkConsistencyOfNormalizedNodeContext(final NormalizedNodeContext payload) { + Preconditions.checkArgument(payload != null); + Preconditions.checkArgument(payload.getData() != null); + Preconditions.checkArgument(payload.getData().getNodeType() != null); + Preconditions.checkArgument(payload.getInstanceIdentifierContext() != null); + Preconditions.checkArgument(payload.getInstanceIdentifierContext().getInstanceIdentifier() != null); + + final QName payloadNodeQname = payload.getData().getNodeType(); + final YangInstanceIdentifier yangIdent = payload.getInstanceIdentifierContext().getInstanceIdentifier(); + if (payloadNodeQname.compareTo(yangIdent.getLastPathArgument().getNodeType()) > 0) { + return yangIdent; + } + final InstanceIdentifierContext parentContext = payload.getInstanceIdentifierContext(); + final SchemaNode parentSchemaNode = parentContext.getSchemaNode(); + if(parentSchemaNode instanceof DataNodeContainer) { + final DataNodeContainer cast = (DataNodeContainer) parentSchemaNode; + for (final DataSchemaNode child : cast.getChildNodes()) { + if (payloadNodeQname.compareTo(child.getQName()) == 0) { + return YangInstanceIdentifier.builder(yangIdent).node(child.getQName()).build(); + } } - - final String completeIdentifier = addMountPointIdentifier(identifier); - iiWithData = controllerContext.toInstanceIdentifier(completeIdentifier); - - value = this.normalizeNode(payload, iiWithData.getSchemaNode(), iiWithData.getMountPoint()); - } else { - final InstanceIdentifierContext incompleteInstIdWithData = controllerContext - .toInstanceIdentifier(identifier); - final DataNodeContainer parentSchema = (DataNodeContainer) incompleteInstIdWithData.getSchemaNode(); - final DOMMountPoint mountPoint = incompleteInstIdWithData.getMountPoint(); - final Module module = findModule(mountPoint, payload); - - final String payloadName = getName(payload); - final DataSchemaNode schemaNode = ControllerContext.findInstanceDataChildByNameAndNamespace( - parentSchema, payloadName, module.getNamespace()); - value = this.normalizeNode(payload, schemaNode, mountPoint); - - iiWithData = addLastIdentifierFromData(incompleteInstIdWithData, value, schemaNode,incompleteInstIdWithData.getSchemaContext()); } - - final NormalizedNode datastoreNormalizedData = compositeNodeToDatastoreNormalizedNode(value, - iiWithData.getSchemaNode()); - final DOMMountPoint mountPoint = iiWithData.getMountPoint(); - YangInstanceIdentifier normalizedII; - - try { - if (mountPoint != null) { - normalizedII = new DataNormalizer(mountPoint.getSchemaContext()).toNormalized(iiWithData - .getInstanceIdentifier()); - broker.commitConfigurationDataPost(mountPoint, normalizedII, datastoreNormalizedData); - } else { - normalizedII = controllerContext.toNormalized(iiWithData.getInstanceIdentifier()); - broker.commitConfigurationDataPost(normalizedII, datastoreNormalizedData); - } - } catch(final RestconfDocumentedException e) { - throw e; - } catch (final Exception e) { - throw new RestconfDocumentedException("Error creating data", e); + if (parentSchemaNode instanceof RpcDefinition) { + return yangIdent; } - - return Response.status(Status.NO_CONTENT).build(); + final String errMsg = "Error parsing input: DataSchemaNode has not children"; + throw new RestconfDocumentedException(errMsg, ErrorType.PROTOCOL, ErrorTag.MALFORMED_MESSAGE); } @Override - public Response createConfigurationData(final Node payload) { + public Response createConfigurationData(final NormalizedNodeContext payload, final UriInfo uriInfo) { if (payload == null) { throw new RestconfDocumentedException("Input is required.", ErrorType.PROTOCOL, ErrorTag.MALFORMED_MESSAGE); } - final URI payloadNS = namespace(payload); + final URI payloadNS = payload.getData().getNodeType().getNamespace(); if (payloadNS == null) { throw new RestconfDocumentedException( "Data has bad format. Root element node must have namespace (XML format) or module name(JSON format)", ErrorType.PROTOCOL, ErrorTag.UNKNOWN_NAMESPACE); } - final Module module = this.findModule(null, payload); - - final String payloadName = getName(payload); - final DataSchemaNode schemaNode = ControllerContext.findInstanceDataChildByNameAndNamespace(module, - payloadName, module.getNamespace()); - final CompositeNode value = this.normalizeNode(payload, schemaNode, null); - final InstanceIdentifierContext iiWithData = addLastIdentifierFromData(null, value, schemaNode,ControllerContext.getInstance().getGlobalSchema()); - final NormalizedNode datastoreNormalizedData = compositeNodeToDatastoreNormalizedNode(value, schemaNode); - final DOMMountPoint mountPoint = iiWithData.getMountPoint(); - YangInstanceIdentifier normalizedII; - + final DOMMountPoint mountPoint = payload.getInstanceIdentifierContext().getMountPoint(); + final InstanceIdentifierContext iiWithData = (InstanceIdentifierContext) payload.getInstanceIdentifierContext(); + final YangInstanceIdentifier normalizedII = iiWithData.getInstanceIdentifier(); + final YangInstanceIdentifier resultII; try { if (mountPoint != null) { - normalizedII = new DataNormalizer(mountPoint.getSchemaContext()).toNormalized(iiWithData - .getInstanceIdentifier()); - broker.commitConfigurationDataPost(mountPoint, normalizedII, datastoreNormalizedData); + broker.commitConfigurationDataPost(mountPoint, normalizedII, payload.getData()); } else { - normalizedII = controllerContext.toNormalized(iiWithData.getInstanceIdentifier()); - broker.commitConfigurationDataPost(normalizedII, datastoreNormalizedData); + broker.commitConfigurationDataPost(normalizedII, payload.getData()); } } catch(final RestconfDocumentedException e) { throw e; @@ -981,22 +1223,37 @@ public class RestconfImpl implements RestconfService { throw new RestconfDocumentedException("Error creating data", e); } - return Response.status(Status.NO_CONTENT).build(); + final ResponseBuilder responseBuilder = Response.status(Status.NO_CONTENT); + // FIXME: Provide path to result. + final URI location = resolveLocation(uriInfo, "", mountPoint, normalizedII); + if (location != null) { + responseBuilder.location(location); + } + return responseBuilder.build(); + } + + private URI resolveLocation(final UriInfo uriInfo, final String uriBehindBase, final DOMMountPoint mountPoint, final YangInstanceIdentifier normalizedII) { + final UriBuilder uriBuilder = uriInfo.getBaseUriBuilder(); + uriBuilder.path("config"); + try { + uriBuilder.path(controllerContext.toFullRestconfIdentifier(normalizedII, mountPoint)); + } catch (final Exception e) { + LOG.debug("Location for instance identifier"+normalizedII+"wasn't created", e); + return null; + } + return uriBuilder.build(); } @Override public Response deleteConfigurationData(final String identifier) { - final InstanceIdentifierContext iiWithData = controllerContext.toInstanceIdentifier(identifier); + final InstanceIdentifierContext iiWithData = controllerContext.toInstanceIdentifier(identifier); final DOMMountPoint mountPoint = iiWithData.getMountPoint(); - YangInstanceIdentifier normalizedII; + final YangInstanceIdentifier normalizedII = iiWithData.getInstanceIdentifier(); try { if (mountPoint != null) { - normalizedII = new DataNormalizer(mountPoint.getSchemaContext()).toNormalized(iiWithData - .getInstanceIdentifier()); broker.commitConfigurationDataDelete(mountPoint, normalizedII); } else { - normalizedII = controllerContext.toNormalized(iiWithData.getInstanceIdentifier()); broker.commitConfigurationDataDelete(normalizedII).get(); } } catch (final Exception e) { @@ -1054,8 +1311,8 @@ public class RestconfImpl implements RestconfService { } catch (final NullPointerException e) { WebSocketServer.createInstance(NOTIFICATION_PORT); } - final UriBuilder port = uriBuilder.port(notificationPort); - final URI uriToWebsocketServer = port.replacePath(streamName).build(); + final UriBuilder uriToWebsocketServerBuilder = uriBuilder.port(notificationPort).scheme("ws"); + final URI uriToWebsocketServer = uriToWebsocketServerBuilder.replacePath(streamName).build(); return Response.status(Status.OK).location(uriToWebsocketServer).build(); } @@ -1067,15 +1324,16 @@ public class RestconfImpl implements RestconfService { * contains value * @return enum object if its string value is equal to {@code paramName}. In other cases null. */ - private T parseEnumTypeParameter(final CompositeNode compNode, final Class classDescriptor, + private T parseEnumTypeParameter(final ContainerNode value, final Class classDescriptor, final String paramName) { final QNameModule salRemoteAugment = QNameModule.create(NAMESPACE_EVENT_SUBSCRIPTION_AUGMENT, EVENT_SUBSCRIPTION_AUGMENT_REVISION); - final SimpleNode simpleNode = compNode.getFirstSimpleByName(QName.create(salRemoteAugment, paramName)); - if (simpleNode == null) { + final Optional> enumNode = value.getChild(new NodeIdentifier( + QName.create(salRemoteAugment, paramName))); + if (!enumNode.isPresent()) { return null; } - final Object rawValue = simpleNode.getValue(); + final Object rawValue = enumNode.get().getValue(); if (!(rawValue instanceof String)) { return null; } @@ -1230,7 +1488,7 @@ public class RestconfImpl implements RestconfService { * || MOUNT_POINT_MODULE_NAME .equals( namespace . * toString( ) ) */) - && SchemaContext.NAME.getLocalName().equals(localName(data)); + && SchemaContext.NAME.getLocalName().equals(localName(data)); } private String addMountPointIdentifier(final String identifier) { @@ -1242,7 +1500,12 @@ public class RestconfImpl implements RestconfService { return identifier + "/" + ControllerContext.MOUNT; } - private CompositeNode normalizeNode(final Node node, final DataSchemaNode schema, final DOMMountPoint mountPoint) { + /** + * @deprecated method will be removed in Lithium release + * we don't wish to use Node and CompositeNode anywhere + */ + @Deprecated + public CompositeNode normalizeNode(final Node node, final DataSchemaNode schema, final DOMMountPoint mountPoint) { if (schema == null) { final String localName = node == null ? null : node instanceof NodeWrapper ? ((NodeWrapper)node).getLocalName() : @@ -1515,6 +1778,13 @@ public class RestconfImpl implements RestconfService { } } + /** + * @deprecated method will be removed for Lithium release + * + * @param data + * @return + */ + @Deprecated private String getName(final Node data) { if (data instanceof NodeWrapper) { return ((NodeWrapper) data).getLocalName(); @@ -1661,6 +1931,90 @@ public class RestconfImpl implements RestconfService { protected MapEntryNode toModuleEntryNode(final Module module, final DataSchemaNode moduleSchemaNode) { Preconditions.checkArgument(moduleSchemaNode instanceof ListSchemaNode, - "moduleSchemaNode has to be of type ListSchemaNode"); final ListSchemaNode listModuleSchemaNode = (ListSchemaNode) moduleSchemaNode; final DataContainerNodeAttrBuilder moduleNodeValues = Builders .mapEntryBuilder(listModuleSchemaNode); List instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( (listModuleSchemaNode), "name"); final DataSchemaNode nameSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); Preconditions.checkState(nameSchemaNode instanceof LeafSchemaNode); moduleNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) nameSchemaNode).withValue(module.getName()) .build()); instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( (listModuleSchemaNode), "revision"); final DataSchemaNode revisionSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); Preconditions.checkState(revisionSchemaNode instanceof LeafSchemaNode); final String revision = REVISION_FORMAT.format(module.getRevision()); moduleNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) revisionSchemaNode).withValue(revision) .build()); instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( (listModuleSchemaNode), "namespace"); final DataSchemaNode namespaceSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); Preconditions.checkState(namespaceSchemaNode instanceof LeafSchemaNode); moduleNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) namespaceSchemaNode) .withValue(module.getNamespace().toString()).build()); instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( (listModuleSchemaNode), "feature"); final DataSchemaNode featureSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); Preconditions.checkState(featureSchemaNode instanceof LeafListSchemaNode); final ListNodeBuilder> featuresBuilder = Builders .leafSetBuilder((LeafListSchemaNode) featureSchemaNode); for (final FeatureDefinition feature : module.getFeatures()) { featuresBuilder.withChild(Builders.leafSetEntryBuilder(((LeafListSchemaNode) featureSchemaNode)) .withValue(feature.getQName().getLocalName()).build()); } moduleNodeValues.withChild(featuresBuilder.build()); - return moduleNodeValues.build(); } + "moduleSchemaNode has to be of type ListSchemaNode"); + final ListSchemaNode listModuleSchemaNode = (ListSchemaNode) moduleSchemaNode; + final DataContainerNodeAttrBuilder moduleNodeValues = Builders + .mapEntryBuilder(listModuleSchemaNode); + + List instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listModuleSchemaNode), "name"); + final DataSchemaNode nameSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(nameSchemaNode instanceof LeafSchemaNode); + moduleNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) nameSchemaNode).withValue(module.getName()) + .build()); + + instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listModuleSchemaNode), "revision"); + final DataSchemaNode revisionSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(revisionSchemaNode instanceof LeafSchemaNode); + final String revision = REVISION_FORMAT.format(module.getRevision()); + moduleNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) revisionSchemaNode).withValue(revision) + .build()); + + instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listModuleSchemaNode), "namespace"); + final DataSchemaNode namespaceSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(namespaceSchemaNode instanceof LeafSchemaNode); + moduleNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) namespaceSchemaNode) + .withValue(module.getNamespace().toString()).build()); + + instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listModuleSchemaNode), "feature"); + final DataSchemaNode featureSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(featureSchemaNode instanceof LeafListSchemaNode); + final ListNodeBuilder> featuresBuilder = Builders + .leafSetBuilder((LeafListSchemaNode) featureSchemaNode); + for (final FeatureDefinition feature : module.getFeatures()) { + featuresBuilder.withChild(Builders.leafSetEntryBuilder(((LeafListSchemaNode) featureSchemaNode)) + .withValue(feature.getQName().getLocalName()).build()); + } + moduleNodeValues.withChild(featuresBuilder.build()); + + return moduleNodeValues.build(); + } + + protected MapEntryNode toStreamEntryNode(final String streamName, final DataSchemaNode streamSchemaNode) { + Preconditions.checkArgument(streamSchemaNode instanceof ListSchemaNode, + "streamSchemaNode has to be of type ListSchemaNode"); + final ListSchemaNode listStreamSchemaNode = (ListSchemaNode) streamSchemaNode; + final DataContainerNodeAttrBuilder streamNodeValues = Builders + .mapEntryBuilder(listStreamSchemaNode); + + List instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listStreamSchemaNode), "name"); + final DataSchemaNode nameSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(nameSchemaNode instanceof LeafSchemaNode); + streamNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) nameSchemaNode).withValue(streamName) + .build()); + + instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listStreamSchemaNode), "description"); + final DataSchemaNode descriptionSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(descriptionSchemaNode instanceof LeafSchemaNode); + streamNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) nameSchemaNode) + .withValue("DESCRIPTION_PLACEHOLDER").build()); + + instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listStreamSchemaNode), "replay-support"); + final DataSchemaNode replaySupportSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(replaySupportSchemaNode instanceof LeafSchemaNode); + streamNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) replaySupportSchemaNode) + .withValue(Boolean.valueOf(true)).build()); + + instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listStreamSchemaNode), "replay-log-creation-time"); + final DataSchemaNode replayLogCreationTimeSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(replayLogCreationTimeSchemaNode instanceof LeafSchemaNode); + streamNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) replayLogCreationTimeSchemaNode) + .withValue("").build()); + + instanceDataChildrenByName = ControllerContext.findInstanceDataChildrenByName( + (listStreamSchemaNode), "events"); + final DataSchemaNode eventsSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null); + Preconditions.checkState(eventsSchemaNode instanceof LeafSchemaNode); + streamNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) eventsSchemaNode) + .withValue("").build()); + + return streamNodeValues.build(); + } }