Merge "Bug 6110: Fixed bugs in statistics manager due to race condition." into stable...
[openflowplugin.git] / openflowplugin-impl / src / main / java / org / opendaylight / openflowplugin / impl / statistics / StatisticsContextImpl.java
index 9e4f3db7d22e50a543c352dd3fb98f46bd3d3d02..3002b8e632d83e53bb23b5d0f6f6376c92605cf0 100644 (file)
@@ -9,6 +9,7 @@
 package org.opendaylight.openflowplugin.impl.statistics;
 
 import com.google.common.annotations.VisibleForTesting;
+import com.google.common.base.Function;
 import com.google.common.base.Preconditions;
 import com.google.common.collect.ImmutableList;
 import com.google.common.collect.Iterators;
@@ -22,20 +23,24 @@ import java.util.Collection;
 import java.util.HashSet;
 import java.util.Iterator;
 import java.util.List;
+import java.util.Objects;
 import java.util.Optional;
-import java.util.concurrent.ExecutionException;
 import javax.annotation.Nonnull;
 import javax.annotation.Nullable;
 import javax.annotation.concurrent.GuardedBy;
+import org.opendaylight.mdsal.common.api.TransactionChainClosedException;
 import org.opendaylight.mdsal.singleton.common.api.ServiceGroupIdentifier;
+import org.opendaylight.openflowplugin.api.ConnectionException;
 import org.opendaylight.openflowplugin.api.openflow.connection.ConnectionContext;
 import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext;
 import org.opendaylight.openflowplugin.api.openflow.device.DeviceInfo;
 import org.opendaylight.openflowplugin.api.openflow.device.DeviceState;
 import org.opendaylight.openflowplugin.api.openflow.device.RequestContext;
-import org.opendaylight.openflowplugin.api.openflow.lifecycle.LifecycleConductor;
+import org.opendaylight.openflowplugin.api.openflow.device.handlers.ClusterInitializationPhaseHandler;
+import org.opendaylight.openflowplugin.api.openflow.lifecycle.LifecycleService;
 import org.opendaylight.openflowplugin.api.openflow.rpc.listener.ItemLifecycleListener;
 import org.opendaylight.openflowplugin.api.openflow.statistics.StatisticsContext;
+import org.opendaylight.openflowplugin.api.openflow.statistics.StatisticsManager;
 import org.opendaylight.openflowplugin.impl.rpc.AbstractRequestContext;
 import org.opendaylight.openflowplugin.impl.rpc.listener.ItemLifecycleListenerImpl;
 import org.opendaylight.openflowplugin.impl.services.RequestContextUtil;
