Bug 6665 - Fix switches scalability
[openflowplugin.git] / openflowplugin-impl / src / main / java / org / opendaylight / openflowplugin / impl / role / RoleContextImpl.java
index 7fc9739892fcfb7aba176f25679aaf8d0f9164ad..b636c9fb3021aa379c9651fca999c8ff84be70ca 100644 (file)
@@ -7,35 +7,31 @@
  */
 package org.opendaylight.openflowplugin.impl.role;
 
-import javax.annotation.Nullable;
-import java.util.concurrent.Future;
-
 import com.google.common.annotations.VisibleForTesting;
+import com.google.common.base.Function;
 import com.google.common.base.Preconditions;
-import com.google.common.base.Verify;
-import com.google.common.util.concurrent.AsyncFunction;
 import com.google.common.util.concurrent.FutureCallback;
 import com.google.common.util.concurrent.Futures;
 import com.google.common.util.concurrent.JdkFutureAdapters;
 import com.google.common.util.concurrent.ListenableFuture;
-import io.netty.util.Timeout;
+import io.netty.util.HashedWheelTimer;
 import io.netty.util.TimerTask;
+
+import java.util.concurrent.ExecutionException;
 import java.util.concurrent.Future;
-import java.util.concurrent.Semaphore;
 import java.util.concurrent.TimeUnit;
+import javax.annotation.Nonnull;
 import javax.annotation.Nullable;
-import org.opendaylight.controller.md.sal.common.api.clustering.CandidateAlreadyRegisteredException;
-import org.opendaylight.controller.md.sal.common.api.clustering.Entity;
-import org.opendaylight.controller.md.sal.common.api.clustering.EntityOwnershipCandidateRegistration;
-import org.opendaylight.controller.md.sal.common.api.clustering.EntityOwnershipService;
+import org.opendaylight.mdsal.singleton.common.api.ServiceGroupIdentifier;
 import org.opendaylight.openflowplugin.api.OFConstants;
 import org.opendaylight.openflowplugin.api.openflow.connection.ConnectionContext;
-import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext;
-import org.opendaylight.openflowplugin.api.openflow.device.DeviceState;
+import org.opendaylight.openflowplugin.api.openflow.device.DeviceInfo;
 import org.opendaylight.openflowplugin.api.openflow.device.RequestContext;
+import org.opendaylight.openflowplugin.api.openflow.device.handlers.ClusterInitializationPhaseHandler;
+import org.opendaylight.openflowplugin.api.openflow.lifecycle.LifecycleService;
 import org.opendaylight.openflowplugin.api.openflow.role.RoleContext;
+import org.opendaylight.openflowplugin.api.openflow.role.RoleManager;
 import org.opendaylight.openflowplugin.impl.rpc.AbstractRequestContext;
-import org.opendaylight.openflowplugin.impl.services.SalRoleServiceImpl;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.OfpRole;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.SalRoleService;
@@ -43,196 +39,166 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.SetR
 import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.SetRoleInputBuilder;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.SetRoleOutput;
 import org.opendaylight.yangtools.yang.common.RpcResult;
-import org.opendaylight.yangtools.yang.common.RpcResultBuilder;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * Created by kramesha on 9/12/15.
+ * Role context try to make change device role on device
  */
