Merge remote-tracking branch 'liblldp/master'
[openflowplugin.git] / openflowplugin-impl / src / main / java / org / opendaylight / openflowplugin / impl / device / DeviceContextImpl.java
index 54c3d77d0baca687bf8911b423fdeb859b3dac31..872a0df1fa5de427253b3f6303068f655ff17639 100644 (file)
@@ -8,18 +8,14 @@
 package org.opendaylight.openflowplugin.impl.device;
 
 import com.google.common.annotations.VisibleForTesting;
-import com.google.common.base.Verify;
-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.JdkFutureAdapters;
 import com.google.common.util.concurrent.ListenableFuture;
+import com.google.common.util.concurrent.MoreExecutors;
 import io.netty.util.HashedWheelTimer;
-import io.netty.util.TimerTask;
 import java.util.Collection;
 import java.util.Collections;
 import java.util.HashSet;
-import java.util.Iterator;
 import java.util.List;
 import java.util.Objects;
 import java.util.Optional;
@@ -27,6 +23,7 @@ import java.util.concurrent.ExecutionException;
 import java.util.concurrent.Future;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.TimeoutException;
+import java.util.concurrent.atomic.AtomicBoolean;
 import javax.annotation.Nonnull;
 import javax.annotation.Nullable;
 import org.opendaylight.controller.md.sal.binding.api.DataBroker;
@@ -36,7 +33,6 @@ import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType;
 import org.opendaylight.mdsal.singleton.common.api.ServiceGroupIdentifier;
 import org.opendaylight.openflowjava.protocol.api.connection.ConnectionAdapter;
 import org.opendaylight.openflowjava.protocol.api.keys.MessageTypeKey;
-import org.opendaylight.openflowplugin.api.ConnectionException;
 import org.opendaylight.openflowplugin.api.OFConstants;
 import org.opendaylight.openflowplugin.api.openflow.connection.ConnectionContext;
 import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext;
@@ -46,35 +42,28 @@ import org.opendaylight.openflowplugin.api.openflow.device.MessageTranslator;
 import org.opendaylight.openflowplugin.api.openflow.device.RequestContext;
 import org.opendaylight.openflowplugin.api.openflow.device.TranslatorLibrary;
 import org.opendaylight.openflowplugin.api.openflow.device.Xid;
-import org.opendaylight.openflowplugin.api.openflow.device.handlers.ClusterInitializationPhaseHandler;
 import org.opendaylight.openflowplugin.api.openflow.device.handlers.MultiMsgCollector;
 import org.opendaylight.openflowplugin.api.openflow.lifecycle.ContextChainMastershipState;
+import org.opendaylight.openflowplugin.api.openflow.lifecycle.ContextChainMastershipWatcher;
 import org.opendaylight.openflowplugin.api.openflow.lifecycle.ContextChainState;
-import org.opendaylight.openflowplugin.api.openflow.lifecycle.MastershipChangeListener;
 import org.opendaylight.openflowplugin.api.openflow.md.core.TranslatorKey;
 import org.opendaylight.openflowplugin.api.openflow.md.util.OpenflowVersion;
-import org.opendaylight.openflowplugin.api.openflow.registry.ItemLifeCycleRegistry;
 import org.opendaylight.openflowplugin.api.openflow.registry.flow.DeviceFlowRegistry;
-import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowDescriptor;
-import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowRegistryKey;
 import org.opendaylight.openflowplugin.api.openflow.registry.group.DeviceGroupRegistry;
 import org.opendaylight.openflowplugin.api.openflow.registry.meter.DeviceMeterRegistry;
-import org.opendaylight.openflowplugin.api.openflow.rpc.ItemLifeCycleKeeper;
-import org.opendaylight.openflowplugin.api.openflow.rpc.listener.ItemLifecycleListener;
 import org.opendaylight.openflowplugin.api.openflow.statistics.ofpspecific.MessageSpy;
+import org.opendaylight.openflowplugin.common.txchain.TransactionChainManager;
 import org.opendaylight.openflowplugin.extension.api.ConvertorMessageFromOFJava;
 import org.opendaylight.openflowplugin.extension.api.ExtensionConverterProviderKeeper;
 import org.opendaylight.openflowplugin.extension.api.core.extension.ExtensionConverterProvider;
 import org.opendaylight.openflowplugin.extension.api.exception.ConversionException;
 import org.opendaylight.openflowplugin.extension.api.path.MessagePath;
-import org.opendaylight.openflowplugin.impl.common.ItemLifeCycleSourceImpl;
 import org.opendaylight.openflowplugin.impl.datastore.MultipartWriterProvider;
 import org.opendaylight.openflowplugin.impl.datastore.MultipartWriterProviderFactory;
 import org.opendaylight.openflowplugin.impl.device.initialization.AbstractDeviceInitializer;
 import org.opendaylight.openflowplugin.impl.device.initialization.DeviceInitializerProvider;
 import org.opendaylight.openflowplugin.impl.device.listener.MultiMsgCollectorImpl;
 import org.opendaylight.openflowplugin.impl.registry.flow.DeviceFlowRegistryImpl;
