Optimized imports
[openflowplugin.git] / openflowplugin-impl / src / main / java / org / opendaylight / openflowplugin / impl / statistics / StatisticsContextImpl.java
index 4e74a51de50410469d31124bf8d6f9856e15e6e7..5d560025855ee71ebf4d292df4ce54d1f9c81d15 100644 (file)
 
 package org.opendaylight.openflowplugin.impl.statistics;
 
+import com.google.common.annotations.VisibleForTesting;
 import com.google.common.base.Preconditions;
+import com.google.common.collect.ImmutableList;
+import com.google.common.collect.Iterators;
 import com.google.common.util.concurrent.FutureCallback;
 import com.google.common.util.concurrent.Futures;
 import com.google.common.util.concurrent.ListenableFuture;
 import com.google.common.util.concurrent.SettableFuture;
-import java.util.Arrays;
+import io.netty.util.Timeout;
+import java.util.ArrayList;
 import java.util.Collection;
 import java.util.HashSet;
+import java.util.Iterator;
 import java.util.List;
+import java.util.Optional;
 import javax.annotation.CheckForNull;
+import javax.annotation.Nonnull;
+import javax.annotation.Nullable;
+import javax.annotation.concurrent.GuardedBy;
 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.rpc.listener.ItemLifecycleListener;
 import org.opendaylight.openflowplugin.api.openflow.statistics.StatisticsContext;
 import org.opendaylight.openflowplugin.impl.rpc.AbstractRequestContext;
+import org.opendaylight.openflowplugin.impl.rpc.listener.ItemLifecycleListenerImpl;
 import org.opendaylight.openflowplugin.impl.services.RequestContextUtil;
