Merge "Add IpConversionUtil.hasIpv4Prefix()"
[openflowplugin.git] / applications / forwardingrules-manager / src / main / java / org / opendaylight / openflowplugin / applications / frm / impl / ForwardingRulesManagerImpl.java
index c058b093648a1386c99ae22850a674e9fc9479d3..334944c215d5060c856bfeed59866f345ad7d631 100644 (file)
@@ -1,30 +1,43 @@
-/**
- * Copyright (c) 2014, 2015 Cisco Systems, Inc. and others.  All rights reserved.
+/*
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
  * and is available at http://www.eclipse.org/legal/epl-v10.html
  */
-
 package org.opendaylight.openflowplugin.applications.frm.impl;
 
 import com.google.common.annotations.VisibleForTesting;
-import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
-import com.google.common.collect.Sets;
-import com.google.common.util.concurrent.CheckedFuture;
-import java.util.Collections;
-import java.util.Set;
+import com.google.common.util.concurrent.ListenableFuture;
+import java.util.Optional;
+import java.util.concurrent.ExecutionException;
 import java.util.concurrent.atomic.AtomicLong;
-import org.opendaylight.controller.md.sal.binding.api.DataBroker;
-import org.opendaylight.controller.md.sal.binding.api.ReadOnlyTransaction;
-import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType;
-import org.opendaylight.controller.md.sal.common.api.data.ReadFailedException;
-import org.opendaylight.controller.sal.binding.api.RpcConsumerRegistry;
+import javax.annotation.Nonnull;
+import javax.annotation.PostConstruct;
+import javax.annotation.PreDestroy;
+import javax.inject.Inject;
+import javax.inject.Singleton;
+import org.apache.aries.blueprint.annotation.service.Reference;
+import org.opendaylight.mdsal.binding.api.DataBroker;
+import org.opendaylight.mdsal.binding.api.ReadTransaction;
+import org.opendaylight.mdsal.binding.api.RpcConsumerRegistry;
+import org.opendaylight.mdsal.binding.api.RpcProviderService;
+import org.opendaylight.mdsal.common.api.LogicalDatastoreType;
 import org.opendaylight.mdsal.singleton.common.api.ClusterSingletonServiceProvider;
+import org.opendaylight.openflowplugin.api.openflow.configuration.ConfigurationService;
+import org.opendaylight.openflowplugin.api.openflow.mastership.MastershipChangeServiceManager;
 import org.opendaylight.openflowplugin.applications.frm.FlowNodeReconciliation;
 import org.opendaylight.openflowplugin.applications.frm.ForwardingRulesCommiter;
 import org.opendaylight.openflowplugin.applications.frm.ForwardingRulesManager;
+import org.opendaylight.openflowplugin.applications.frm.ForwardingRulesProperty;
+import org.opendaylight.openflowplugin.applications.frm.NodeConfigurator;
+import org.opendaylight.openflowplugin.applications.frm.nodeconfigurator.NodeConfiguratorImpl;
+import org.opendaylight.openflowplugin.applications.frm.recovery.OpenflowServiceRecoveryHandler;
+import org.opendaylight.openflowplugin.applications.reconciliation.NotificationRegistration;
+import org.opendaylight.openflowplugin.applications.reconciliation.ReconciliationManager;
+import org.opendaylight.serviceutils.srm.RecoverableListener;
+import org.opendaylight.serviceutils.srm.ServiceRecoveryRegistry;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowCapableNode;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.meters.Meter;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.tables.table.Flow;
@@ -33,7 +46,10 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.group.service.rev130918.Sal
 import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.groups.Group;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.Node;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.meter.service.rev130918.SalMeterService;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.openflowplugin.extension.onf.bundle.service.rev170124.SalBundleService;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.openflowplugin.app.arbitrator.reconcile.service.rev180227.ArbitratorReconcileService;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.openflowplugin.app.forwardingrules.manager.config.rev160511.ForwardingRulesManagerConfig;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.openflowplugin.rf.state.rev170713.ResultState;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.table.service.rev131026.SalTableService;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.table.types.rev131026.table.features.TableFeatures;
 import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