-public class RoleContextImpl implements RoleContext {
-    private static final Logger LOG = LoggerFactory.getLogger(RoleContextImpl.class);
-
-    private final EntityOwnershipService entityOwnershipService;
-    private EntityOwnershipCandidateRegistration entityOwnershipCandidateRegistration;
-    private EntityOwnershipCandidateRegistration txEntityOwnershipCandidateRegistration;
-
-    private final DeviceContext deviceContext;
-
-    private final Entity entity;
-    private final Entity txEntity;
-
-    private SalRoleService salRoleService;
+class RoleContextImpl implements RoleContext {
 
-    private final Semaphore mainCandidateGuard = new Semaphore(1, true);
-    private final Semaphore txCandidateGuard = new Semaphore(1, true);
+    private static final Logger LOG = LoggerFactory.getLogger(RoleContextImpl.class);
 
-    public RoleContextImpl(final DeviceContext deviceContext, final EntityOwnershipService entityOwnershipService,
-                           final Entity entity, final Entity txEntity) {
-        this.entityOwnershipService = Preconditions.checkNotNull(entityOwnershipService);
-        this.deviceContext = Preconditions.checkNotNull(deviceContext);
-        this.entity = Preconditions.checkNotNull(entity);
-        this.txEntity = Preconditions.checkNotNull(txEntity);
-        salRoleService = new SalRoleServiceImpl(this, deviceContext);
+    private SalRoleService salRoleService = null;
+    private final HashedWheelTimer hashedWheelTimer;
+    private final DeviceInfo deviceInfo;
+    private CONTEXT_STATE state;
+    private final RoleManager myManager;
+    private ClusterInitializationPhaseHandler clusterInitializationPhaseHandler;
+    private final LifecycleService lifecycleService;
+
+    RoleContextImpl(final DeviceInfo deviceInfo,
+                    final HashedWheelTimer hashedWheelTimer,
+                    final RoleManager myManager,
+                    final LifecycleService lifecycleService) {
+        this.deviceInfo = deviceInfo;
+        this.state = CONTEXT_STATE.WORKING;
+        this.myManager = myManager;
+        this.hashedWheelTimer = hashedWheelTimer;
+        this.lifecycleService = lifecycleService;
     }
 
+    @Nullable
     @Override
-    public void initialization() throws CandidateAlreadyRegisteredException {
-        LOG.debug("Initialization RoleContext for Node {}", deviceContext.getDeviceState().getNodeId());
-        final AsyncFunction<RpcResult<SetRoleOutput>, Void> initFunction = new AsyncFunction<RpcResult<SetRoleOutput>, Void>() {
+    public <T> RequestContext<T> createRequestContext() {
+        return new AbstractRequestContext<T>(deviceInfo.reserveXidForDeviceMessage()) {
             @Override
-            public ListenableFuture<Void> apply(final RpcResult<SetRoleOutput> input) throws Exception {
-                LOG.debug("Initialization request OpenflowEntityOwnership for entity {}", entity);
-                getDeviceState().setRole(OfpRole.BECOMESLAVE);
-                entityOwnershipCandidateRegistration = entityOwnershipService.registerCandidate(entity);
-                LOG.debug("RoleContextImpl : Candidate registered with ownership service for device :{}", deviceContext
-                        .getPrimaryConnectionContext().getNodeId().getValue());
-                return Futures.immediateFuture(null);
+            public void close() {
             }
         };
-        final ListenableFuture<Void> roleChange = sendRoleChangeToDevice(OfpRole.BECOMESLAVE, initFunction);
-        Futures.addCallback(roleChange, new FutureCallback<Void>() {
-
-            @Override
-            public void onSuccess(final Void result) {
-                LOG.debug("Initial RoleContext for Node {} is successful", deviceContext.getDeviceState().getNodeId());
-            }
-
-            @Override
-            public void onFailure(final Throwable t) {
-                LOG.warn("Initial RoleContext for Node {} fail", deviceContext.getDeviceState().getNodeId(), t);
-                deviceContext.close();
-            }
-        });
     }
 
     @Override
-    public ListenableFuture<Void> onRoleChanged(final OfpRole oldRole, final OfpRole newRole) {
-        LOG.trace("onRoleChanged method call for Entity {}", entity);
-
-        if (!isDeviceConnected()) {
-            // this can happen as after the disconnect, we still get a last message from EntityOwnershipService.
-            LOG.info("Device {} is disconnected from this node. Hence not attempting a role change.",
-                    deviceContext.getPrimaryConnectionContext().getNodeId());
-            LOG.debug("SetRole cancelled for entity [{}], reason = device disconnected.", entity);
-            return Futures.immediateFailedFuture(new Exception(
-                    "Device disconnected - stopped by setRole: " + deviceContext
-                            .getPrimaryConnectionContext().getNodeId()));
-        }
-
-        LOG.debug("Role change received from ownership listener from {} to {} for device:{}", oldRole, newRole,
-                deviceContext.getPrimaryConnectionContext().getNodeId());
-
-        final AsyncFunction<RpcResult<SetRoleOutput>, Void> roleChangeFunction = new AsyncFunction<RpcResult<SetRoleOutput>, Void>() {
-            @Override
-            public ListenableFuture<Void> apply(final RpcResult<SetRoleOutput> setRoleOutputRpcResult) throws Exception {
-                LOG.debug("Role change {} successful made on switch :{}", newRole, deviceContext.getDeviceState()
-                        .getNodeId());
-                getDeviceState().setRole(newRole);
-                return deviceContext.onClusterRoleChange(oldRole, newRole);
-            }
-        };
-        return sendRoleChangeToDevice(newRole, roleChangeFunction);
+    public void setSalRoleService(@Nonnull final SalRoleService salRoleService) {
+        Preconditions.checkNotNull(salRoleService);
+        this.salRoleService = salRoleService;
     }
 
     @Override
-    public void setupTxCandidate() throws CandidateAlreadyRegisteredException {
-        LOG.debug("setupTxCandidate for entity {} and Transaction entity {}", entity, txEntity);
-        Verify.verify(txEntity != null);
-
-        txEntityOwnershipCandidateRegistration = entityOwnershipService.registerCandidate(txEntity);
+    public CONTEXT_STATE getState() {
+        return this.state;
     }
 
     @Override
-    public void close() {
-        if (entityOwnershipCandidateRegistration != null) {
-            LOG.debug("Closing EntityOwnershipCandidateRegistration for {}", entity);
-            entityOwnershipCandidateRegistration.close();
-        }
+    public void setState(CONTEXT_STATE state) {
+        this.state = state;
     }
 
     @Override
-    public Entity getEntity() {
-        return entity;
+    public ServiceGroupIdentifier getServiceIdentifier() {
+        return this.deviceInfo.getServiceIdentifier();
     }
 
     @Override
-    public Entity getTxEntity() {
-        return txEntity;
+    public DeviceInfo getDeviceInfo() {
+        return this.deviceInfo;
     }
 
-    private boolean isDeviceConnected() {
-        return ConnectionContext.CONNECTION_STATE.WORKING.equals(
-                deviceContext.getPrimaryConnectionContext().getConnectionState());
+    public void startupClusterServices() throws ExecutionException, InterruptedException {
+        Futures.addCallback(sendRoleChangeToDevice(OfpRole.BECOMEMASTER), new RpcResultFutureCallback());
     }
 
-    @Nullable
     @Override
-    public <T> RequestContext<T> createRequestContext() {
-        final AbstractRequestContext<T> ret = new AbstractRequestContext<T>(deviceContext.reservedXidForDeviceMessage()) {
-            @Override
-            public void close() {
-            }
-        };
-        return ret;
-    }
+    public ListenableFuture<Void> stopClusterServices(final boolean deviceDisconnected) {
 
-    @VisibleForTesting
-    void setSalRoleService(final SalRoleService salRoleService) {
-        this.salRoleService = salRoleService;
+        if (!deviceDisconnected) {
+            ListenableFuture<Void> future = Futures.transform(makeDeviceSlave(), new Function<RpcResult<SetRoleOutput>, Void>() {
+                @Nullable
+                @Override
+                public Void apply(@Nullable RpcResult<SetRoleOutput> setRoleOutputRpcResult) {
+                    return null;
+                }
+            });
+
+            Futures.addCallback(future, new FutureCallback<Void>() {
+                @Override
+                public void onSuccess(@Nullable Void aVoid) {
+                    if (LOG.isDebugEnabled()) {
+                        LOG.debug("Role SLAVE was successfully propagated on device, node {}", deviceInfo.getLOGValue());
+                    }
+                }
+
+                @Override
+                public void onFailure(final Throwable throwable) {
+                    LOG.warn("Was not able to set role SLAVE to device on node {} ", deviceInfo.getLOGValue());
+                    LOG.trace("Error occurred on device role setting, probably connection loss: ", throwable);
+                    myManager.removeDeviceFromOperationalDS(deviceInfo);
+                }
+            });
+            return future;
+        } else {
+            return myManager.removeDeviceFromOperationalDS(deviceInfo);
+        }
     }
 
     @Override
-    public DeviceState getDeviceState() {
-        return deviceContext.getDeviceState();
+    public ListenableFuture<RpcResult<SetRoleOutput>> makeDeviceSlave(){
+        return sendRoleChangeToDevice(OfpRole.BECOMESLAVE);
     }
 
-    @Override
-    public void suspendTxCandidate() {
-        if (txEntityOwnershipCandidateRegistration != null) {
-            txEntityOwnershipCandidateRegistration.close();
-            txEntityOwnershipCandidateRegistration = null;
+    @VisibleForTesting
+    ListenableFuture<RpcResult<SetRoleOutput>> sendRoleChangeToDevice(final OfpRole newRole) {
+        if (LOG.isDebugEnabled()) {
+            LOG.debug("Sending new role {} to device {}", newRole, deviceInfo.getNodeId());
+        }
+        final Future<RpcResult<SetRoleOutput>> setRoleOutputFuture;
+        if (deviceInfo.getVersion() >= OFConstants.OFP_VERSION_1_3) {
+            final SetRoleInput setRoleInput = (new SetRoleInputBuilder()).setControllerRole(newRole)
+                    .setNode(new NodeRef(deviceInfo.getNodeInstanceIdentifier())).build();
+            setRoleOutputFuture = this.salRoleService.setRole(setRoleInput);
+            final TimerTask timerTask = timeout -> {
+                if (!setRoleOutputFuture.isDone()) {
+                    LOG.warn("New role {} was not propagated to device {} during 5 sec", newRole, deviceInfo.getLOGValue());
+                    setRoleOutputFuture.cancel(true);
+                }
+            };
+            hashedWheelTimer.newTimeout(timerTask, 5, TimeUnit.SECONDS);
+        } else {
+            LOG.info("Device: {} with version: {} does not support role", deviceInfo.getLOGValue(), deviceInfo.getVersion());
+            return Futures.immediateFuture(null);
         }
+        return JdkFutureAdapters.listenInPoolThread(setRoleOutputFuture);
     }
 
     @Override
-    public DeviceContext getDeviceContext() {
-        return deviceContext;
+    public void setLifecycleInitializationPhaseHandler(final ClusterInitializationPhaseHandler handler) {
+        this.clusterInitializationPhaseHandler = handler;
     }
 
     @Override
-    public Semaphore getMainCandidateGuard() {
-        return mainCandidateGuard;
-    }
+    public boolean onContextInstantiateService(final ConnectionContext connectionContext) {
 
-    @Override
-    public Semaphore getTxCandidateGuard() {
-        return txCandidateGuard;
+        if (connectionContext.getConnectionState().equals(ConnectionContext.CONNECTION_STATE.RIP)) {
+            LOG.warn("Connection on device {} was interrupted, will stop starting master services.", deviceInfo.getLOGValue());
+            return false;
+        }
+
+        Futures.addCallback(sendRoleChangeToDevice(OfpRole.BECOMEMASTER), new RpcResultFutureCallback());
+        return this.clusterInitializationPhaseHandler.onContextInstantiateService(connectionContext);
     }
 
-    private ListenableFuture<Void> sendRoleChangeToDevice(final OfpRole newRole, final AsyncFunction<RpcResult<SetRoleOutput>, Void> function) {
-        LOG.debug("Send new role {} to device {}", newRole, deviceContext.getDeviceState().getNodeId());
-        final Future<RpcResult<SetRoleOutput>> setRoleOutputFuture;
-        if (deviceContext.getDeviceState().getFeatures().getVersion() < OFConstants.OFP_VERSION_1_3) {
-            LOG.debug("Device OF version {} not support ROLE", deviceContext.getDeviceState().getFeatures().getVersion());
-            setRoleOutputFuture = Futures.immediateFuture(RpcResultBuilder.<SetRoleOutput> success().build());
-        } else {
-            final SetRoleInput setRoleInput = (new SetRoleInputBuilder()).setControllerRole(newRole)
-                    .setNode(new NodeRef(deviceContext.getDeviceState().getNodeInstanceIdentifier())).build();
-            setRoleOutputFuture = salRoleService.setRole(setRoleInput);
-            final TimerTask timerTask = new TimerTask() {
+    private class RpcResultFutureCallback implements FutureCallback<RpcResult<SetRoleOutput>> {
+        @Override
+        public void onSuccess(@Nullable RpcResult<SetRoleOutput> setRoleOutputRpcResult) {
+            if (LOG.isDebugEnabled()) {
+                LOG.debug("Role MASTER was successfully set on device, node {}", deviceInfo.getLOGValue());
+            }
+        }
 
-                @Override
-                public void run(final Timeout timeout) throws Exception {
-                    if (!setRoleOutputFuture.isDone()) {
-                        LOG.info("New role {} was not propagated to device {} during 10 sec. Close connection immediately.",
-                                newRole, deviceContext.getDeviceState().getNodeId());
-                        deviceContext.close();
-                    }
-                }
-            };
-            deviceContext.getTimer().newTimeout(timerTask, 10, TimeUnit.SECONDS);
+        @Override
+        public void onFailure(final Throwable throwable) {
+            LOG.warn("Was not able to set MASTER role on device, node {}", deviceInfo.getLOGValue());
+            lifecycleService.closeConnection();
         }
-        return Futures.transform(JdkFutureAdapters.listenInPoolThread(setRoleOutputFuture), function);
     }
 }