@@ -56,40 +61,50 @@ class StatisticsContextImpl implements StatisticsContext {
     private final DeviceContext deviceContext;
     private final DeviceState devState;
     private final ListenableFuture<Boolean> emptyFuture;
-    private final boolean shuttingDownStatisticsPolling;
-    private final Object COLLECTION_STAT_TYPE_LOCK = new Object();
+    private final boolean isStatisticsPollingOn;
     private final SinglePurposeMultipartReplyTranslator multipartReplyTranslator;
-    @GuardedBy("COLLECTION_STAT_TYPE_LOCK")
+    private final Object collectionStatTypeLock = new Object();
+    @GuardedBy("collectionStatTypeLock")
     private List<MultipartType> collectingStatType;
 
     private StatisticsGatheringService statisticsGatheringService;
     private StatisticsGatheringOnTheFlyService statisticsGatheringOnTheFlyService;
     private Timeout pollTimeout;
     private final DeviceInfo deviceInfo;
+    private final StatisticsManager myManager;
+    private final LifecycleService lifecycleService;
 
     private volatile boolean schedulingEnabled;
     private volatile CONTEXT_STATE state;
+    private ClusterInitializationPhaseHandler clusterInitializationPhaseHandler;
+    private ClusterInitializationPhaseHandler initialSubmitHandler;
+
+    private ListenableFuture<Boolean> lastDataGathering;
 
     StatisticsContextImpl(@Nonnull final DeviceInfo deviceInfo,
-                          @Nonnull final boolean shuttingDownStatisticsPolling,
-                          @Nonnull final LifecycleConductor lifecycleConductor,
-                         @Nonnull final ConvertorExecutor convertorExecutor) {
-        this.deviceContext = Preconditions.checkNotNull(lifecycleConductor.getDeviceContext(deviceInfo));
+                          final boolean isStatisticsPollingOn,
+                          @Nonnull final LifecycleService lifecycleService,
+                          @Nonnull final ConvertorExecutor convertorExecutor,
+                          @Nonnull final StatisticsManager myManager) {
+        this.lifecycleService = lifecycleService;
+        this.deviceContext = lifecycleService.getDeviceContext();
         this.devState = Preconditions.checkNotNull(deviceContext.getDeviceState());
-        this.shuttingDownStatisticsPolling = shuttingDownStatisticsPolling;
+        this.isStatisticsPollingOn = isStatisticsPollingOn;
         multipartReplyTranslator = new SinglePurposeMultipartReplyTranslator(convertorExecutor);
         emptyFuture = Futures.immediateFuture(false);
         statisticsGatheringService = new StatisticsGatheringService(this, deviceContext);
         statisticsGatheringOnTheFlyService = new StatisticsGatheringOnTheFlyService(this, deviceContext, convertorExecutor);
         itemLifeCycleListener = new ItemLifecycleListenerImpl(deviceContext);
         statListForCollectingInitialization();
-        setState(CONTEXT_STATE.INITIALIZATION);
+        this.state = CONTEXT_STATE.INITIALIZATION;
         this.deviceInfo = deviceInfo;
+        this.myManager = myManager;
+        this.lastDataGathering = null;
     }
 
     @Override
     public void statListForCollectingInitialization() {
-        synchronized (COLLECTION_STAT_TYPE_LOCK) {
+        synchronized (collectionStatTypeLock) {
             final List<MultipartType> statListForCollecting = new ArrayList<>();
             if (devState.isTableStatisticsAvailable()) {
                 statListForCollecting.add(MultipartType.OFPMPTABLE);
@@ -127,15 +142,16 @@ class StatisticsContextImpl implements StatisticsContext {
     }
 
     private ListenableFuture<Boolean> gatherDynamicData(final boolean initial) {
-        if (shuttingDownStatisticsPolling) {
-            LOG.debug("Statistics for device {} is not enabled.", getDeviceInfo().getNodeId());
+        this.lastDataGathering = null;
+        if (!isStatisticsPollingOn) {
+            LOG.debug("Statistics for device {} is not enabled.", getDeviceInfo().getNodeId().getValue());
             return Futures.immediateFuture(Boolean.TRUE);
         }
         final ListenableFuture<Boolean> errorResultFuture = deviceConnectionCheck();
         if (errorResultFuture != null) {
             return errorResultFuture;
         }
-        synchronized (COLLECTION_STAT_TYPE_LOCK) {
+        synchronized (collectionStatTypeLock) {
             final Iterator<MultipartType> statIterator = collectingStatType.iterator();
             final SettableFuture<Boolean> settableStatResultFuture = SettableFuture.create();
 
@@ -152,41 +168,55 @@ class StatisticsContextImpl implements StatisticsContext {
                 }
                 @Override
                 public void onFailure(final Throwable t) {
-                    StatisticsGatheringUtils.markDeviceStateSnapshotEnd(deviceContext, false);
+                    if (!(t instanceof TransactionChainClosedException)) {
+                        StatisticsGatheringUtils.markDeviceStateSnapshotEnd(deviceContext, false);
+                    }
                 }
             });
+            this.lastDataGathering = settableStatResultFuture;
             return settableStatResultFuture;
         }
     }
 
     private ListenableFuture<Boolean> chooseStat(final MultipartType multipartType, final boolean initial){
+        ListenableFuture<Boolean> result = Futures.immediateCheckedFuture(Boolean.TRUE);
+
         switch (multipartType) {
             case OFPMPFLOW:
-                return collectFlowStatistics(multipartType, initial);
+                result = collectFlowStatistics(multipartType, initial);
+                break;
             case OFPMPTABLE:
-                return collectTableStatistics(multipartType);
+                result = collectTableStatistics(multipartType);
+                break;
             case OFPMPPORTSTATS:
-                return collectPortStatistics(multipartType);
+                result = collectPortStatistics(multipartType);
+                break;
             case OFPMPQUEUE:
-                return collectQueueStatistics(multipartType);
+                result = collectQueueStatistics(multipartType);
+                break;
             case OFPMPGROUPDESC:
-                return collectGroupDescStatistics(multipartType);
+                result = collectGroupDescStatistics(multipartType);
+                break;
             case OFPMPGROUP:
-                return collectGroupStatistics(multipartType);
+                result = collectGroupStatistics(multipartType);
+                break;
             case OFPMPMETERCONFIG:
-                return collectMeterConfigStatistics(multipartType);
+                result = collectMeterConfigStatistics(multipartType);
+                break;
             case OFPMPMETER:
-                return collectMeterStatistics(multipartType);
+                result = collectMeterStatistics(multipartType);
+                break;
             default:
-                LOG.warn("Unsuported Statistics type {}", multipartType);
-                return Futures.immediateCheckedFuture(Boolean.TRUE);
+                LOG.warn("Unsupported Statistics type {}", multipartType);
         }
+
+        return result;
     }
 
 
     @Override
     public <T> RequestContext<T> createRequestContext() {
-        final AbstractRequestContext<T> ret = new AbstractRequestContext<T>(deviceContext.reserveXidForDeviceMessage()) {
+        final AbstractRequestContext<T> ret = new AbstractRequestContext<T>(deviceInfo.reserveXidForDeviceMessage()) {
             @Override
             public void close() {
                 requestContexts.remove(this);
@@ -200,15 +230,22 @@ class StatisticsContextImpl implements StatisticsContext {
     public void close() {
         if (CONTEXT_STATE.TERMINATION.equals(getState())) {
             if (LOG.isDebugEnabled()) {
-                LOG.debug("Statistics context is already in state TERMINATION.");
+                LOG.debug("StatisticsContext for node {} is already in TERMINATION state.", getDeviceInfo().getLOGValue());
             }
         } else {
-            setState(CONTEXT_STATE.TERMINATION);
-            schedulingEnabled = false;
+            try {
+                stopClusterServices().get();
+            } catch (Exception e) {
+                LOG.debug("Failed to close StatisticsContext for node {} with exception: ", getDeviceInfo().getLOGValue(), e);
+            }
+
+            this.state = CONTEXT_STATE.TERMINATION;
+
             for (final Iterator<RequestContext<?>> iterator = Iterators.consumingIterator(requestContexts.iterator());
                  iterator.hasNext(); ) {
                 RequestContextUtil.closeRequestContextWithRpcError(iterator.next(), CONNECTION_CLOSED);
             }
+
             if (null != pollTimeout && !pollTimeout.isExpired()) {
                 pollTimeout.cancel();
             }
@@ -240,17 +277,17 @@ class StatisticsContextImpl implements StatisticsContext {
             final String errMsg = String.format("Device connection is closed for Node : %s.",
                     getDeviceInfo().getNodeId());
             LOG.debug(errMsg);
-            resultFuture.setException(new IllegalStateException(errMsg));
+            resultFuture.setException(new ConnectionException(errMsg));
             return;
         }
         if ( ! iterator.hasNext()) {
             resultFuture.set(Boolean.TRUE);
-            LOG.debug("Stats collection successfully finished for node {}", getDeviceInfo().getNodeId());
+            LOG.debug("Stats collection successfully finished for node {}", getDeviceInfo().getLOGValue());
             return;
         }
 
         final MultipartType nextType = iterator.next();
-        LOG.debug("Stats iterating to next type for node {} of type {}", getDeviceInfo().getNodeId(), nextType);
+        LOG.debug("Stats iterating to next type for node {} of type {}", getDeviceInfo().getLOGValue(), nextType);
 
         final ListenableFuture<Boolean> deviceStatisticsCollectionFuture = chooseStat(nextType, initial);
         Futures.addCallback(deviceStatisticsCollectionFuture, new FutureCallback<Boolean>() {
@@ -392,11 +429,6 @@ class StatisticsContextImpl implements StatisticsContext {
         return this.state;
     }
 
-    @Override
-    public void setState(CONTEXT_STATE state) {
-        this.state = state;
-    }
-
     @Override
     public ServiceGroupIdentifier getServiceIdentifier() {
         return this.deviceInfo.getServiceIdentifier();
@@ -408,13 +440,81 @@ class StatisticsContextImpl implements StatisticsContext {
     }
 
     @Override
-    public void startupClusterServices() throws ExecutionException, InterruptedException {
+    public ListenableFuture<Void> stopClusterServices() {
+        if (CONTEXT_STATE.TERMINATION.equals(getState())) {
+            return Futures.immediateCancelledFuture();
+        }
+
+        return Futures.transform(Futures.immediateFuture(null), new Function<Object, Void>() {
+            @Nullable
+            @Override
+            public Void apply(@Nullable Object input) {
+                schedulingEnabled = false;
+                stopGatheringData();
+                return null;
+            }
+        });
+    }
+
+    @Override
+    public DeviceState gainDeviceState() {
+        return gainDeviceContext().getDeviceState();
+    }
+
+    @Override
+    public DeviceContext gainDeviceContext() {
+        return this.lifecycleService.getDeviceContext();
+    }
+
+    @Override
+    public void stopGatheringData() {
+        if (Objects.nonNull(this.lastDataGathering)) {
+            if (LOG.isDebugEnabled()) {
+                LOG.debug("Stop the running statistics gathering for node {}", this.deviceInfo.getLOGValue());
+            }
+
+            lastDataGathering.cancel(true);
+        }
+    }
+
+    @Override
+    public void setLifecycleInitializationPhaseHandler(final ClusterInitializationPhaseHandler handler) {
+        this.clusterInitializationPhaseHandler = handler;
+    }
+
+    @Override
+    public boolean onContextInstantiateService(final ConnectionContext connectionContext) {
+        if (connectionContext.getConnectionState().equals(ConnectionContext.CONNECTION_STATE.RIP)) {
+            LOG.warn("Connection on device {} was interrupted, will stop starting master services.", deviceInfo.getLOGValue());
+            return false;
+        }
+
+        LOG.info("Starting statistics context cluster services for node {}", deviceInfo.getLOGValue());
+
         this.statListForCollectingInitialization();
-        this.initialGatherDynamicData();
+        Futures.addCallback(this.initialGatherDynamicData(), new FutureCallback<Boolean>() {
+
+            @Override
+            public void onSuccess(@Nullable Boolean aBoolean) {
+                initialSubmitHandler.initialSubmitTransaction();
+            }
+
+            @Override
+            public void onFailure(Throwable throwable) {
+                LOG.warn("Initial gathering statistics unsuccessful for node {}", deviceInfo.getLOGValue());
+                lifecycleService.closeConnection();
+            }
+        });
+
+        if (this.isStatisticsPollingOn) {
+            myManager.startScheduling(deviceInfo);
+        }
+
+        return this.clusterInitializationPhaseHandler.onContextInstantiateService(connectionContext);
     }
 
     @Override
-    public ListenableFuture<Void> stopClusterServices() {
-        return Futures.immediateFuture(null);
+    public void setInitialSubmitHandler(final ClusterInitializationPhaseHandler initialSubmitHandler) {
+        this.initialSubmitHandler = initialSubmitHandler;
     }
-}
+}
\ No newline at end of file