@@ -41,50 +57,76 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * forwardingrules-manager
- * org.opendaylight.openflowplugin.applications.frm.impl
+ * forwardingrules-manager org.opendaylight.openflowplugin.applications.frm.impl
  *
- * Manager and middle point for whole module.
- * It contains ActiveNodeHolder and provide all RPC services.
+ * <p>
+ * Manager and middle point for whole module. It contains ActiveNodeHolder and
+ * provide all RPC services.
  *
  */
+@Singleton
 public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
-
     private static final Logger LOG = LoggerFactory.getLogger(ForwardingRulesManagerImpl.class);
+
     static final int STARTUP_LOOP_TICK = 500;
     static final int STARTUP_LOOP_MAX_RETRIES = 8;
+    private static final int FRM_RECONCILIATION_PRIORITY = Integer.getInteger("frm.reconciliation.priority", 1);
+    private static final String SERVICE_NAME = "FRM";
 
     private final AtomicLong txNum = new AtomicLong();
-    private final Object lockObj = new Object();
-    private Set<InstanceIdentifier<FlowCapableNode>> activeNodes = Collections.emptySet();
-
     private final DataBroker dataService;
     private final SalFlowService salFlowService;
     private final SalGroupService salGroupService;
     private final SalMeterService salMeterService;
     private final SalTableService salTableService;
-
+    private final ClusterSingletonServiceProvider clusterSingletonServiceProvider;
+    private final SalBundleService salBundleService;
+    private final AutoCloseable configurationServiceRegistration;
+    private final MastershipChangeServiceManager mastershipChangeServiceManager;
+    private final RpcProviderService rpcProviderService;
     private ForwardingRulesCommiter<Flow> flowListener;
     private ForwardingRulesCommiter<Group> groupListener;
     private ForwardingRulesCommiter<Meter> meterListener;
     private ForwardingRulesCommiter<TableFeatures> tableListener;
     private FlowNodeReconciliation nodeListener;
-
-    private final ForwardingRulesManagerConfig forwardingRulesManagerConfig;
+    private NotificationRegistration reconciliationNotificationRegistration;
     private FlowNodeConnectorInventoryTranslatorImpl flowNodeConnectorInventoryTranslatorImpl;
-    private final ClusterSingletonServiceProvider clusterSingletonServiceProvider;
     private DeviceMastershipManager deviceMastershipManager;
