Fix findbugs violations in restconf-nb-bierman02
[netconf.git] / restconf / restconf-nb-bierman02 / src / main / java / org / opendaylight / netconf / sal / restconf / impl / RestconfImpl.java
index 99200cb845f8d1c3aba750a9c7b9c8de5ed15653..5576469c14f1c71c7208c382329a1c3c0b15645e 100644 (file)
@@ -18,18 +18,17 @@ import com.google.common.base.Strings;
 import com.google.common.base.Throwables;
 import com.google.common.collect.ImmutableSet;
 import com.google.common.collect.Iterables;
-import com.google.common.collect.Lists;
 import com.google.common.collect.Maps;
 import com.google.common.util.concurrent.CheckedFuture;
 import com.google.common.util.concurrent.Futures;
 import java.net.URI;
-import java.text.ParseException;
 import java.time.Instant;
 import java.time.format.DateTimeFormatter;
 import java.time.format.DateTimeFormatterBuilder;
 import java.time.format.DateTimeParseException;
 import java.time.temporal.ChronoField;
 import java.time.temporal.TemporalAccessor;
+import java.util.AbstractMap.SimpleImmutableEntry;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.Collections;
@@ -76,7 +75,7 @@ import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.yang.types.
 import org.opendaylight.yang.gen.v1.urn.sal.restconf.event.subscription.rev140708.NotificationOutputTypeGrouping.NotificationOutputType;
 import org.opendaylight.yangtools.yang.common.QName;
 import org.opendaylight.yangtools.yang.common.QNameModule;
-import org.opendaylight.yangtools.yang.common.SimpleDateFormatUtil;
+import org.opendaylight.yangtools.yang.common.Revision;
 import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
 import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.AugmentationIdentifier;
 import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.NodeIdentifier;
@@ -101,7 +100,6 @@ import org.opendaylight.yangtools.yang.data.impl.schema.builder.api.NormalizedNo
 import org.opendaylight.yangtools.yang.data.impl.schema.builder.impl.ImmutableContainerNodeBuilder;
 import org.opendaylight.yangtools.yang.data.impl.schema.builder.impl.ImmutableLeafNodeBuilder;
 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.FeatureDefinition;
 import org.opendaylight.yangtools.yang.model.api.LeafListSchemaNode;