-import org.opendaylight.openflowplugin.impl.registry.flow.FlowRegistryKeyFactory;
 import org.opendaylight.openflowplugin.impl.registry.group.DeviceGroupRegistryImpl;
 import org.opendaylight.openflowplugin.impl.registry.meter.DeviceMeterRegistryImpl;
 import org.opendaylight.openflowplugin.impl.rpc.AbstractRequestContext;
@@ -85,9 +74,6 @@ import org.opendaylight.openflowplugin.openflow.md.util.InventoryDataServiceUtil
 import org.opendaylight.yang.gen.v1.urn.opendaylight.experimenter.message.service.rev151020.ExperimenterMessageFromDevBuilder;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowCapableNode;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowCapableNodeConnector;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.tables.Table;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.tables.table.Flow;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.tables.table.FlowKey;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorRef;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnector;
@@ -110,16 +96,10 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709.Pa
 import org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709.PacketReceivedBuilder;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.port.statistics.rev131214.FlowCapableNodeConnectorStatisticsData;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.port.statistics.rev131214.FlowCapableNodeConnectorStatisticsDataBuilder;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.OfpRole;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.SalRoleService;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.role.service.rev150727.SetRoleInput;
-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.binding.DataContainer;
 import org.opendaylight.yangtools.yang.binding.DataObject;
 import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
 import org.opendaylight.yangtools.yang.binding.KeyedInstanceIdentifier;
-import org.opendaylight.yangtools.yang.common.RpcResult;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -134,12 +114,12 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
     // TODO: high water mark factor should be parametrized
     private static final float HIGH_WATERMARK_FACTOR = 0.95f;
 
-    // Timeout in seconds after what we will give up on propagating role
-    private static final int SET_ROLE_TIMEOUT = 10;
-
     // Timeout in milliseconds after what we will give up on initializing device
     private static final int DEVICE_INIT_TIMEOUT = 9000;
 
+    // Timeout in milliseconds after what we will give up on closing transaction chain
+    private static final int TX_CHAIN_CLOSE_TIMEOUT = 10000;
+
     private static final int LOW_WATERMARK = 1000;
     private static final int HIGH_WATERMARK = 2000;
 
@@ -149,46 +129,42 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
     private final DataBroker dataBroker;
     private final Collection<RequestContext<?>> requestContexts = new HashSet<>();
     private final MessageSpy messageSpy;
-    private final ItemLifeCycleKeeper flowLifeCycleKeeper;
     private final MessageTranslator<PortGrouping, FlowCapableNodeConnector> portStatusTranslator;
     private final MessageTranslator<PacketInMessage, PacketReceived> packetInTranslator;
-    private final MessageTranslator<FlowRemoved, org.opendaylight.yang.gen.v1.urn.opendaylight.flow.service.rev130819.FlowRemoved> flowRemovedTranslator;
+    private final MessageTranslator<FlowRemoved, org.opendaylight.yang.gen.v1.urn.opendaylight
+            .flow.service.rev130819.FlowRemoved> flowRemovedTranslator;
     private final TranslatorLibrary translatorLibrary;
-    private final ItemLifeCycleRegistry itemLifeCycleSourceRegistry;
     private final ConvertorExecutor convertorExecutor;
     private final DeviceInitializerProvider deviceInitializerProvider;
     private final PacketInRateLimiter packetInLimiter;
     private final DeviceInfo deviceInfo;
+    private final ConnectionContext primaryConnectionContext;
     private final boolean skipTableFeatures;
     private final boolean switchFeaturesMandatory;
     private final boolean isFlowRemovedNotificationOn;
     private final boolean useSingleLayerSerialization;
+    private final AtomicBoolean initialized = new AtomicBoolean(false);
+    private final AtomicBoolean hasState = new AtomicBoolean(false);
+    private final AtomicBoolean isInitialTransactionSubmitted = new AtomicBoolean(false);
     private NotificationPublishService notificationPublishService;
     private TransactionChainManager transactionChainManager;
     private DeviceFlowRegistry deviceFlowRegistry;
     private DeviceGroupRegistry deviceGroupRegistry;
     private DeviceMeterRegistry deviceMeterRegistry;
     private ExtensionConverterProvider extensionConverterProvider;
