Solves issue with two connections from one device.
[openflowplugin.git] / openflowplugin-impl / src / main / java / org / opendaylight / openflowplugin / impl / device / DeviceManagerImpl.java
index 94286671a219c90d951f61ab444a63d72f96882e..39e2954a888114ab2a659a3837b016fa928a4ab7 100644 (file)
@@ -7,29 +7,22 @@
  */
 package org.opendaylight.openflowplugin.impl.device;
 
-import com.google.common.collect.Iterators;
-import com.google.common.util.concurrent.CheckedFuture;
-import com.google.common.util.concurrent.FutureCallback;
-import com.google.common.util.concurrent.Futures;
+import com.google.common.util.concurrent.ListenableFuture;
 import io.netty.util.HashedWheelTimer;
 import io.netty.util.internal.ConcurrentSet;
-import java.util.Collections;
-import java.util.Iterator;
 import java.util.Optional;
 import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
-import java.util.concurrent.ExecutionException;
 import java.util.concurrent.ScheduledThreadPoolExecutor;
 import java.util.concurrent.TimeUnit;
 import javax.annotation.Nonnull;
-import javax.annotation.Nullable;
 import org.opendaylight.controller.md.sal.binding.api.DataBroker;
 import org.opendaylight.controller.md.sal.binding.api.NotificationPublishService;
 import org.opendaylight.controller.md.sal.binding.api.WriteTransaction;
 import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType;
-import org.opendaylight.controller.md.sal.common.api.data.TransactionCommitFailedException;
 import org.opendaylight.openflowjava.protocol.api.connection.OutboundQueueHandlerRegistration;
+import org.opendaylight.openflowplugin.api.openflow.OFPContext;
 import org.opendaylight.openflowplugin.api.openflow.connection.ConnectionContext;
 import org.opendaylight.openflowplugin.api.openflow.connection.OutboundQueueProvider;
 import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext;
@@ -42,16 +35,15 @@ import org.opendaylight.openflowplugin.extension.api.core.extension.ExtensionCon
 import org.opendaylight.openflowplugin.impl.connection.OutboundQueueProviderImpl;
 import org.opendaylight.openflowplugin.impl.device.initialization.DeviceInitializerProvider;
 import org.opendaylight.openflowplugin.impl.device.listener.OpenflowProtocolListenerFullImpl;
-import org.opendaylight.openflowplugin.impl.services.sal.SalRoleServiceImpl;
+import org.opendaylight.openflowplugin.impl.util.DeviceInitializationUtil;
 import org.opendaylight.openflowplugin.openflow.md.core.sal.convertor.ConvertorExecutor;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRemovedBuilder;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeUpdatedBuilder;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Nodes;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodesBuilder;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.Node;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey;