+import org.opendaylight.openflowplugin.impl.statistics.services.dedicated.StatisticsGatheringOnTheFlyService;
 import org.opendaylight.openflowplugin.impl.statistics.services.dedicated.StatisticsGatheringService;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.common.types.rev130731.MultipartType;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-/**
- * Created by Martin Bobak <mbobak@cisco.com> on 1.4.2015.
- */
-public class StatisticsContextImpl implements StatisticsContext {
+class StatisticsContextImpl implements StatisticsContext {
 
     private static final Logger LOG = LoggerFactory.getLogger(StatisticsContextImpl.class);
     private static final String CONNECTION_CLOSED = "Connection closed.";
+
+    private final ItemLifecycleListener itemLifeCycleListener;
     private final Collection<RequestContext<?>> requestContexts = new HashSet<>();
     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();
+    @GuardedBy("COLLECTION_STAT_TYPE_LOCK")
+    private List<MultipartType> collectingStatType;
 
-    private final StatisticsGatheringService statisticsGatheringService;
+    private StatisticsGatheringService statisticsGatheringService;
+    private StatisticsGatheringOnTheFlyService statisticsGatheringOnTheFlyService;
+    private Timeout pollTimeout;
 
-    public StatisticsContextImpl(@CheckForNull final DeviceContext deviceContext) {
-        this.deviceContext = Preconditions.checkNotNull(deviceContext);
-        devState = Preconditions.checkNotNull(deviceContext.getDeviceState());
-        emptyFuture = Futures.immediateFuture(new Boolean(false));
+    private volatile boolean schedulingEnabled;
+
+    StatisticsContextImpl(@CheckForNull final DeviceInfo deviceInfo, final boolean shuttingDownStatisticsPolling, final LifecycleConductor lifecycleConductor) {
+        this.deviceContext = Preconditions.checkNotNull(lifecycleConductor.getDeviceContext(deviceInfo));
+        this.devState = Preconditions.checkNotNull(deviceContext.getDeviceState());
+        this.shuttingDownStatisticsPolling = shuttingDownStatisticsPolling;
+        emptyFuture = Futures.immediateFuture(false);
         statisticsGatheringService = new StatisticsGatheringService(this, deviceContext);
+        statisticsGatheringOnTheFlyService = new StatisticsGatheringOnTheFlyService(this, deviceContext);
+        itemLifeCycleListener = new ItemLifecycleListenerImpl(deviceContext);
+        statListForCollectingInitialization();
     }
 
     @Override
-    public ListenableFuture<Boolean> gatherDynamicData() {
-        final SettableFuture<Boolean> settableResultingFuture = SettableFuture.create();
-        final ListenableFuture<Boolean> flowStatistics = gatherDynamicData(MultipartType.OFPMPFLOW);
-        final ListenableFuture<Boolean> tableStatistics = gatherDynamicData(MultipartType.OFPMPTABLE);
-        final ListenableFuture<Boolean> portStatistics = gatherDynamicData(MultipartType.OFPMPPORTSTATS);
-        final ListenableFuture<Boolean> queueStatistics = gatherDynamicData(MultipartType.OFPMPQUEUE);
-        final ListenableFuture<Boolean> groupDescStatistics = gatherDynamicData(MultipartType.OFPMPGROUPDESC);
-        final ListenableFuture<Boolean> groupStatistics = gatherDynamicData(MultipartType.OFPMPGROUP);
-        final ListenableFuture<Boolean> meterConfigStatistics = gatherDynamicData(MultipartType.OFPMPMETERCONFIG);
-        final ListenableFuture<Boolean> meterStatistics = gatherDynamicData(MultipartType.OFPMPMETER);
-
-        final ListenableFuture<List<Boolean>> allFutures = Futures.allAsList(Arrays.asList(flowStatistics, tableStatistics, groupDescStatistics, groupStatistics, meterConfigStatistics, meterStatistics, portStatistics, queueStatistics));
-        Futures.addCallback(allFutures, new FutureCallback<List<Boolean>>() {
-            @Override
-            public void onSuccess(final List<Boolean> booleans) {
-                boolean atLeastOneSuccess = false;
-                for (final Boolean bool : booleans) {
-                    atLeastOneSuccess |= bool.booleanValue();
-                }
-                settableResultingFuture.set(new Boolean(atLeastOneSuccess));
+    public void statListForCollectingInitialization() {
+        synchronized (COLLECTION_STAT_TYPE_LOCK) {
+            final List<MultipartType> statListForCollecting = new ArrayList<>();
+            if (devState.isTableStatisticsAvailable()) {
+                statListForCollecting.add(MultipartType.OFPMPTABLE);
             }
-
-            @Override
-            public void onFailure(final Throwable throwable) {
-                settableResultingFuture.setException(throwable);
+            if (devState.isFlowStatisticsAvailable()) {
+                statListForCollecting.add(MultipartType.OFPMPFLOW);
             }
-        });
-        return settableResultingFuture;
+            if (devState.isGroupAvailable()) {
+                statListForCollecting.add(MultipartType.OFPMPGROUPDESC);
+                statListForCollecting.add(MultipartType.OFPMPGROUP);
+            }
+            if (devState.isMetersAvailable()) {
+                statListForCollecting.add(MultipartType.OFPMPMETERCONFIG);
+                statListForCollecting.add(MultipartType.OFPMPMETER);
+            }
+            if (devState.isPortStatisticsAvailable()) {
+                statListForCollecting.add(MultipartType.OFPMPPORTSTATS);
+            }
+            if (devState.isQueueStatisticsAvailable()) {
+                statListForCollecting.add(MultipartType.OFPMPQUEUE);
+            }
+            collectingStatType = ImmutableList.<MultipartType>copyOf(statListForCollecting);
+        }
     }
 
+
     @Override
-    public ListenableFuture<Boolean> gatherDynamicData(final MultipartType multipartType) {
-        Preconditions.checkArgument(multipartType != null);
-        final ListenableFuture<Boolean> resultingFuture = deviceConnectionCheck();
-        if (resultingFuture != null) {
-            return resultingFuture;
+    public ListenableFuture<Boolean> initialGatherDynamicData() {
+        return gatherDynamicData(true);
+    }
+
+    @Override
+    public ListenableFuture<Boolean> gatherDynamicData(){
+        return gatherDynamicData(false);
+    }
+
+    private ListenableFuture<Boolean> gatherDynamicData(final boolean initial) {
+        if (shuttingDownStatisticsPolling) {
+            LOG.debug("Statistics for device {} is not enabled.", deviceContext.getDeviceInfo().getNodeId());
+            return Futures.immediateFuture(Boolean.TRUE);
+        }
+        final ListenableFuture<Boolean> errorResultFuture = deviceConnectionCheck();
+        if (errorResultFuture != null) {
+            return errorResultFuture;
+        }
+        synchronized (COLLECTION_STAT_TYPE_LOCK) {
+            final Iterator<MultipartType> statIterator = collectingStatType.iterator();
+            final SettableFuture<Boolean> settableStatResultFuture = SettableFuture.create();
+
+            // write start timestamp to state snapshot container
+            StatisticsGatheringUtils.markDeviceStateSnapshotStart(deviceContext);
+
+            statChainFuture(statIterator, settableStatResultFuture, initial);
+
+            // write end timestamp to state snapshot container
+            Futures.addCallback(settableStatResultFuture, new FutureCallback<Boolean>() {
+                @Override
+                public void onSuccess(@Nullable final Boolean result) {
+                    StatisticsGatheringUtils.markDeviceStateSnapshotEnd(deviceContext, true);
+                }
+                @Override
+                public void onFailure(final Throwable t) {
+                    StatisticsGatheringUtils.markDeviceStateSnapshotEnd(deviceContext, false);
+                }
+            });
+            return settableStatResultFuture;
         }
+    }
+
+    private ListenableFuture<Boolean> chooseStat(final MultipartType multipartType, final boolean initial){
         switch (multipartType) {
-        case OFPMPFLOW:
-            return collectFlowStatistics(multipartType);
-        case OFPMPTABLE:
-            return collectTableStatistics(multipartType);
-        case OFPMPPORTSTATS:
-            return collectPortStatistics(multipartType);
-        case OFPMPQUEUE:
-            return collectQueueStatistics(multipartType);
-        case OFPMPGROUPDESC:
-            return collectGroupDescStatistics(multipartType);
-        case OFPMPGROUP:
-            return collectGroupStatistics(multipartType);
-        case OFPMPMETERCONFIG:
-            return collectMeterConfigStatistics(multipartType);
-        case OFPMPMETER:
-            return collectMeterStatistics(multipartType);
-        default:
-            LOG.warn("Unsuported Statistics type {}", multipartType);
-            return Futures.immediateCheckedFuture(Boolean.TRUE);
+            case OFPMPFLOW:
+                return collectFlowStatistics(multipartType, initial);
+            case OFPMPTABLE:
+                return collectTableStatistics(multipartType);
+            case OFPMPPORTSTATS:
+                return collectPortStatistics(multipartType);
+            case OFPMPQUEUE:
+                return collectQueueStatistics(multipartType);
+            case OFPMPGROUPDESC:
+                return collectGroupDescStatistics(multipartType);
+            case OFPMPGROUP:
+                return collectGroupStatistics(multipartType);
+            case OFPMPMETERCONFIG:
+                return collectMeterConfigStatistics(multipartType);
+            case OFPMPMETER:
+                return collectMeterStatistics(multipartType);
+            default:
+                LOG.warn("Unsuported Statistics type {}", multipartType);
+                return Futures.immediateCheckedFuture(Boolean.TRUE);
         }
     }
 
+
     @Override
     public <T> RequestContext<T> createRequestContext() {
-        final AbstractRequestContext<T> ret = new AbstractRequestContext<T>(deviceContext.getReservedXid()) {
+        final AbstractRequestContext<T> ret = new AbstractRequestContext<T>(deviceContext.reserveXidForDeviceMessage()) {
             @Override
             public void close() {
                 requestContexts.remove(this);
@@ -126,72 +187,186 @@ public class StatisticsContextImpl implements StatisticsContext {
 
     @Override
     public void close() {
-        for (final RequestContext<?> requestContext : requestContexts) {
-            RequestContextUtil.closeRequestContextWithRpcError(requestContext, CONNECTION_CLOSED);
+        schedulingEnabled = false;
+        for (final Iterator<RequestContext<?>> iterator = Iterators.consumingIterator(requestContexts.iterator());
+                iterator.hasNext();) {
+            RequestContextUtil.closeRequestContextWithRpcError(iterator.next(), CONNECTION_CLOSED);
+        }
+        if (null != pollTimeout && !pollTimeout.isExpired()) {
+            pollTimeout.cancel();
         }
     }
 
+    @Override
+    public void setSchedulingEnabled(final boolean schedulingEnabled) {
+        this.schedulingEnabled = schedulingEnabled;
+    }
+
+    @Override
+    public boolean isSchedulingEnabled() {
+        return schedulingEnabled;
+    }
+
+    @Override
+    public void setPollTimeout(final Timeout pollTimeout) {
+        this.pollTimeout = pollTimeout;
+    }
+
+    @Override
+    public Optional<Timeout> getPollTimeout() {
+        return Optional.ofNullable(pollTimeout);
+    }
+
+    private void statChainFuture(final Iterator<MultipartType> iterator, final SettableFuture<Boolean> resultFuture, final boolean initial) {
+        if (ConnectionContext.CONNECTION_STATE.RIP.equals(deviceContext.getPrimaryConnectionContext().getConnectionState())) {
+            final String errMsg = String.format("Device connection is closed for Node : %s.",
+                    deviceContext.getDeviceInfo().getNodeId());
+            LOG.debug(errMsg);
+            resultFuture.setException(new IllegalStateException(errMsg));
+            return;
+        }
+        if ( ! iterator.hasNext()) {
+            resultFuture.set(Boolean.TRUE);
+            LOG.debug("Stats collection successfully finished for node {}", deviceContext.getDeviceInfo().getNodeId());
+            return;
+        }
+
+        final MultipartType nextType = iterator.next();
+        LOG.debug("Stats iterating to next type for node {} of type {}", deviceContext.getDeviceInfo().getNodeId(), nextType);
+
+        final ListenableFuture<Boolean> deviceStatisticsCollectionFuture = chooseStat(nextType, initial);
+        Futures.addCallback(deviceStatisticsCollectionFuture, new FutureCallback<Boolean>() {
+            @Override
+            public void onSuccess(final Boolean result) {
+                statChainFuture(iterator, resultFuture, initial);
+            }
+            @Override
+            public void onFailure(@Nonnull final Throwable t) {
+                resultFuture.setException(t);
+            }
+        });
+    }
+
     /**
      * Method checks a device state. It returns null for be able continue. Otherwise it returns immediateFuture
      * which has to be returned from caller too
      *
      * @return
      */
-    private ListenableFuture<Boolean> deviceConnectionCheck() {
-        if ( ! ConnectionContext.CONNECTION_STATE.WORKING.equals(deviceContext.getPrimaryConnectionContext().getConnectionState())) {
-            ListenableFuture<Boolean> resultingFuture = SettableFuture.create();
+    @VisibleForTesting
+    ListenableFuture<Boolean> deviceConnectionCheck() {
+        if (!ConnectionContext.CONNECTION_STATE.WORKING.equals(deviceContext.getPrimaryConnectionContext().getConnectionState())) {
+            ListenableFuture<Boolean> resultingFuture;
             switch (deviceContext.getPrimaryConnectionContext().getConnectionState()) {
-            case RIP:
-                final String errMsg = String.format("Device connection doesn't exist anymore. Primary connection status : %s",
-                        deviceContext.getPrimaryConnectionContext().getConnectionState());
-                resultingFuture = Futures.immediateFailedFuture(new Throwable(errMsg));
-                break;
-            default:
-                resultingFuture = Futures.immediateCheckedFuture(Boolean.TRUE);
-                break;
+                case RIP:
+                    final String errMsg = String.format("Device connection doesn't exist anymore. Primary connection status : %s",
+                            deviceContext.getPrimaryConnectionContext().getConnectionState());
+                    resultingFuture = Futures.immediateFailedFuture(new Throwable(errMsg));
+                    break;
+                default:
+                    resultingFuture = Futures.immediateCheckedFuture(Boolean.TRUE);
+                    break;
             }
             return resultingFuture;
         }
         return null;
     }
 
-    private ListenableFuture<Boolean> collectFlowStatistics(final MultipartType multipartType) {
+    //TODO: Refactor twice sending deviceContext into gatheringStatistics
+    private ListenableFuture<Boolean> collectFlowStatistics(final MultipartType multipartType, final boolean initial) {
         return devState.isFlowStatisticsAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPFLOW*/ multipartType) : emptyFuture;
+                statisticsGatheringOnTheFlyService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPFLOW*/ multipartType,
+                deviceContext,
+                deviceContext,
+                initial) : emptyFuture;
     }
 
     private ListenableFuture<Boolean> collectTableStatistics(final MultipartType multipartType) {
         return devState.isTableStatisticsAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPTABLE*/ multipartType) : emptyFuture;
+                statisticsGatheringService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPTABLE*/ multipartType,
+                deviceContext,
+                deviceContext,
+                false) : emptyFuture;
     }
 
     private ListenableFuture<Boolean> collectPortStatistics(final MultipartType multipartType) {
         return devState.isPortStatisticsAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPPORTSTATS*/ multipartType) : emptyFuture;
+                statisticsGatheringService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPPORTSTATS*/ multipartType,
+                deviceContext,
+                deviceContext,
+                false) : emptyFuture;
     }
 
     private ListenableFuture<Boolean> collectQueueStatistics(final MultipartType multipartType) {
-        return devState.isQueueStatisticsAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPQUEUE*/ multipartType) : emptyFuture;
+        return !devState.isQueueStatisticsAvailable() ? emptyFuture : StatisticsGatheringUtils.gatherStatistics(
+                statisticsGatheringService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPQUEUE*/ multipartType,
+                deviceContext,
+                deviceContext,
+                false);
     }
 
     private ListenableFuture<Boolean> collectGroupDescStatistics(final MultipartType multipartType) {
         return devState.isGroupAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPGROUPDESC*/ multipartType) : emptyFuture;
+                statisticsGatheringService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPGROUPDESC*/ multipartType,
+                deviceContext,
+                deviceContext,
+                false) : emptyFuture;
     }
 
     private ListenableFuture<Boolean> collectGroupStatistics(final MultipartType multipartType) {
         return devState.isGroupAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPGROUP*/ multipartType) : emptyFuture;
+                statisticsGatheringService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPGROUP*/ multipartType,
+                deviceContext,
+                deviceContext,
+                false) : emptyFuture;
     }
 
     private ListenableFuture<Boolean> collectMeterConfigStatistics(final MultipartType multipartType) {
         return devState.isMetersAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPMETERCONFIG*/ multipartType) : emptyFuture;
+                statisticsGatheringService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPMETERCONFIG*/ multipartType,
+                deviceContext,
+                deviceContext,
+                false) : emptyFuture;
     }
 
     private ListenableFuture<Boolean> collectMeterStatistics(final MultipartType multipartType) {
         return devState.isMetersAvailable() ? StatisticsGatheringUtils.gatherStatistics(
-                statisticsGatheringService, deviceContext, /*MultipartType.OFPMPMETER*/ multipartType) : emptyFuture;
+                statisticsGatheringService,
+                deviceContext.getDeviceInfo(),
+                /*MultipartType.OFPMPMETER*/ multipartType,
+                deviceContext,
+                deviceContext,
+                false) : emptyFuture;
     }
+
+    @VisibleForTesting
+    void setStatisticsGatheringService(final StatisticsGatheringService statisticsGatheringService) {
+        this.statisticsGatheringService = statisticsGatheringService;
+    }
+
+    @VisibleForTesting
+    void setStatisticsGatheringOnTheFlyService(final StatisticsGatheringOnTheFlyService
+                                                             statisticsGatheringOnTheFlyService) {
+        this.statisticsGatheringOnTheFlyService = statisticsGatheringOnTheFlyService;
+    }
+
+    @Override
+    public ItemLifecycleListener getItemLifeCycleListener () {
+        return itemLifeCycleListener;
+    }
+
 }