-    private ClusterInitializationPhaseHandler clusterInitializationPhaseHandler;
-    private SalRoleService salRoleService;
-    private boolean initialized;
-    private boolean hasState;
-    private boolean isInitialTransactionSubmitted;
-    private volatile ConnectionContext primaryConnectionContext;
-    private volatile ContextState state;
-
-    DeviceContextImpl(
-            @Nonnull final ConnectionContext primaryConnectionContext,
-            @Nonnull final DataBroker dataBroker,
-            @Nonnull final MessageSpy messageSpy,
-            @Nonnull final TranslatorLibrary translatorLibrary,
-            final ConvertorExecutor convertorExecutor,
-            final boolean skipTableFeatures,
-            final HashedWheelTimer hashedWheelTimer,
-            final boolean useSingleLayerSerialization,
-            final DeviceInitializerProvider deviceInitializerProvider,
-            final boolean isFlowRemovedNotificationOn,
-            final boolean switchFeaturesMandatory) {
+    private ContextChainMastershipWatcher contextChainMastershipWatcher;
+
+    DeviceContextImpl(@Nonnull final ConnectionContext primaryConnectionContext,
+                      @Nonnull final DataBroker dataBroker,
+                      @Nonnull final MessageSpy messageSpy,
+                      @Nonnull final TranslatorLibrary translatorLibrary,
+                      final ConvertorExecutor convertorExecutor,
+                      final boolean skipTableFeatures,
+                      final HashedWheelTimer hashedWheelTimer,
+                      final boolean useSingleLayerSerialization,
+                      final DeviceInitializerProvider deviceInitializerProvider,
+                      final boolean isFlowRemovedNotificationOn,
+                      final boolean switchFeaturesMandatory) {
 
         this.primaryConnectionContext = primaryConnectionContext;
         this.deviceInfo = primaryConnectionContext.getDeviceInfo();
@@ -207,26 +183,27 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
         this.portStatusTranslator = translatorLibrary.lookupTranslator(
                 new TranslatorKey(deviceInfo.getVersion(), PortGrouping.class.getName()));
         this.packetInTranslator = translatorLibrary.lookupTranslator(
-                new TranslatorKey(deviceInfo.getVersion(), org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731
+                new TranslatorKey(deviceInfo.getVersion(), org.opendaylight.yang.gen.v1.urn.opendaylight.openflow
+                        .protocol.rev130731
                         .PacketIn.class.getName()));
         this.flowRemovedTranslator = translatorLibrary.lookupTranslator(
                 new TranslatorKey(deviceInfo.getVersion(), FlowRemoved.class.getName()));
 
-        this.itemLifeCycleSourceRegistry = new ItemLifeCycleRegistryImpl();
-        this.flowLifeCycleKeeper = new ItemLifeCycleSourceImpl();
-        this.itemLifeCycleSourceRegistry.registerLifeCycleSource(flowLifeCycleKeeper);
-        this.state = ContextState.INITIALIZATION;
         this.convertorExecutor = convertorExecutor;
         this.skipTableFeatures = skipTableFeatures;
         this.useSingleLayerSerialization = useSingleLayerSerialization;
-        this.initialized = false;
         writerProvider = MultipartWriterProviderFactory.createDefaultProvider(this);
     }
 
     @Override
     public boolean initialSubmitTransaction() {
-        return (initialized &&(isInitialTransactionSubmitted =
-                transactionChainManager.initialSubmitWriteTransaction()));
+        if (!initialized.get()) {
+            return false;
+        }
+
+        final boolean initialSubmit = transactionChainManager.initialSubmitWriteTransaction();
+        isInitialTransactionSubmitted.set(initialSubmit);
+        return initialSubmit;
     }
 
     @Override
@@ -241,14 +218,14 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
 
     @Override
     public boolean isTransactionsEnabled() {
-        return isInitialTransactionSubmitted;
+        return isInitialTransactionSubmitted.get();
     }
 
     @Override
     public <T extends DataObject> void writeToTransaction(final LogicalDatastoreType store,
                                                           final InstanceIdentifier<T> path,
-                                                          final T data){
-        if (initialized) {
+                                                          final T data) {
+        if (initialized.get()) {
             transactionChainManager.writeToTransaction(store, path, data, false);
         }
     }
@@ -256,22 +233,23 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
     @Override
     public <T extends DataObject> void writeToTransactionWithParentsSlow(final LogicalDatastoreType store,
                                                                          final InstanceIdentifier<T> path,
-                                                                         final T data){
-        if (initialized) {
+                                                                         final T data) {
+        if (initialized.get()) {
             transactionChainManager.writeToTransaction(store, path, data, true);
         }
     }
 
     @Override
-    public <T extends DataObject> void addDeleteToTxChain(final LogicalDatastoreType store, final InstanceIdentifier<T> path) {
-        if (initialized) {
-            transactionChainManager.addDeleteOperationTotTxChain(store, path);
+    public <T extends DataObject> void addDeleteToTxChain(final LogicalDatastoreType store,
+                                                          final InstanceIdentifier<T> path) {
+        if (initialized.get()) {
+            transactionChainManager.addDeleteOperationToTxChain(store, path);
         }
     }
 
     @Override
     public boolean submitTransaction() {
-        return initialized && transactionChainManager.submitWriteTransaction();
+        return initialized.get() && transactionChainManager.submitTransaction();
     }
 
     @Override
@@ -298,7 +276,7 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
     public void processReply(final OfHeader ofHeader) {
         messageSpy.spyMessage(
                 ofHeader.getImplementedInterface(),
-                (ofHeader instanceof Error)
+                ofHeader instanceof Error
                         ? MessageSpy.StatisticsGroup.FROM_SWITCH_PUBLISHED_FAILURE
                         : MessageSpy.StatisticsGroup.FROM_SWITCH_PUBLISHED_SUCCESS);
     }
@@ -307,7 +285,7 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
     public void processReply(final Xid xid, final List<? extends OfHeader> ofHeaderList) {
         ofHeaderList.forEach(header -> messageSpy.spyMessage(
                 header.getImplementedInterface(),
-                (header instanceof Error)
+                header instanceof Error
                         ? MessageSpy.StatisticsGroup.FROM_SWITCH_PUBLISHED_FAILURE
                         : MessageSpy.StatisticsGroup.FROM_SWITCH_PUBLISHED_SUCCESS));
     }
@@ -322,42 +300,23 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
             // Trigger off a notification
             notificationPublishService.offerNotification(flowRemovedNotification);
         }
-
-        final ItemLifecycleListener itemLifecycleListener = flowLifeCycleKeeper.getItemLifecycleListener();
-        if (itemLifecycleListener != null) {
-            //2. create registry key
-            final FlowRegistryKey flowRegKey = FlowRegistryKeyFactory.create(getDeviceInfo().getVersion(), flowRemovedNotification);
-            //3. lookup flowId
-            final FlowDescriptor flowDescriptor = deviceFlowRegistry.retrieveDescriptor(flowRegKey);
-            //4. if flowId present:
-            if (flowDescriptor != null) {
-                // a) construct flow path
-                final KeyedInstanceIdentifier<Flow, FlowKey> flowPath = getDeviceInfo().getNodeInstanceIdentifier()
-                        .augmentation(FlowCapableNode.class)
-                        .child(Table.class, flowDescriptor.getTableKey())
-                        .child(Flow.class, new FlowKey(flowDescriptor.getFlowId()));
-                // b) notify listener
-                itemLifecycleListener.onRemoved(flowPath);
-            } else {
-                LOG.debug("flow id not found: nodeId={} tableId={}, priority={}",
-                        getDeviceInfo().getNodeId(), flowRegKey.getTableId(), flowRemovedNotification.getPriority());
-            }
-        }
     }
 
     @Override
+    @SuppressWarnings("checkstyle:IllegalCatch")
     public void processPortStatusMessage(final PortStatusMessage portStatus) {
-        messageSpy.spyMessage(portStatus.getImplementedInterface(), MessageSpy.StatisticsGroup.FROM_SWITCH_PUBLISHED_SUCCESS);
+        messageSpy.spyMessage(portStatus.getImplementedInterface(), MessageSpy.StatisticsGroup
+                .FROM_SWITCH_PUBLISHED_SUCCESS);
 
-        if (initialized) {
+        if (initialized.get()) {
             try {
                 writePortStatusMessage(portStatus);
                 submitTransaction();
             } catch (final Exception e) {
                 LOG.warn("Error processing port status message for port {} on device {}",
-                        portStatus.getPortNo(), getDeviceInfo().getLOGValue(), e);
+                        portStatus.getPortNo(), getDeviceInfo(), e);
             }
-        } else if (!hasState) {
+        } else if (!hasState.get()) {
             primaryConnectionContext.handlePortStatusMessage(portStatus);
         }
     }
@@ -374,11 +333,13 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
                                 portStatusMessage.getPortNo(),
                                 OpenflowVersion.get(deviceInfo.getVersion()))));
 
-        if (PortReason.OFPPRADD.equals(portStatusMessage.getReason()) || PortReason.OFPPRMODIFY.equals(portStatusMessage.getReason())) {
+        if (PortReason.OFPPRADD.equals(portStatusMessage.getReason())
+                || PortReason.OFPPRMODIFY.equals(portStatusMessage.getReason())) {
             // because of ADD status node connector has to be created
             writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToNodeConnector, new NodeConnectorBuilder()
                     .setKey(iiToNodeConnector.getKey())
-                    .addAugmentation(FlowCapableNodeConnectorStatisticsData.class, new FlowCapableNodeConnectorStatisticsDataBuilder().build())
+                    .addAugmentation(FlowCapableNodeConnectorStatisticsData.class, new
+                            FlowCapableNodeConnectorStatisticsDataBuilder().build())
                     .addAugmentation(FlowCapableNodeConnector.class, flowCapableNodeConnector)
                     .build());
         } else if (PortReason.OFPPRDELETE.equals(portStatusMessage.getReason())) {
@@ -407,36 +368,33 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
         final OpenflowVersion openflowVersion = OpenflowVersion.get(deviceInfo.getVersion());
 
         // Try to get ingress from match
-        final Optional<NodeConnectorRef> nodeConnectorRef = Optional.ofNullable(match)
-                .flatMap(m -> Optional.ofNullable(m.getInPort()))
-                .flatMap(nodeConnectorId -> Optional.ofNullable(InventoryDataServiceUtil
+        final NodeConnectorRef nodeConnectorRef = Objects.nonNull(packetIn.getIngress())
+                ? packetIn.getIngress() : Optional.ofNullable(match)
+                .map(Match::getInPort)
+                .map(nodeConnectorId -> InventoryDataServiceUtil
                         .portNumberfromNodeConnectorId(
                                 openflowVersion,
-                                nodeConnectorId)))
+                                nodeConnectorId))
                 .map(portNumber -> InventoryDataServiceUtil
                         .nodeConnectorRefFromDatapathIdPortno(
                                 deviceInfo.getDatapathId(),
                                 portNumber,
-                                openflowVersion));
-
-        if (!nodeConnectorRef.isPresent()) {
-            LOG.debug("Received packet from switch {}  but couldn't find an input port", connectionAdapter.getRemoteAddress());
-            messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH_TRANSLATE_SRC_FAILURE);
-            return;
-        }
+                                openflowVersion))
+                .orElse(null);
 
         messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH_TRANSLATE_OUT_SUCCESS);
 
         if (!packetInLimiter.acquirePermit()) {
             LOG.debug("Packet limited");
             // TODO: save packet into emergency slot if possible
-            messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH_PACKET_IN_LIMIT_REACHED_AND_DROPPED);
+            messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup
+                    .FROM_SWITCH_PACKET_IN_LIMIT_REACHED_AND_DROPPED);
             return;
         }
 
         final ListenableFuture<?> offerNotification = notificationPublishService
                 .offerNotification(new PacketReceivedBuilder(packetIn)
-                        .setIngress(nodeConnectorRef.get())
+                        .setIngress(nodeConnectorRef)
                         .setMatch(MatchUtil.transformMatch(match,
                                 org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709.packet.received
                                         .Match.class))
@@ -458,13 +416,14 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
             }
 
             @Override