-import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.openflow.provider.config.rev160510.OpenflowProviderConfig;
 import org.opendaylight.yangtools.yang.binding.KeyedInstanceIdentifier;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -62,60 +54,37 @@ import org.slf4j.LoggerFactory;
 public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProviderKeeper {
 
     private static final Logger LOG = LoggerFactory.getLogger(DeviceManagerImpl.class);
-
-    private long globalNotificationQuota;
-    private boolean switchFeaturesMandatory;
-    private boolean isFlowRemovedNotificationOn;
-    private boolean skipTableFeatures;
     private static final int SPY_RATE = 10;
 
+    private final OpenflowProviderConfig config;
     private final DataBroker dataBroker;
     private final DeviceInitializerProvider deviceInitializerProvider;
     private final ConvertorExecutor convertorExecutor;
-    private TranslatorLibrary translatorLibrary;
-
     private final ConcurrentMap<DeviceInfo, DeviceContext> deviceContexts = new ConcurrentHashMap<>();
-    private final Set<DeviceInfo> notificationCreateNodeSend = new ConcurrentSet<>();
-
-    private long barrierIntervalNanos;
-    private int barrierCountLimit;
-
-    private ExtensionConverterProvider extensionConverterProvider;
-    private ScheduledThreadPoolExecutor spyPool;
+    private final Set<KeyedInstanceIdentifier<Node, NodeKey>> notificationCreateNodeSend = new ConcurrentSet<>();
     private final NotificationPublishService notificationPublishService;
     private final MessageSpy messageSpy;
     private final HashedWheelTimer hashedWheelTimer;
-    private final boolean useSingleLayerSerialization;
+    private TranslatorLibrary translatorLibrary;
+    private ExtensionConverterProvider extensionConverterProvider;
+    private ScheduledThreadPoolExecutor spyPool;
 
-    public DeviceManagerImpl(@Nonnull final DataBroker dataBroker,
+    public DeviceManagerImpl(@Nonnull final OpenflowProviderConfig config,
+                             @Nonnull final DataBroker dataBroker,
                              @Nonnull final MessageSpy messageSpy,
-                             @Nullable final NotificationPublishService notificationPublishService,
+                             @Nonnull final NotificationPublishService notificationPublishService,
                              @Nonnull final HashedWheelTimer hashedWheelTimer,
                              @Nonnull final ConvertorExecutor convertorExecutor,
-                             @Nonnull final DeviceInitializerProvider deviceInitializerProvider,
-                             final boolean useSingleLayerSerialization) {
-
+                             @Nonnull final DeviceInitializerProvider deviceInitializerProvider) {
+        this.config = config;
         this.dataBroker = dataBroker;
         this.deviceInitializerProvider = deviceInitializerProvider;
-        this.useSingleLayerSerialization = useSingleLayerSerialization;
-
-        /* merge empty nodes to oper DS to predict any problems with missing parent for Node */
-        final WriteTransaction tx = dataBroker.newWriteOnlyTransaction();
-        final NodesBuilder nodesBuilder = new NodesBuilder();
-        nodesBuilder.setNode(Collections.<Node>emptyList());
-        tx.merge(LogicalDatastoreType.OPERATIONAL, InstanceIdentifier.create(Nodes.class), nodesBuilder.build());
-        try {
-            tx.submit().get();
-        } catch (ExecutionException | InterruptedException e) {
-            LOG.error("Creation of node failed.", e);
-            throw new IllegalStateException(e);
-        }
-
         this.convertorExecutor = convertorExecutor;
         this.hashedWheelTimer = hashedWheelTimer;
         this.spyPool = new ScheduledThreadPoolExecutor(1);
         this.notificationPublishService = notificationPublishService;
         this.messageSpy = messageSpy;
+        DeviceInitializationUtil.makeEmptyNodes(dataBroker);
     }
 
     @Override
@@ -130,13 +99,8 @@ public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProvi
 
     @Override
     public void close() {
-        for (final Iterator<DeviceContext> iterator = Iterators.consumingIterator(deviceContexts.values().iterator());
-                iterator.hasNext();) {
-            final DeviceContext deviceCtx = iterator.next();
-            deviceCtx.shutdownConnection();
-            deviceCtx.shuttingDownDataStoreTransactions();
-        }
-
+        deviceContexts.values().forEach(OFPContext::close);
+        deviceContexts.clear();
         Optional.ofNullable(spyPool).ifPresent(ScheduledThreadPoolExecutor::shutdownNow);
         spyPool = null;
 
@@ -158,66 +122,13 @@ public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProvi
     }
 
     @Override
-    public void setFlowRemovedNotificationOn(boolean isNotificationFlowRemovedOff) {
-        this.isFlowRemovedNotificationOn = isNotificationFlowRemovedOff;
-    }
-
-    @Override
-    public boolean isFlowRemovedNotificationOn() {
-        return this.isFlowRemovedNotificationOn;
-    }
-
-    @Override
-    public void setGlobalNotificationQuota(final long globalNotificationQuota) {
-        this.globalNotificationQuota = globalNotificationQuota;
-    }
-
-    @Override
-    public void setSwitchFeaturesMandatory(final boolean switchFeaturesMandatory) {
-        this.switchFeaturesMandatory = switchFeaturesMandatory;
-    }
-
-    @Override
-    public void setSkipTableFeatures(boolean skipTableFeaturesValue) {
-        skipTableFeatures = skipTableFeaturesValue;
-    }
+    public ListenableFuture<Void> removeDeviceFromOperationalDS(
+            @Nonnull final KeyedInstanceIdentifier<Node, NodeKey> ii) {
 
-    @Override
-    public void setBarrierCountLimit(final int barrierCountLimit) {
-        this.barrierCountLimit = barrierCountLimit;
-    }
-
-    @Override
-    public void setBarrierInterval(final long barrierTimeoutLimit) {
-        this.barrierIntervalNanos = TimeUnit.MILLISECONDS.toNanos(barrierTimeoutLimit);
-    }
-
-    @Override
-    public CheckedFuture<Void, TransactionCommitFailedException> removeDeviceFromOperationalDS(final KeyedInstanceIdentifier<Node, NodeKey> ii) {
         final WriteTransaction delWtx = dataBroker.newWriteOnlyTransaction();
         delWtx.delete(LogicalDatastoreType.OPERATIONAL, ii);
-        final CheckedFuture<Void, TransactionCommitFailedException> delFuture = delWtx.submit();
-
-        Futures.addCallback(delFuture, new FutureCallback<Void>() {
-            @Override
-            public void onSuccess(final Void result) {
-                if (LOG.isDebugEnabled()) {
-                    LOG.debug("Delete Node {} was successful", ii);
-                }
-            }
-
-            @Override
-            public void onFailure(@Nonnull final Throwable t) {
-                LOG.warn("Delete node {} failed with exception {}", ii, t);
-            }
-        });
-
-        return delFuture;
-    }
+        return delWtx.submit();
 
-    @Override
-    public CheckedFuture<Void, TransactionCommitFailedException> removeDeviceFromOperationalDS(final DeviceInfo deviceInfo) {
-        return this.removeDeviceFromOperationalDS(deviceInfo.getNodeInstanceIdentifier());
     }
 
     public DeviceContext createContext(@Nonnull final ConnectionContext connectionContext) {
@@ -235,8 +146,8 @@ public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProvi
         final OutboundQueueHandlerRegistration<OutboundQueueProvider> outboundQueueHandlerRegistration =
                 connectionContext.getConnectionAdapter().registerOutboundQueueHandler(
                         outboundQueueProvider,
-                        barrierCountLimit,
-                        barrierIntervalNanos);
+                        config.getBarrierCountLimit().getValue(),
+                        TimeUnit.MILLISECONDS.toNanos(config.getBarrierIntervalTimeoutLimit().getValue()));
         connectionContext.setOutboundQueueHandleRegistration(outboundQueueHandlerRegistration);
 
 
@@ -245,15 +156,14 @@ public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProvi
                 dataBroker,
                 messageSpy,
                 translatorLibrary,
-                this,
                 convertorExecutor,
-                skipTableFeatures,
+                config.isSkipTableFeatures(),
                 hashedWheelTimer,
-                useSingleLayerSerialization,
-                deviceInitializerProvider);
+                config.isUseSingleLayerSerialization(),
+                deviceInitializerProvider,
+                config.isEnableFlowRemovedNotification(),
+                config.isSwitchFeaturesMandatory());
 
-        deviceContext.setSalRoleService(new SalRoleServiceImpl(deviceContext, deviceContext));
-        deviceContext.setSwitchFeaturesMandatory(switchFeaturesMandatory);
         ((ExtensionConverterProviderKeeper) deviceContext).setExtensionConverterProvider(extensionConverterProvider);
         deviceContext.setNotificationPublishService(notificationPublishService);
 
@@ -264,6 +174,7 @@ public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProvi
                 connectionContext.getConnectionAdapter(), deviceContext);
 
         connectionContext.getConnectionAdapter().setMessageListener(messageListener);