-
-    public ForwardingRulesManagerImpl(final DataBroker dataBroker,
-                                      final RpcConsumerRegistry rpcRegistry,
+    private final ReconciliationManager reconciliationManager;
+    private DevicesGroupRegistry devicesGroupRegistry;
+    private NodeConfigurator nodeConfigurator;
+    private final ArbitratorReconcileService arbitratorReconciliationManager;
+    private boolean disableReconciliation;
+    private boolean staleMarkingEnabled;
+    private int reconciliationRetryCount;
+    private boolean isBundleBasedReconciliationEnabled;
+    private final OpenflowServiceRecoveryHandler openflowServiceRecoveryHandler;
+    private final ServiceRecoveryRegistry serviceRecoveryRegistry;
+
+    @Inject
+    public ForwardingRulesManagerImpl(@Reference final DataBroker dataBroker,
+                                      @Reference final RpcConsumerRegistry rpcRegistry,
+                                      @Reference final RpcProviderService rpcProviderService,
                                       final ForwardingRulesManagerConfig config,
-                                      final ClusterSingletonServiceProvider clusterSingletonService) {
+                                      @Reference final MastershipChangeServiceManager mastershipChangeServiceManager,
+                                      @Reference final ClusterSingletonServiceProvider clusterSingletonService,
+                                      @Reference final ConfigurationService configurationService,
+                                      @Reference final ReconciliationManager reconciliationManager,
+                                      final OpenflowServiceRecoveryHandler openflowServiceRecoveryHandler,
+                                      @Reference final ServiceRecoveryRegistry serviceRecoveryRegistry) {
+        disableReconciliation = config.isDisableReconciliation();
+        staleMarkingEnabled = config.isStaleMarkingEnabled();
+        reconciliationRetryCount = config.getReconciliationRetryCount();
+        isBundleBasedReconciliationEnabled = config.isBundleBasedReconciliationEnabled();
+        this.configurationServiceRegistration = configurationService.registerListener(this);
         this.dataService = Preconditions.checkNotNull(dataBroker, "DataBroker can not be null!");
-        this.forwardingRulesManagerConfig = Preconditions.checkNotNull(config, "Configuration for FRM cannot be null");
         this.clusterSingletonServiceProvider = Preconditions.checkNotNull(clusterSingletonService,
                 "ClusterSingletonService provider can not be null");
+        this.reconciliationManager = reconciliationManager;
+        this.rpcProviderService = rpcProviderService;
+        this.mastershipChangeServiceManager = mastershipChangeServiceManager;
 
-        Preconditions.checkArgument(rpcRegistry != null, "RpcConsumerRegistry can not be null !");
+        Preconditions.checkArgument(rpcRegistry != null, "RpcProviderRegistry can not be null !");
 
         this.salFlowService = Preconditions.checkNotNull(rpcRegistry.getRpcService(SalFlowService.class),
                 "RPC SalFlowService not found.");
@@ -94,23 +136,48 @@ public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
                 "RPC SalMeterService not found.");
         this.salTableService = Preconditions.checkNotNull(rpcRegistry.getRpcService(SalTableService.class),
                 "RPC SalTableService not found.");
+        this.salBundleService = Preconditions.checkNotNull(rpcRegistry.getRpcService(SalBundleService.class),
+                "RPC SalBundlService not found.");
+        this.openflowServiceRecoveryHandler = Preconditions.checkNotNull(openflowServiceRecoveryHandler,
+                "Openflow service recovery handler cannot be null");
+        this.serviceRecoveryRegistry = Preconditions.checkNotNull(serviceRecoveryRegistry,
+                "Service recovery registry cannot be null");
+        this.arbitratorReconciliationManager = Preconditions
+                .checkNotNull(rpcRegistry.getRpcService(ArbitratorReconcileService.class),
+                        "ArbitratorReconciliationManager can not be null!");
     }
 
     @Override
+    @PostConstruct
     public void start() {
+        nodeConfigurator = new NodeConfiguratorImpl();
+        this.devicesGroupRegistry = new DevicesGroupRegistry();
+
+        this.nodeListener = new FlowNodeReconciliationImpl(this, dataService, SERVICE_NAME, FRM_RECONCILIATION_PRIORITY,
+                ResultState.DONOTHING);
+        if (this.isReconciliationDisabled()) {
+            LOG.debug("Reconciliation is disabled by user");
+        } else {
+            this.reconciliationNotificationRegistration = reconciliationManager.registerService(this.nodeListener);
+            LOG.debug("Reconciliation is enabled by user and successfully registered to the reconciliation framework");
+        }
+        this.deviceMastershipManager = new DeviceMastershipManager(clusterSingletonServiceProvider, this.nodeListener,
+                dataService, mastershipChangeServiceManager, rpcProviderService,
+                new FrmReconciliationServiceImpl(this));
+        flowNodeConnectorInventoryTranslatorImpl = new FlowNodeConnectorInventoryTranslatorImpl(dataService);
+
         this.flowListener = new FlowForwarder(this, dataService);
         this.groupListener = new GroupForwarder(this, dataService);
         this.meterListener = new MeterForwarder(this, dataService);
         this.tableListener = new TableForwarder(this, dataService);
-        this.deviceMastershipManager = new DeviceMastershipManager(clusterSingletonServiceProvider);
-        this.nodeListener = new FlowNodeReconciliationImpl(this, dataService);
-        flowNodeConnectorInventoryTranslatorImpl =
-                new FlowNodeConnectorInventoryTranslatorImpl(this,dataService);
         LOG.info("ForwardingRulesManager has started successfully.");
     }
 
     @Override