-            public void onFailure(final Throwable t) {
-                messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH_NOTIFICATION_REJECTED);
-                LOG.debug("notification offer failed: {}", t.getMessage());
-                LOG.trace("notification offer failed..", t);
+            public void onFailure(final Throwable throwable) {
+                messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup
+                        .FROM_SWITCH_NOTIFICATION_REJECTED);
+                LOG.debug("notification offer failed: {}", throwable.getMessage());
+                LOG.trace("notification offer failed..", throwable);
                 packetInLimiter.releasePermit();
             }
-        });
+        }, MoreExecutors.directExecutor());
     }
 
     @Override
@@ -474,7 +433,8 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
         final MessageTypeKey<? extends ExperimenterDataOfChoice> key = new MessageTypeKey<>(
                 getDeviceInfo().getVersion(),
                 (Class<? extends ExperimenterDataOfChoice>) vendorData.getImplementedInterface());
-        final ConvertorMessageFromOFJava<ExperimenterDataOfChoice, MessagePath> messageConverter = extensionConverterProvider.getMessageConverter(key);
+        final ConvertorMessageFromOFJava<ExperimenterDataOfChoice, MessagePath> messageConverter =
+                extensionConverterProvider.getMessageConverter(key);
         if (messageConverter == null) {
             LOG.warn("custom converter for {}[OF:{}] not found",
                     notification.getExperimenterDataOfChoice().getImplementedInterface(),
@@ -485,7 +445,8 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
         final ExperimenterMessageOfChoice messageOfChoice;
         try {
             messageOfChoice = messageConverter.convert(vendorData, MessagePath.MESSAGE_NOTIFICATION);
-            final ExperimenterMessageFromDevBuilder experimenterMessageFromDevBld = new ExperimenterMessageFromDevBuilder()
+            final ExperimenterMessageFromDevBuilder experimenterMessageFromDevBld = new
+                    ExperimenterMessageFromDevBuilder()
                     .setNode(new NodeRef(getDeviceInfo().getNodeInstanceIdentifier()))
                     .setExperimenterMessageOfChoice(messageOfChoice);
             // publish
@@ -529,24 +490,19 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
 
     @Override
     public void onPublished() {
-        Verify.verify(ContextState.INITIALIZATION.equals(state));
-        this.state = ContextState.WORKING;
         primaryConnectionContext.getConnectionAdapter().setPacketInFiltering(false);
     }
 
     @Override
-    public <T extends OfHeader> MultiMsgCollector<T> getMultiMsgCollector(final RequestContext<List<T>> requestContext) {
+    public <T extends OfHeader> MultiMsgCollector<T> getMultiMsgCollector(final RequestContext<List<T>>
+                                                                                      requestContext) {
         return new MultiMsgCollectorImpl<>(this, requestContext);
     }
 
     @Override
     public void updatePacketInRateLimit(final long upperBound) {
-        packetInLimiter.changeWaterMarks((int) (LOW_WATERMARK_FACTOR * upperBound), (int) (HIGH_WATERMARK_FACTOR * upperBound));
-    }
-
-    @Override
-    public ItemLifeCycleRegistry getItemLifeCycleSourceRegistry() {
-        return itemLifeCycleSourceRegistry;
+        packetInLimiter.changeWaterMarks((int) (LOW_WATERMARK_FACTOR * upperBound),
+                (int) (HIGH_WATERMARK_FACTOR * upperBound));
     }
 
     @Override
@@ -565,15 +521,18 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
     }
 
     @Override
-    public ListenableFuture<Void> stopClusterServices() {
-        return initialized
+    public ListenableFuture<Void> closeServiceInstance() {
+        final ListenableFuture<Void> listenableFuture = initialized.get()
                 ? transactionChainManager.deactivateTransactionManager()
                 : Futures.immediateFuture(null);
-    }
 
-    @Override
-    public ServiceGroupIdentifier getServiceIdentifier() {
-        return this.deviceInfo.getServiceIdentifier();
+        hashedWheelTimer.newTimeout((timerTask) -> {
+            if (!listenableFuture.isDone() && !listenableFuture.isCancelled()) {
+                listenableFuture.cancel(true);
+            }
+        }, TX_CHAIN_CLOSE_TIMEOUT, TimeUnit.MILLISECONDS);
+
+        return listenableFuture;
     }
 
     @Override
@@ -582,25 +541,27 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
     }
 
     @Override
-    public void close() {
-        if (ContextState.TERMINATION.equals(state)) {
-            if (LOG.isDebugEnabled()) {
-                LOG.debug("DeviceContext for node {} is already in TERMINATION state.", getDeviceInfo().getLOGValue());
-            }
-
-            return;
-        }
+    public void registerMastershipWatcher(@Nonnull final ContextChainMastershipWatcher newWatcher) {
+        this.contextChainMastershipWatcher = newWatcher;
+    }
 
-        state = ContextState.TERMINATION;
+    @Nonnull
+    @Override
+    public ServiceGroupIdentifier getIdentifier() {
+        return deviceInfo.getServiceIdentifier();
+    }
 
+    @Override
+    public void close() {
         // Close all datastore registries and transactions
-        if (initialized) {
-            initialized = false;
+        if (initialized.getAndSet(false)) {
             deviceGroupRegistry.close();
             deviceFlowRegistry.close();
             deviceMeterRegistry.close();
 
-            Futures.addCallback(transactionChainManager.shuttingDown(), new FutureCallback<Void>() {
+            final ListenableFuture<Void> txChainShuttingDown = transactionChainManager.shuttingDown();
+
+            Futures.addCallback(txChainShuttingDown, new FutureCallback<Void>() {
                 @Override
                 public void onSuccess(@Nullable final Void result) {
                     transactionChainManager.close();
@@ -608,17 +569,16 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
                 }
 
                 @Override
-                public void onFailure(final Throwable t) {
+                public void onFailure(final Throwable throwable) {
                     transactionChainManager.close();
                     transactionChainManager = null;
                 }
-            });
+            }, MoreExecutors.directExecutor());
         }
 
-        for (final Iterator<RequestContext<?>> iterator = Iterators
-                .consumingIterator(requestContexts.iterator()); iterator.hasNext();) {
-            RequestContextUtil.closeRequestContextWithRpcError(iterator.next(), "Connection closed.");
-        }
+        requestContexts.forEach(requestContext -> RequestContextUtil
+                .closeRequestContextWithRpcError(requestContext, "Connection closed."));
+        requestContexts.clear();
     }
 
     @Override
@@ -626,19 +586,10 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
         return useSingleLayerSerialization && getDeviceInfo().getVersion() >= OFConstants.OFP_VERSION_1_3;
     }
 
+    // TODO: exception handling should be fixed by using custom checked exception, never RuntimeExceptions
     @Override
-    public void setSalRoleService(@Nonnull SalRoleService salRoleService) {
-        this.salRoleService = salRoleService;
-    }
-
-    @Override
-    public void setLifecycleInitializationPhaseHandler(final ClusterInitializationPhaseHandler handler) {
-        this.clusterInitializationPhaseHandler = handler;
-    }
-
-    @Override
-    public boolean onContextInstantiateService(final MastershipChangeListener mastershipChangeListener) {
-        LOG.info("Starting device context cluster services for node {}", deviceInfo.getLOGValue());
+    @SuppressWarnings({"checkstyle:IllegalCatch"})
+    public void instantiateServiceInstance() {
         lazyTransactionManagerInitialization();
 
         try {
@@ -648,51 +599,56 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
             portStatusMessages.forEach(this::writePortStatusMessage);
             submitTransaction();
         } catch (final Exception ex) {
-            LOG.warn("Error processing port status messages from device {}", getDeviceInfo().getLOGValue(), ex);
-            return false;
+            throw new RuntimeException(String.format("Error processing port status messages from device %s: %s",
+                    deviceInfo.toString(), ex.toString()), ex);
         }
 
-        try {
-            final Optional<AbstractDeviceInitializer> initializer = deviceInitializerProvider
-                    .lookup(deviceInfo.getVersion());
-
-            if (initializer.isPresent()) {
-                initializer
-                        .get()
-                        .initialize(this, switchFeaturesMandatory, skipTableFeatures, writerProvider, convertorExecutor)
-                        .get(DEVICE_INIT_TIMEOUT, TimeUnit.MILLISECONDS);
-            } else {
-                throw new ExecutionException(new ConnectionException("Unsupported version " + deviceInfo.getVersion()));
+        final Optional<AbstractDeviceInitializer> initializer = deviceInitializerProvider
+                .lookup(deviceInfo.getVersion());
+
+        if (initializer.isPresent()) {
+            final Future<Void> initialize = initializer
+                    .get()
+                    .initialize(this, switchFeaturesMandatory, skipTableFeatures, writerProvider, convertorExecutor);
+
+            try {
+                initialize.get(DEVICE_INIT_TIMEOUT, TimeUnit.MILLISECONDS);
+            } catch (TimeoutException ex) {
+                initialize.cancel(true);
+                throw new RuntimeException(String.format("Failed to initialize device %s in %ss: %s",
+                        deviceInfo.toString(), String.valueOf(DEVICE_INIT_TIMEOUT / 1000), ex.toString()), ex);
+            } catch (ExecutionException | InterruptedException ex) {
+                throw new RuntimeException(
+                        String.format("Device %s cannot be initialized: %s", deviceInfo.toString(), ex.toString()), ex);
             }
-        } catch (ExecutionException | InterruptedException | TimeoutException ex) {
-            LOG.warn("Device {} cannot be initialized: {}", deviceInfo.getLOGValue(), ex.getMessage());
-            LOG.trace("Device {} cannot be initialized: ", deviceInfo.getLOGValue(), ex);
-            return false;
+        } else {
+            throw new RuntimeException(String.format("Unsupported version %s for device %s",
+                    deviceInfo.getVersion(),
+                    deviceInfo.toString()));
         }
 
-        Futures.addCallback(sendRoleChangeToDevice(OfpRole.BECOMEMASTER),
-                new RpcResultFutureCallback(mastershipChangeListener));
-
-        final ListenableFuture<List<com.google.common.base.Optional<FlowCapableNode>>> deviceFlowRegistryFill = getDeviceFlowRegistry().fill();
+        final ListenableFuture<List<com.google.common.base.Optional<FlowCapableNode>>> deviceFlowRegistryFill =
+                getDeviceFlowRegistry().fill();
         Futures.addCallback(deviceFlowRegistryFill,
-                new DeviceFlowRegistryCallback(deviceFlowRegistryFill, mastershipChangeListener));
-
-        return this.clusterInitializationPhaseHandler.onContextInstantiateService(mastershipChangeListener);
+                new DeviceFlowRegistryCallback(deviceFlowRegistryFill, contextChainMastershipWatcher),
+                MoreExecutors.directExecutor());
     }
 
     @VisibleForTesting
     void lazyTransactionManagerInitialization() {
-        if (!this.initialized) {
+        if (!this.initialized.get()) {
             if (LOG.isDebugEnabled()) {
-                LOG.debug("Transaction chain manager for node {} created", deviceInfo.getLOGValue());
+                LOG.debug("Transaction chain manager for node {} created", deviceInfo);
             }
-            this.transactionChainManager = new TransactionChainManager(dataBroker, deviceInfo);
-            this.deviceFlowRegistry = new DeviceFlowRegistryImpl(deviceInfo.getVersion(), dataBroker, deviceInfo.getNodeInstanceIdentifier());
+            this.transactionChainManager = new TransactionChainManager(dataBroker, deviceInfo.getNodeId().getValue());
+            this.deviceFlowRegistry = new DeviceFlowRegistryImpl(deviceInfo.getVersion(), dataBroker,
+                    deviceInfo.getNodeInstanceIdentifier());
             this.deviceGroupRegistry = new DeviceGroupRegistryImpl();
             this.deviceMeterRegistry = new DeviceMeterRegistryImpl();
-            this.transactionChainManager.activateTransactionManager();
-            this.initialized = true;
         }
+
+        transactionChainManager.activateTransactionManager();
+        initialized.set(true);
     }
 
     @Nullable
@@ -711,81 +667,21 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
         return abstractRequestContext;
     }
 
-    private 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 {} sec", newRole, deviceInfo.getLOGValue(), SET_ROLE_TIMEOUT);
-                    setRoleOutputFuture.cancel(true);
-                }
-            };
-
-            hashedWheelTimer.newTimeout(timerTask, SET_ROLE_TIMEOUT, 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 ListenableFuture<RpcResult<SetRoleOutput>> makeDeviceSlave() {
-        return sendRoleChangeToDevice(OfpRole.BECOMESLAVE);
-    }
-
     @Override
     public void onStateAcquired(final ContextChainState state) {
-        hasState = true;
-    }
-
-    private class RpcResultFutureCallback implements FutureCallback<RpcResult<SetRoleOutput>> {
-
-        private final MastershipChangeListener mastershipChangeListener;
-
-        RpcResultFutureCallback(final MastershipChangeListener mastershipChangeListener) {
-            this.mastershipChangeListener = mastershipChangeListener;
-        }
-
-        @Override
-        public void onSuccess(@Nullable RpcResult<SetRoleOutput> setRoleOutputRpcResult) {
-            this.mastershipChangeListener.onMasterRoleAcquired(
-                    deviceInfo,
-                    ContextChainMastershipState.MASTER_ON_DEVICE
-            );
-            if (LOG.isDebugEnabled()) {
-                LOG.debug("Role MASTER was successfully set on device, node {}", deviceInfo.getLOGValue());
-            }
-        }
-
-        @Override
-        public void onFailure(final Throwable throwable) {
-            mastershipChangeListener.onNotAbleToStartMastershipMandatory(
-                    deviceInfo,
-                    "Was not able to set MASTER role on device");
-        }
+        hasState.set(true);
     }
 
-    private class DeviceFlowRegistryCallback implements FutureCallback<List<com.google.common.base.Optional<FlowCapableNode>>> {
+    private class DeviceFlowRegistryCallback implements FutureCallback<List<com.google.common.base
+            .Optional<FlowCapableNode>>> {
         private final ListenableFuture<List<com.google.common.base.Optional<FlowCapableNode>>> deviceFlowRegistryFill;
-        private final MastershipChangeListener mastershipChangeListener;
+        private final ContextChainMastershipWatcher contextChainMastershipWatcher;
 
         DeviceFlowRegistryCallback(
                 ListenableFuture<List<com.google.common.base.Optional<FlowCapableNode>>> deviceFlowRegistryFill,
-                MastershipChangeListener mastershipChangeListener) {
+                ContextChainMastershipWatcher contextChainMastershipWatcher) {
             this.deviceFlowRegistryFill = deviceFlowRegistryFill;
-            this.mastershipChangeListener = mastershipChangeListener;
+            this.contextChainMastershipWatcher = contextChainMastershipWatcher;
         }
 
         @Override
@@ -810,21 +706,23 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi
                         .filter(Objects::nonNull)
                         .count();
 
-                LOG.debug("Finished filling flow registry with {} flows for node: {}", flowCount, deviceInfo.getLOGValue());
+                LOG.debug("Finished filling flow registry with {} flows for node: {}", flowCount, deviceInfo);
             }
-            this.mastershipChangeListener.onMasterRoleAcquired(deviceInfo, ContextChainMastershipState.INITIAL_FLOW_REGISTRY_FILL);
+            this.contextChainMastershipWatcher.onMasterRoleAcquired(deviceInfo, ContextChainMastershipState
+                    .INITIAL_FLOW_REGISTRY_FILL);
         }
 
         @Override
-        public void onFailure(Throwable t) {
+        public void onFailure(Throwable throwable) {
             if (deviceFlowRegistryFill.isCancelled()) {
                 if (LOG.isDebugEnabled()) {
-                    LOG.debug("Cancelled filling flow registry with flows for node: {}", deviceInfo.getLOGValue());
+                    LOG.debug("Cancelled filling flow registry with flows for node: {}", deviceInfo);
                 }
             } else {
-                LOG.warn("Failed filling flow registry with flows for node: {} with exception: {}", deviceInfo.getLOGValue(), t);
+                LOG.warn("Failed filling flow registry with flows for node: {} with exception: {}", deviceInfo,
+                         throwable);
             }
-            mastershipChangeListener.onNotAbleToStartMastership(
+            contextChainMastershipWatcher.onNotAbleToStartMastership(
                     deviceInfo,
                     "Was not able to fill flow registry on device",
                     false);