+        connectionContext.getConnectionAdapter().setAlienMessageListener(messageListener);
 
         return deviceContext;
     }
@@ -272,7 +183,7 @@ public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProvi
         synchronized (deviceContexts) {
             final int deviceContextsSize = deviceContexts.size();
             if (deviceContextsSize > 0) {
-                long freshNotificationLimit = globalNotificationQuota / deviceContextsSize;
+                long freshNotificationLimit = config.getGlobalNotificationQuota() / deviceContextsSize;
                 if (freshNotificationLimit < 100) {
                     freshNotificationLimit = 100;
                 }
@@ -286,47 +197,36 @@ public class DeviceManagerImpl implements DeviceManager, ExtensionConverterProvi
         }
     }
 
-    private void sendNodeRemovedNotification(final DeviceInfo deviceInfo) {
-        notificationCreateNodeSend.remove(deviceInfo);
-        NodeRemovedBuilder builder = new NodeRemovedBuilder();
-        builder.setNodeRef(new NodeRef(deviceInfo.getNodeInstanceIdentifier()));
-        if (LOG.isDebugEnabled()) {
-            LOG.debug("Publishing node removed notification for {}", deviceInfo.getLOGValue());
-        }
-        notificationPublishService.offerNotification(builder.build());
-    }
-
-
     @Override
     public void onDeviceRemoved(final DeviceInfo deviceInfo) {
-        this.sendNodeRemovedNotification(deviceInfo);
         deviceContexts.remove(deviceInfo);
         if (LOG.isDebugEnabled()) {
-            LOG.debug("Device context removed for node {}", deviceInfo.getLOGValue());
+            LOG.debug("Device context removed for node {}", deviceInfo);
+        }
+        if (deviceContexts.size() > 0) {
+            this.updatePacketInRateLimiters();
         }
-        this.updatePacketInRateLimiters();
-    }
-
-    @Override
-    public long getBarrierIntervalNanos() {
-        return barrierIntervalNanos;
     }
 
     @Override