+    @PreDestroy
     public void close() throws Exception {
+        configurationServiceRegistration.close();
+
         if (this.flowListener != null) {
             this.flowListener.close();
             this.flowListener = null;
@@ -131,10 +198,17 @@ public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
             this.nodeListener.close();
             this.nodeListener = null;
         }
+        if (deviceMastershipManager != null) {
+            deviceMastershipManager.close();
+        }
+        if (this.reconciliationNotificationRegistration != null) {
+            this.reconciliationNotificationRegistration.close();
+            this.reconciliationNotificationRegistration = null;
+        }
     }
 
     @Override
-    public ReadOnlyTransaction getReadTranaction() {
+    public ReadTransaction getReadTransaction() {
         return dataService.newReadOnlyTransaction();
     }
 
@@ -144,63 +218,30 @@ public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
     }
 
     @Override
-    public boolean isNodeActive(InstanceIdentifier<FlowCapableNode> ident) {
-        return activeNodes.contains(ident);
+    public boolean isNodeActive(final InstanceIdentifier<FlowCapableNode> ident) {
+        return deviceMastershipManager.isNodeActive(ident.firstKeyOf(Node.class).getId());
     }
 
     @Override
-    public boolean checkNodeInOperationalDataStore(InstanceIdentifier<FlowCapableNode> ident) {
+    public boolean checkNodeInOperationalDataStore(final InstanceIdentifier<FlowCapableNode> ident) {
         boolean result = false;
         InstanceIdentifier<Node> nodeIid = ident.firstIdentifierOf(Node.class);
-        final ReadOnlyTransaction transaction = dataService.newReadOnlyTransaction();
-        Optional<Node> optionalDataObject;
-        CheckedFuture<Optional<Node>, ReadFailedException> future = transaction.read(LogicalDatastoreType.OPERATIONAL, nodeIid);
-        try {
-            optionalDataObject = future.checkedGet();
+        try (ReadTransaction transaction = dataService.newReadOnlyTransaction()) {
+            ListenableFuture<Optional<Node>> future = transaction
+                .read(LogicalDatastoreType.OPERATIONAL, nodeIid);
+            Optional<Node> optionalDataObject = future.get();
             if (optionalDataObject.isPresent()) {
                 result = true;
             } else {
-                LOG.debug("{}: Failed to read {}",
-                        Thread.currentThread().getStackTrace()[1], nodeIid);
+                LOG.debug("{}: Failed to read {}", Thread.currentThread().getStackTrace()[1], nodeIid);
             }
-        } catch (ReadFailedException e) {
+        } catch (ExecutionException | InterruptedException e) {
             LOG.warn("Failed to read {} ", nodeIid, e);
         }
-        transaction.close();
 
         return result;
     }
 
-    @Override
-    public void registrateNewNode(InstanceIdentifier<FlowCapableNode> ident) {
-        if (!activeNodes.contains(ident)) {
-            synchronized (lockObj) {
-                if (!activeNodes.contains(ident)) {
-                    Set<InstanceIdentifier<FlowCapableNode>> set =
-                            Sets.newHashSet(activeNodes);
-                    set.add(ident);
-                    activeNodes = Collections.unmodifiableSet(set);
-                    deviceMastershipManager.onDeviceConnected(ident.firstKeyOf(Node.class).getId());
-                }
-            }
-        }
-    }
-
-    @Override
-    public void unregistrateNode(InstanceIdentifier<FlowCapableNode> ident) {
-        if (activeNodes.contains(ident)) {
-            synchronized (lockObj) {
-                if (activeNodes.contains(ident)) {
-                    Set<InstanceIdentifier<FlowCapableNode>> set =
-                            Sets.newHashSet(activeNodes);
-                    set.remove(ident);
-                    activeNodes = Collections.unmodifiableSet(set);
-                    deviceMastershipManager.onDeviceDisconnected(ident.firstKeyOf(Node.class).getId());
-                }
-            }
-        }
-    }
-
     @Override
     public SalFlowService getSalFlowService() {
         return salFlowService;
@@ -221,6 +262,16 @@ public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
         return salTableService;
     }
 
+    @Override
+    public DevicesGroupRegistry getDevicesGroupRegistry() {
+        return this.devicesGroupRegistry;
+    }
+
+    @Override
+    public SalBundleService getSalBundleService() {
+        return salBundleService;
+    }
+
     @Override
     public ForwardingRulesCommiter<Flow> getFlowCommiter() {
         return flowListener;
@@ -242,13 +293,29 @@ public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
     }
 
     @Override
-    public FlowNodeReconciliation getFlowNodeReconciliation() {
-        return nodeListener;
+    public ArbitratorReconcileService getArbitratorReconciliationManager() {
+        return arbitratorReconciliationManager;
+    }
+
+    @Override
+    public boolean isReconciliationDisabled() {
+        return disableReconciliation;
     }
 
     @Override
-    public ForwardingRulesManagerConfig getConfiguration() {
-        return forwardingRulesManagerConfig;
+    public boolean isStaleMarkingEnabled() {
+        return staleMarkingEnabled;
+    }
+
+    @Override
+    public int getReconciliationRetryCount() {
+        return reconciliationRetryCount;
+    }
+
+    @Override
+    public void addRecoverableListener(final RecoverableListener recoverableListener) {
+        serviceRecoveryRegistry.addRecoverableListener(openflowServiceRecoveryHandler.buildServiceRegistryKey(),
+                recoverableListener);
     }
 
     @Override
@@ -257,8 +324,22 @@ public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
     }
 
     @Override
-    public boolean isNodeOwner(InstanceIdentifier<FlowCapableNode> ident) {
-        return deviceMastershipManager.isDeviceMastered(ident.firstKeyOf(Node.class).getId());
+    public NodeConfigurator getNodeConfigurator() {
+        return nodeConfigurator;
+    }
+
+    public FlowNodeReconciliation getNodeListener() {
+        return nodeListener;
+    }
+
+    @Override
+    public boolean isBundleBasedReconciliationEnabled() {
+        return isBundleBasedReconciliationEnabled;
+    }
+
+    @Override
+    public boolean isNodeOwner(final InstanceIdentifier<FlowCapableNode> ident) {
+        return ident != null && deviceMastershipManager.isDeviceMastered(ident.firstKeyOf(Node.class).getId());
     }
 
     @VisibleForTesting
@@ -266,5 +347,27 @@ public class ForwardingRulesManagerImpl implements ForwardingRulesManager {
         this.deviceMastershipManager = deviceMastershipManager;
     }
 
+    @Override
+    public void onPropertyChanged(@Nonnull final String propertyName, @Nonnull final String propertyValue) {
+        final ForwardingRulesProperty forwardingRulesProperty = ForwardingRulesProperty.forValue(propertyName);
+        if (forwardingRulesProperty != null) {
+            switch (forwardingRulesProperty) {
+                case DISABLE_RECONCILIATION:
+                    disableReconciliation = Boolean.valueOf(propertyValue);
+                    break;
+                case STALE_MARKING_ENABLED:
+                    staleMarkingEnabled = Boolean.valueOf(propertyValue);
+                    break;
+                case RECONCILIATION_RETRY_COUNT:
+                    reconciliationRetryCount = Integer.parseInt(propertyValue);
+                    break;
+                case BUNDLE_BASED_RECONCILIATION_ENABLED:
+                    isBundleBasedReconciliationEnabled = Boolean.valueOf(propertyValue);
+                    break;
+                default:
+                    LOG.warn("No forwarding rule property found.");
+                    break;
+            }
+        }
+    }
 }
-