@@ -117,7 +115,7 @@ import org.opendaylight.yangtools.yang.model.util.SimpleSchemaContext;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class RestconfImpl implements RestconfService {
+public final class RestconfImpl implements RestconfService {
 
     private static final RestconfImpl INSTANCE = new RestconfImpl();
 
@@ -148,19 +146,11 @@ public class RestconfImpl implements RestconfService {
 
     private static final String NETCONF_BASE_PAYLOAD_NAME = "data";
 
-    private static final QName NETCONF_BASE_QNAME = QName.create(QNameModule.create(URI.create(NETCONF_BASE), null),
+    private static final QName NETCONF_BASE_QNAME = QName.create(QNameModule.create(URI.create(NETCONF_BASE)),
         NETCONF_BASE_PAYLOAD_NAME).intern();
 
-    private static final QNameModule SAL_REMOTE_AUGMENT;
-
-    static {
-        try {
-            SAL_REMOTE_AUGMENT = QNameModule.create(NAMESPACE_EVENT_SUBSCRIPTION_AUGMENT,
-                SimpleDateFormatUtil.getRevisionFormat().parse("2014-07-08"));
-        } catch (final ParseException e) {
-            throw new ExceptionInInitializerError(e);
-        }
-    }
+    private static final QNameModule SAL_REMOTE_AUGMENT = QNameModule.create(NAMESPACE_EVENT_SUBSCRIPTION_AUGMENT,
+        Revision.of("2014-07-08"));
 
     private static final AugmentationIdentifier SAL_REMOTE_AUG_IDENTIFIER =
             new AugmentationIdentifier(ImmutableSet.of(
@@ -259,7 +249,7 @@ public class RestconfImpl implements RestconfService {
     @Override
     public NormalizedNodeContext getModule(final String identifier, final UriInfo uriInfo) {
         Preconditions.checkNotNull(identifier);
-        final QName moduleNameAndRevision = getModuleNameAndRevision(identifier);
+        final Entry<String, Revision> nameRev = getModuleNameAndRevision(identifier);
         Module module = null;
         DOMMountPoint mountPoint = null;
         final SchemaContext schemaContext;
@@ -267,16 +257,17 @@ public class RestconfImpl implements RestconfService {
             final InstanceIdentifierContext<?> mountPointIdentifier =
                     this.controllerContext.toMountPointIdentifier(identifier);
             mountPoint = mountPointIdentifier.getMountPoint();
-            module = this.controllerContext.findModuleByNameAndRevision(mountPoint, moduleNameAndRevision);
+            module = this.controllerContext.findModuleByNameAndRevision(mountPoint, nameRev.getKey(),
+                nameRev.getValue());
             schemaContext = mountPoint.getSchemaContext();
         } else {
-            module = this.controllerContext.findModuleByNameAndRevision(moduleNameAndRevision);
+            module = this.controllerContext.findModuleByNameAndRevision(nameRev.getKey(), nameRev.getValue());
             schemaContext = this.controllerContext.getGlobalSchema();
         }
 
         if (module == null) {
-            final String errMsg = "Module with name '" + moduleNameAndRevision.getLocalName() + "' and revision '"
-                    + moduleNameAndRevision.getRevision() + "' was not found.";
+            final String errMsg = "Module with name '" + nameRev.getKey() + "' and revision '"
+                    + nameRev.getValue() + "' was not found.";
             LOG.debug(errMsg);
             throw new RestconfDocumentedException(errMsg, ErrorType.PROTOCOL, ErrorTag.UNKNOWN_ELEMENT);
         }
@@ -407,7 +398,7 @@ public class RestconfImpl implements RestconfService {
         return restconfModule;
     }
 
-    private static QName getModuleNameAndRevision(final String identifier) {
+    private static Entry<String, Revision> getModuleNameAndRevision(final String identifier) {
         final int mountIndex = identifier.indexOf(ControllerContext.MOUNT);
         String moduleNameAndRevision = "";
         if (mountIndex >= 0) {
@@ -416,9 +407,8 @@ public class RestconfImpl implements RestconfService {
             moduleNameAndRevision = identifier;
         }
 
-        final Splitter splitter = Splitter.on("/").omitEmptyStrings();
-        final Iterable<String> split = splitter.split(moduleNameAndRevision);
-        final List<String> pathArgs = Lists.<String>newArrayList(split);
+        final Splitter splitter = Splitter.on('/').omitEmptyStrings();
+        final List<String> pathArgs = splitter.splitToList(moduleNameAndRevision);
         if (pathArgs.size() < 2) {
             LOG.debug("URI has bad format. It should be \'moduleName/yyyy-MM-dd\' " + identifier);
             throw new RestconfDocumentedException(
@@ -427,13 +417,11 @@ public class RestconfImpl implements RestconfService {
         }
 
         try {
-            final String moduleName = pathArgs.get(0);
-            final String revision = pathArgs.get(1);
-            return QName.create(null, SimpleDateFormatUtil.getRevisionFormat().parse(revision), moduleName);
-        } catch (final ParseException e) {
+            return new SimpleImmutableEntry<>(pathArgs.get(0), Revision.of(pathArgs.get(1)));
+        } catch (final DateTimeParseException e) {
             LOG.debug("URI has bad format. It should be \'moduleName/yyyy-MM-dd\' " + identifier);
             throw new RestconfDocumentedException("URI has bad format. It should be \'moduleName/yyyy-MM-dd\'",
-                    ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE);
+                    ErrorType.PROTOCOL, ErrorTag.INVALID_VALUE, e);
         }
     }
 
@@ -479,9 +467,12 @@ public class RestconfImpl implements RestconfService {
         final DOMRpcResult result = checkRpcResponse(response);
 
         RpcDefinition resultNodeSchema = null;
-        final NormalizedNode<?, ?> resultData = result.getResult();
+        final NormalizedNode<?, ?> resultData;
         if (result != null && result.getResult() != null) {
+            resultData = result.getResult();
             resultNodeSchema = (RpcDefinition) payload.getInstanceIdentifierContext().getSchemaNode();
+        } else {
+            resultData = null;
         }
 
         return new NormalizedNodeContext(
@@ -524,7 +515,7 @@ public class RestconfImpl implements RestconfService {
 
         RpcDefinition rpc = null;
         if (mountPoint == null) {
-            rpc = this.controllerContext.getRpcDefinition(identifierDecoded, null);
+            rpc = this.controllerContext.getRpcDefinition(identifierDecoded);
         } else {
             rpc = findRpc(mountPoint.getSchemaContext(), identifierDecoded);
         }
@@ -536,8 +527,8 @@ public class RestconfImpl implements RestconfService {
 
         if (!rpc.getInput().getChildNodes().isEmpty()) {
             LOG.debug("RPC " + rpc + " does not need input value.");
-            // FIXME : find a correct Error from specification
-            throw new IllegalStateException("RPC " + rpc + " does'n need input value!");
+            throw new RestconfDocumentedException("RPC " + rpc + " does not take any input value.",
+                    ErrorType.RPC, ErrorTag.INVALID_VALUE);
         }
 
         final CheckedFuture<DOMRpcResult, DOMRpcException> response;
@@ -557,13 +548,14 @@ public class RestconfImpl implements RestconfService {
                 result.getResult(), QueryParametersParser.parseWriterParameters(uriInfo));
     }
 
+    @SuppressWarnings("checkstyle:avoidHidingCauseException")
     private static DOMRpcResult checkRpcResponse(final CheckedFuture<DOMRpcResult, DOMRpcException> response) {
         if (response == null) {
             return null;
         }
         try {
             final DOMRpcResult retValue = response.get();
-            if (retValue.getErrors() == null || retValue.getErrors().isEmpty()) {
+            if (retValue.getErrors().isEmpty()) {
                 return retValue;
             }
             LOG.debug("RpcError message", retValue.getErrors());
@@ -571,7 +563,7 @@ public class RestconfImpl implements RestconfService {
         } catch (final InterruptedException e) {
             final String errMsg = "The operation was interrupted while executing and did not complete.";
             LOG.debug("Rpc Interrupt - " + errMsg, e);
-            throw new RestconfDocumentedException(errMsg, ErrorType.RPC, ErrorTag.PARTIAL_OPERATION);
+            throw new RestconfDocumentedException(errMsg, ErrorType.RPC, ErrorTag.PARTIAL_OPERATION, e);
         } catch (final ExecutionException e) {
             LOG.debug("Execution RpcError: ", e);
             Throwable cause = e.getCause();
@@ -614,8 +606,9 @@ public class RestconfImpl implements RestconfService {
             invokeSalRemoteRpcSubscribeRPC(final NormalizedNodeContext payload) {
         final ContainerNode value = (ContainerNode) payload.getData();
         final QName rpcQName = payload.getInstanceIdentifierContext().getSchemaNode().getQName();
-        final Optional<DataContainerChild<? extends PathArgument, ?>> path = value.getChild(new NodeIdentifier(
-                QName.create(payload.getInstanceIdentifierContext().getSchemaNode().getQName(), "path")));
+        final java.util.Optional<DataContainerChild<? extends PathArgument, ?>> 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)) {
@@ -708,11 +701,11 @@ public class RestconfImpl implements RestconfService {
         }
         boolean tagged = false;
         if (withDefaUsed) {
-            if (withDefa.equals("report-all-tagged")) {
+            if ("report-all-tagged".equals(withDefa)) {
                 tagged = true;
                 withDefa = null;
             }
-            if (withDefa.equals("report-all")) {
+            if ("report-all".equals(withDefa)) {
                 withDefa = null;
             }
         }
@@ -942,26 +935,28 @@ public class RestconfImpl implements RestconfService {
         String insert = null;
         String point = null;
 
-        for (final Entry<String, List<String>> entry : uriInfo.getQueryParameters().entrySet()) {
-            switch (entry.getKey()) {
-                case "insert":
-                    if (!insertUsed) {
-                        insertUsed = true;
-                        insert = entry.getValue().iterator().next();
-                    } else {
-                        throw new RestconfDocumentedException("Insert parameter can be used only once.");
-                    }
-                    break;
-                case "point":
-                    if (!pointUsed) {
-                        pointUsed = true;
-                        point = entry.getValue().iterator().next();
-                    } else {
-                        throw new RestconfDocumentedException("Point parameter can be used only once.");
-                    }
-                    break;
-                default:
-                    throw new RestconfDocumentedException("Bad parameter for post: " + entry.getKey());
+        if (uriInfo != null) {
+            for (final Entry<String, List<String>> entry : uriInfo.getQueryParameters().entrySet()) {
+                switch (entry.getKey()) {
+                    case "insert":
+                        if (!insertUsed) {
+                            insertUsed = true;
+                            insert = entry.getValue().iterator().next();
+                        } else {
+                            throw new RestconfDocumentedException("Insert parameter can be used only once.");
+                        }
+                        break;
+                    case "point":
+                        if (!pointUsed) {
+                            pointUsed = true;
+                            point = entry.getValue().iterator().next();
+                        } else {
+                            throw new RestconfDocumentedException("Point parameter can be used only once.");
+                        }
+                        break;
+                    default:
+                        throw new RestconfDocumentedException("Bad parameter for post: " + entry.getKey());
+                }
             }
         }
 
@@ -1002,37 +997,6 @@ public class RestconfImpl implements RestconfService {
         return responseBuilder.build();
     }
 
-    // FIXME create RestconfIdetifierHelper and move this method there
-    private static 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();
-                }
-            }
-        }
-        if (parentSchemaNode instanceof RpcDefinition) {
-            return yangIdent;
-        }
-        final String errMsg = "Error parsing input: DataSchemaNode has not children ";
-        LOG.info(errMsg + yangIdent);
-        throw new RestconfDocumentedException(errMsg, ErrorType.PROTOCOL, ErrorTag.MALFORMED_MESSAGE);
-    }
-
     @SuppressWarnings("checkstyle:IllegalCatch")
     private URI resolveLocation(final UriInfo uriInfo, final String uriBehindBase, final DOMMountPoint mountPoint,
             final YangInstanceIdentifier normalizedII) {
@@ -1071,8 +1035,8 @@ public class RestconfImpl implements RestconfService {
             final Optional<Throwable> searchedException = Iterables.tryFind(Throwables.getCausalChain(e),
                     Predicates.instanceOf(ModifiedNodeDoesNotExistException.class));
             if (searchedException.isPresent()) {
-                throw new RestconfDocumentedException("Data specified for delete doesn't exist.", ErrorType.APPLICATION,
-                        ErrorTag.DATA_MISSING);
+                throw new RestconfDocumentedException("Data specified for delete doesn't exist.",
+                        ErrorType.APPLICATION, ErrorTag.DATA_MISSING, e);
             }
 
             final String errMsg = "Error while deleting data";
@@ -1197,7 +1161,7 @@ public class RestconfImpl implements RestconfService {
         final QName qnameBase = QName.create("subscribe:to:notification", "2016-10-28", "notifi");
         final SchemaContext schemaCtx = ControllerContext.getInstance().getGlobalSchema();
         final DataSchemaNode location = ((ContainerSchemaNode) schemaCtx
-                .findModuleByNamespaceAndRevision(qnameBase.getNamespace(), qnameBase.getRevision())
+                .findModule(qnameBase.getModule()).orElse(null)
                 .getDataChildByName(qnameBase)).getDataChildByName(QName.create(qnameBase, "location"));
         final List<PathArgument> path = new ArrayList<>();
         path.add(NodeIdentifier.create(qnameBase));
@@ -1241,17 +1205,13 @@ public class RestconfImpl implements RestconfService {
         }
 
         final UriBuilder uriBuilder = uriInfo.getAbsolutePathBuilder();
-        int notificationPort = NOTIFICATION_PORT;
-        try {
-            final WebSocketServer webSocketServerInstance = WebSocketServer.getInstance();
-            notificationPort = webSocketServerInstance.getPort();
-        } catch (final NullPointerException e) {
-            WebSocketServer.createInstance(NOTIFICATION_PORT);
-        }
+
+        final WebSocketServer webSocketServerInstance = WebSocketServer.getInstance(NOTIFICATION_PORT);
+        final int notificationPort = webSocketServerInstance.getPort();
+
         final UriBuilder uriToWebsocketServerBuilder = uriBuilder.port(notificationPort).scheme("ws");
-        final URI uriToWebsocketServer = uriToWebsocketServerBuilder.replacePath(streamName).build();
 
-        return uriToWebsocketServer;
+        return uriToWebsocketServerBuilder.replacePath(streamName).build();
     }
 
     /**
@@ -1301,17 +1261,13 @@ public class RestconfImpl implements RestconfService {
         this.broker.registerToListenDataChanges(datastore, scope, listener);
 
         final UriBuilder uriBuilder = uriInfo.getAbsolutePathBuilder();
-        int notificationPort = NOTIFICATION_PORT;
-        try {
-            final WebSocketServer webSocketServerInstance = WebSocketServer.getInstance();
-            notificationPort = webSocketServerInstance.getPort();
-        } catch (final NullPointerException e) {
-            WebSocketServer.createInstance(NOTIFICATION_PORT);
-        }
+
+        final WebSocketServer webSocketServerInstance = WebSocketServer.getInstance(NOTIFICATION_PORT);
+        final int notificationPort = webSocketServerInstance.getPort();
+
         final UriBuilder uriToWebsocketServerBuilder = uriBuilder.port(notificationPort).scheme("ws");
-        final URI uriToWebsocketServer = uriToWebsocketServerBuilder.replacePath(streamName).build();
 
-        return uriToWebsocketServer;
+        return uriToWebsocketServerBuilder.replacePath(streamName).build();
     }
 
     @SuppressWarnings("checkstyle:IllegalCatch")
@@ -1326,7 +1282,7 @@ public class RestconfImpl implements RestconfService {
             return this.broker.patchConfigurationDataWithinTransaction(context);
         } catch (final Exception e) {
             LOG.debug("Patch transaction failed", e);
-            throw new RestconfDocumentedException(e.getMessage());
+            throw new RestconfDocumentedException(e.getMessage(), e);
         }
     }
 
@@ -1341,7 +1297,7 @@ public class RestconfImpl implements RestconfService {
             return this.broker.patchConfigurationDataWithinTransaction(context);
         } catch (final Exception e) {
             LOG.debug("Patch transaction failed", e);
-            throw new RestconfDocumentedException(e.getMessage());
+            throw new RestconfDocumentedException(e.getMessage(), e);
         }
     }
 
@@ -1355,13 +1311,17 @@ public class RestconfImpl implements RestconfService {
      */
     private static <T> T parseEnumTypeParameter(final ContainerNode value, final Class<T> classDescriptor,
             final String paramName) {
-        final Optional<DataContainerChild<? extends PathArgument, ?>> augNode =
-                value.getChild(SAL_REMOTE_AUG_IDENTIFIER);
-        if (!augNode.isPresent() && !(augNode instanceof AugmentationNode)) {
+        final java.util.Optional<DataContainerChild<? extends PathArgument, ?>> optAugNode = value.getChild(
+            SAL_REMOTE_AUG_IDENTIFIER);
+        if (!optAugNode.isPresent()) {
+            return null;
+        }
+        final DataContainerChild<? extends PathArgument, ?> augNode = optAugNode.get();
+        if (!(augNode instanceof AugmentationNode)) {
             return null;
         }
-        final Optional<DataContainerChild<? extends PathArgument, ?>> enumNode = ((AugmentationNode) augNode.get())
-                .getChild(new NodeIdentifier(QName.create(SAL_REMOTE_AUGMENT, paramName)));
+        final java.util.Optional<DataContainerChild<? extends PathArgument, ?>> enumNode = ((AugmentationNode) augNode)
+            .getChild(new NodeIdentifier(QName.create(SAL_REMOTE_AUGMENT, paramName)));
         if (!enumNode.isPresent()) {
             return null;
         }
@@ -1445,9 +1405,11 @@ public class RestconfImpl implements RestconfService {
                 ControllerContext.findInstanceDataChildrenByName(listModuleSchemaNode, "revision");
         final DataSchemaNode revisionSchemaNode = Iterables.getFirst(instanceDataChildrenByName, null);
         Preconditions.checkState(revisionSchemaNode instanceof LeafSchemaNode);
-        final String revision = module.getQNameModule().getFormattedRevision();
-        moduleNodeValues
-                .withChild(Builders.leafBuilder((LeafSchemaNode) revisionSchemaNode).withValue(revision).build());
+        final java.util.Optional<Revision> revision = module.getQNameModule().getRevision();
+        if (revision.isPresent()) {
+            moduleNodeValues.withChild(Builders.leafBuilder((LeafSchemaNode) revisionSchemaNode)
+                .withValue(revision.get().toString()).build());
+        }
 
         instanceDataChildrenByName =
                 ControllerContext.findInstanceDataChildrenByName(listModuleSchemaNode, "namespace");
@@ -1537,6 +1499,7 @@ public class RestconfImpl implements RestconfService {
         final List<SchemaPath> paths = new ArrayList<>();
         String streamName = CREATE_NOTIFICATION_STREAM + "/";
 
+        StringBuilder streamNameBuilder = new StringBuilder(streamName);
         final Iterator<LeafSetEntryNode> iterator = entryNodes.iterator();
         while (iterator.hasNext()) {
             final QName valueQName = QName.create((String) iterator.next().getValue());
@@ -1555,12 +1518,14 @@ public class RestconfImpl implements RestconfService {
             Preconditions.checkNotNull(notifiDef,
                     "Notification " + valueQName + "doesn't exist in module " + moduleName);
             paths.add(notifiDef.getPath());
-            streamName = streamName + moduleName + ":" + valueQName.getLocalName();
+            streamNameBuilder.append(moduleName).append(':').append(valueQName.getLocalName());
             if (iterator.hasNext()) {
-                streamName = streamName + ",";
+                streamNameBuilder.append(',');
             }
         }
 
+        streamName = streamNameBuilder.toString();
+
         final QName rpcQName = payload.getInstanceIdentifierContext().getSchemaNode().getQName();
         final QName outputQname = QName.create(rpcQName, "output");
         final QName streamNameQname = QName.create(rpcQName, "notification-stream-identifier");