-    public int getBarrierCountLimit() {
-        return barrierCountLimit;
+    public void sendNodeRemovedNotification(@Nonnull final KeyedInstanceIdentifier<Node, NodeKey> instanceIdentifier) {
+        if (notificationCreateNodeSend.remove(instanceIdentifier)) {
+            NodeRemovedBuilder builder = new NodeRemovedBuilder();
+            builder.setNodeRef(new NodeRef(instanceIdentifier));
+            LOG.info("Publishing node removed notification for {}", instanceIdentifier.firstKeyOf(Node.class).getId());
+            notificationPublishService.offerNotification(builder.build());
+        }
     }
 
     @Override
-    public void sendNodeAddedNotification(@Nonnull final DeviceInfo deviceInfo) {
-        if (!notificationCreateNodeSend.contains(deviceInfo)) {
-            notificationCreateNodeSend.add(deviceInfo);
+    public void sendNodeAddedNotification(@Nonnull final KeyedInstanceIdentifier<Node, NodeKey> instanceIdentifier) {
+        if (!notificationCreateNodeSend.contains(instanceIdentifier)) {
+            notificationCreateNodeSend.add(instanceIdentifier);
+            final NodeId id = instanceIdentifier.firstKeyOf(Node.class).getId();
             NodeUpdatedBuilder builder = new NodeUpdatedBuilder();
-            builder.setId(deviceInfo.getNodeId());
-            builder.setNodeRef(new NodeRef(deviceInfo.getNodeInstanceIdentifier()));
-            if (LOG.isDebugEnabled()) {
-                LOG.debug("Publishing node added notification for {}", deviceInfo.getLOGValue());
-            }
+            builder.setId(id);
+            builder.setNodeRef(new NodeRef(instanceIdentifier));
+            LOG.info("Publishing node added notification for {}", id);
             notificationPublishService.offerNotification(builder.build());
         }
     }