X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?a=blobdiff_plain;f=openflowplugin-impl%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fopenflowplugin%2Fimpl%2Fdevice%2FDeviceContextImpl.java;h=c44a2605bb375cb0e898e34c09b81a21a685f7eb;hb=cfe3a97837951ebbedb337dc988027f10c49f714;hp=92f28aa6af636a37ae2503fbfd0f5c49013ffda0;hpb=a12f9f020650faad66c9390b566c3a3275afebc3;p=openflowplugin.git diff --git a/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceContextImpl.java b/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceContextImpl.java index 92f28aa6af..c44a2605bb 100644 --- a/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceContextImpl.java +++ b/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceContextImpl.java @@ -1,4 +1,4 @@ -/** +/* * Copyright (c) 2015 Cisco Systems, Inc. and others. All rights reserved. * * This program and the accompanying materials are made available under the @@ -8,114 +8,101 @@ package org.opendaylight.openflowplugin.impl.device; import com.google.common.annotations.VisibleForTesting; -import com.google.common.base.Optional; -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 edu.umd.cs.findbugs.annotations.SuppressFBWarnings; import io.netty.util.HashedWheelTimer; -import io.netty.util.Timeout; -import io.netty.util.TimerTask; import java.util.Collection; -import java.util.HashSet; -import java.util.Iterator; +import java.util.Collections; import java.util.List; import java.util.Objects; +import java.util.Optional; +import java.util.concurrent.ConcurrentHashMap; 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; -import org.opendaylight.controller.md.sal.binding.api.NotificationPublishService; -import org.opendaylight.controller.md.sal.binding.api.ReadOnlyTransaction; -import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType; +import org.opendaylight.mdsal.binding.api.DataBroker; +import org.opendaylight.mdsal.binding.api.NotificationPublishService; +import org.opendaylight.mdsal.binding.api.ReadTransaction; +import org.opendaylight.mdsal.common.api.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; import org.opendaylight.openflowplugin.api.openflow.device.DeviceInfo; -import org.opendaylight.openflowplugin.api.openflow.device.DeviceManager; import org.opendaylight.openflowplugin.api.openflow.device.DeviceState; 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.ContextChain; +import org.opendaylight.openflowplugin.api.openflow.lifecycle.ContextChainHolder; 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; import org.opendaylight.openflowplugin.impl.services.util.RequestContextUtil; +import org.opendaylight.openflowplugin.impl.util.MatchUtil; import org.opendaylight.openflowplugin.openflow.md.core.sal.convertor.ConvertorExecutor; 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; import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnectorKey; +import org.opendaylight.yang.gen.v1.urn.opendaylight.model.match.types.rev131026.Match; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.common.types.rev130731.PortReason; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.Error; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.ExperimenterMessage; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.FlowRemoved; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.OfHeader; -import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PacketIn; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PacketInMessage; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PortGrouping; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PortStatus; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PortStatusMessage; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.experimenter.core.ExperimenterDataOfChoice; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflowplugin.experimenter.types.rev151020.experimenter.core.message.ExperimenterMessageOfChoice; +import org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709.PacketIn; import org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709.PacketReceived; +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; @@ -130,71 +117,70 @@ 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; - private final MultipartWriterProvider writerProvider; - - private boolean initialized; - private SalRoleService salRoleService = null; + private final MultipartWriterProvider writerProvider; private final HashedWheelTimer hashedWheelTimer; - private volatile ConnectionContext primaryConnectionContext; private final DeviceState deviceState; private final DataBroker dataBroker; - private final Collection> requestContexts = new HashSet<>(); - private TransactionChainManager transactionChainManager; - private DeviceFlowRegistry deviceFlowRegistry; - private DeviceGroupRegistry deviceGroupRegistry; - private DeviceMeterRegistry deviceMeterRegistry; - private PacketInRateLimiter packetInLimiter; + private final Collection> requestContexts = ConcurrentHashMap.newKeySet(); private final MessageSpy messageSpy; - private final ItemLifeCycleKeeper flowLifeCycleKeeper; - private NotificationPublishService notificationPublishService; - private Timeout barrierTaskTimeout; private final MessageTranslator portStatusTranslator; private final MessageTranslator packetInTranslator; - private final MessageTranslator flowRemovedTranslator; + private final MessageTranslator flowRemovedTranslator; private final TranslatorLibrary translatorLibrary; - private final ItemLifeCycleRegistry itemLifeCycleSourceRegistry; - private ExtensionConverterProvider extensionConverterProvider; - private boolean skipTableFeatures; - private boolean switchFeaturesMandatory; - private DeviceInfo deviceInfo; private final ConvertorExecutor convertorExecutor; - private volatile ContextState state; - private ClusterInitializationPhaseHandler clusterInitializationPhaseHandler; - private final DeviceManager myManager; 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 boolean hasState; - private boolean isInitialTransactionSubmitted; - - DeviceContextImpl( - @Nonnull final ConnectionContext primaryConnectionContext, - @Nonnull final DataBroker dataBroker, - @Nonnull final MessageSpy messageSpy, - @Nonnull final TranslatorLibrary translatorLibrary, - @Nonnull final DeviceManager contextManager, - final ConvertorExecutor convertorExecutor, - final boolean skipTableFeatures, - final HashedWheelTimer hashedWheelTimer, - final boolean useSingleLayerSerialization, - final DeviceInitializerProvider deviceInitializerProvider) { + private final AtomicBoolean initialized = new AtomicBoolean(false); + private final AtomicBoolean hasState = new AtomicBoolean(false); + private final AtomicBoolean isInitialTransactionSubmitted = new AtomicBoolean(false); + private final ContextChainHolder contextChainHolder; + private NotificationPublishService notificationPublishService; + private TransactionChainManager transactionChainManager; + private DeviceFlowRegistry deviceFlowRegistry; + private DeviceGroupRegistry deviceGroupRegistry; + private DeviceMeterRegistry deviceMeterRegistry; + private ExtensionConverterProvider extensionConverterProvider; + 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, + final ContextChainHolder contextChainHolder) { this.primaryConnectionContext = primaryConnectionContext; this.deviceInfo = primaryConnectionContext.getDeviceInfo(); this.hashedWheelTimer = hashedWheelTimer; this.deviceInitializerProvider = deviceInitializerProvider; - this.myManager = contextManager; + this.isFlowRemovedNotificationOn = isFlowRemovedNotificationOn; + this.switchFeaturesMandatory = switchFeaturesMandatory; this.deviceState = new DeviceStateImpl(); this.dataBroker = dataBroker; this.messageSpy = messageSpy; + this.contextChainHolder = contextChainHolder; this.packetInLimiter = new PacketInRateLimiter(primaryConnectionContext.getConnectionAdapter(), /*initial*/ LOW_WATERMARK, /*initial*/HIGH_WATERMARK, this.messageSpy, REJECTED_DRAIN_FACTOR); @@ -203,25 +189,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(), PacketIn.class.getName())); + 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 @@ -230,20 +218,20 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi } @Override - public ReadOnlyTransaction getReadTransaction() { + public ReadTransaction getReadTransaction() { return dataBroker.newReadOnlyTransaction(); } @Override public boolean isTransactionsEnabled() { - return isInitialTransactionSubmitted; + return isInitialTransactionSubmitted.get(); } @Override public void writeToTransaction(final LogicalDatastoreType store, final InstanceIdentifier path, - final T data){ - if (initialized) { + final T data) { + if (initialized.get()) { transactionChainManager.writeToTransaction(store, path, data, false); } } @@ -251,22 +239,28 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi @Override public void writeToTransactionWithParentsSlow(final LogicalDatastoreType store, final InstanceIdentifier path, - final T data){ - if (initialized) { + final T data) { + if (initialized.get()) { transactionChainManager.writeToTransaction(store, path, data, true); } } @Override - public void addDeleteToTxChain(final LogicalDatastoreType store, final InstanceIdentifier path) { - if (initialized) { - transactionChainManager.addDeleteOperationTotTxChain(store, path); + public void addDeleteToTxChain(final LogicalDatastoreType store, + final InstanceIdentifier path) { + if (initialized.get()) { + transactionChainManager.addDeleteOperationToTxChain(store, path); } } @Override public boolean submitTransaction() { - return initialized && transactionChainManager.submitWriteTransaction(); + return initialized.get() && transactionChainManager.submitTransaction(); + } + + @Override + public boolean syncSubmitTransaction() { + return initialized.get() && transactionChainManager.submitTransaction(true); } @Override @@ -293,7 +287,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); } @@ -302,59 +296,43 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi public void processReply(final Xid xid, final List 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)); } @Override public void processFlowRemovedMessage(final FlowRemoved flowRemoved) { - //1. translate to general flow (table, priority, match, cookie) - final org.opendaylight.yang.gen.v1.urn.opendaylight.flow.service.rev130819.FlowRemoved flowRemovedNotification = - flowRemovedTranslator.translate(flowRemoved, deviceInfo, null); - - if(myManager.isFlowRemovedNotificationOn()) { - // Trigger off a notification - notificationPublishService.offerNotification(flowRemovedNotification); - } else if(LOG.isDebugEnabled()) { - LOG.debug("For nodeId={} isNotificationFlowRemovedOn={}", getDeviceInfo().getLOGValue(), myManager.isFlowRemovedNotificationOn()); - } - - 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 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()); + if (isMasterOfDevice()) { + //1. translate to general flow (table, priority, match, cookie) + final org.opendaylight.yang.gen.v1.urn.opendaylight.flow.service.rev130819 + .FlowRemoved flowRemovedNotification = flowRemovedTranslator + .translate(flowRemoved, deviceInfo, null); + + if (isFlowRemovedNotificationOn) { + // Trigger off a notification + notificationPublishService.offerNotification(flowRemovedNotification); } + } else { + LOG.debug("Controller is not owner of the device {}, skipping Flow Removed message", + deviceInfo.getLOGValue()); } } @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); } } @@ -371,43 +349,88 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi portStatusMessage.getPortNo(), OpenflowVersion.get(deviceInfo.getVersion())))); - 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(FlowCapableNodeConnector.class, flowCapableNodeConnector) - .build()); - } else if (PortReason.OFPPRDELETE.equals(portStatusMessage.getReason())) { + writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToNodeConnector, new NodeConnectorBuilder() + .withKey(iiToNodeConnector.getKey()) + .addAugmentation(FlowCapableNodeConnectorStatisticsData.class, new + FlowCapableNodeConnectorStatisticsDataBuilder().build()) + .addAugmentation(FlowCapableNodeConnector.class, flowCapableNodeConnector) + .build()); + syncSubmitTransaction(); + if (PortReason.OFPPRDELETE.equals(portStatusMessage.getReason())) { addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, iiToNodeConnector); + syncSubmitTransaction(); } } @Override public void processPacketInMessage(final PacketInMessage packetInMessage) { - messageSpy.spyMessage(packetInMessage.getImplementedInterface(), MessageSpy.StatisticsGroup.FROM_SWITCH); + if (isMasterOfDevice()) { + final PacketReceived packetReceived = packetInTranslator.translate(packetInMessage, getDeviceInfo(), null); + handlePacketInMessage(packetReceived, packetInMessage.getImplementedInterface(), packetReceived.getMatch()); + } else { + LOG.debug("Controller is not owner of the device {}, skipping packet_in message", deviceInfo.getLOGValue()); + } + } + + private Boolean isMasterOfDevice() { + final ContextChain contextChain = contextChainHolder.getContextChain(deviceInfo); + boolean result = false; + if (contextChain != null) { + result = contextChain.isMastered(ContextChainMastershipState.CHECK, false); + } + return result; + } + + private void handlePacketInMessage(final PacketIn packetIn, + final Class implementedInterface, + final Match match) { + messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH); final ConnectionAdapter connectionAdapter = getPrimaryConnectionContext().getConnectionAdapter(); - final PacketReceived packetReceived = packetInTranslator.translate(packetInMessage, getDeviceInfo(), null); - if (packetReceived == null) { + if (packetIn == null) { LOG.debug("Received a null packet from switch {}", connectionAdapter.getRemoteAddress()); - messageSpy.spyMessage(packetInMessage.getImplementedInterface(), MessageSpy.StatisticsGroup.FROM_SWITCH_TRANSLATE_SRC_FAILURE); + messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH_TRANSLATE_SRC_FAILURE); return; - } else { - messageSpy.spyMessage(packetReceived.getImplementedInterface(), MessageSpy.StatisticsGroup.FROM_SWITCH_TRANSLATE_OUT_SUCCESS); } + final OpenflowVersion openflowVersion = OpenflowVersion.get(deviceInfo.getVersion()); + + // Try to get ingress from match + final NodeConnectorRef nodeConnectorRef = Objects.nonNull(packetIn.getIngress()) + ? packetIn.getIngress() : Optional.ofNullable(match) + .map(Match::getInPort) + .map(nodeConnectorId -> InventoryDataServiceUtil + .portNumberfromNodeConnectorId( + openflowVersion, + nodeConnectorId)) + .map(portNumber -> InventoryDataServiceUtil + .nodeConnectorRefFromDatapathIdPortno( + deviceInfo.getDatapathId(), + portNumber, + 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(packetReceived.getImplementedInterface(), 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(packetReceived); + final ListenableFuture offerNotification = notificationPublishService + .offerNotification(new PacketReceivedBuilder(packetIn) + .setIngress(nodeConnectorRef) + .setMatch(MatchUtil.transformMatch(match, + org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709.packet.received + .Match.class)) + .build()); + if (NotificationPublishService.REJECTED.equals(offerNotification)) { LOG.debug("notification offer rejected"); - messageSpy.spyMessage(packetReceived.getImplementedInterface(), MessageSpy.StatisticsGroup.FROM_SWITCH_NOTIFICATION_REJECTED); + messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH_NOTIFICATION_REJECTED); packetInLimiter.drainLowWaterMark(); packetInLimiter.releasePermit(); return; @@ -416,61 +439,79 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi Futures.addCallback(offerNotification, new FutureCallback() { @Override public void onSuccess(final Object result) { - messageSpy.spyMessage(packetReceived.getImplementedInterface(), MessageSpy.StatisticsGroup.FROM_SWITCH_PUBLISHED_SUCCESS); + messageSpy.spyMessage(implementedInterface, MessageSpy.StatisticsGroup.FROM_SWITCH_PUBLISHED_SUCCESS); packetInLimiter.releasePermit(); } @Override - public void onFailure(final Throwable t) { - messageSpy.spyMessage(packetReceived.getImplementedInterface(), 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 public void processExperimenterMessage(final ExperimenterMessage notification) { - // lookup converter - final ExperimenterDataOfChoice vendorData = notification.getExperimenterDataOfChoice(); - final MessageTypeKey key = new MessageTypeKey<>( - getDeviceInfo().getVersion(), - (Class) vendorData.getImplementedInterface()); - final ConvertorMessageFromOFJava messageConverter = extensionConverterProvider.getMessageConverter(key); - if (messageConverter == null) { - LOG.warn("custom converter for {}[OF:{}] not found", - notification.getExperimenterDataOfChoice().getImplementedInterface(), - getDeviceInfo().getVersion()); - return; - } - // build notification - final ExperimenterMessageOfChoice messageOfChoice; - try { - messageOfChoice = messageConverter.convert(vendorData, MessagePath.MESSAGE_NOTIFICATION); - final ExperimenterMessageFromDevBuilder experimenterMessageFromDevBld = new ExperimenterMessageFromDevBuilder() - .setNode(new NodeRef(getDeviceInfo().getNodeInstanceIdentifier())) - .setExperimenterMessageOfChoice(messageOfChoice); - // publish - notificationPublishService.offerNotification(experimenterMessageFromDevBld.build()); - } catch (final ConversionException e) { - LOG.error("Conversion of experimenter notification failed", e); + if (isMasterOfDevice()) { + // lookup converter + final ExperimenterDataOfChoice vendorData = notification.getExperimenterDataOfChoice(); + final MessageTypeKey key = new MessageTypeKey<>( + getDeviceInfo().getVersion(), + (Class) vendorData.getImplementedInterface()); + final ConvertorMessageFromOFJava messageConverter = + extensionConverterProvider.getMessageConverter(key); + if (messageConverter == null) { + LOG.warn("custom converter for {}[OF:{}] not found", + notification.getExperimenterDataOfChoice().getImplementedInterface(), + getDeviceInfo().getVersion()); + return; + } + // build notification + final ExperimenterMessageOfChoice messageOfChoice; + try { + messageOfChoice = messageConverter.convert(vendorData, MessagePath.MESSAGE_NOTIFICATION); + final ExperimenterMessageFromDevBuilder experimenterMessageFromDevBld = new + ExperimenterMessageFromDevBuilder() + .setNode(new NodeRef(getDeviceInfo().getNodeInstanceIdentifier())) + .setExperimenterMessageOfChoice(messageOfChoice); + // publish + notificationPublishService.offerNotification(experimenterMessageFromDevBld.build()); + } catch (final ConversionException e) { + LOG.error("Conversion of experimenter notification failed", e); + } + } else { + LOG.debug("Controller is not owner of the device {}, skipping experimenter message", + deviceInfo.getLOGValue()); } } @Override - public TranslatorLibrary oook() { - return translatorLibrary; - } + // The cast to PacketInMessage is safe as the implemented interface is verified before the cas tbut FB doesn't + // recognize it. + @SuppressFBWarnings("BC_UNCONFIRMED_CAST") + public boolean processAlienMessage(final OfHeader message) { + final Class implementedInterface = message.getImplementedInterface(); - @Override - public void setCurrentBarrierTimeout(final Timeout timeout) { - barrierTaskTimeout = timeout; + if (Objects.nonNull(implementedInterface) && org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service + .rev130709.PacketInMessage.class.equals(implementedInterface)) { + final org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709 + .PacketInMessage packetInMessage = (org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service + .rev130709.PacketInMessage) message; + + handlePacketInMessage(packetInMessage, implementedInterface, packetInMessage.getMatch()); + return true; + } + + return false; } @Override - public Timeout getBarrierTaskTimeout() { - return barrierTaskTimeout; + public TranslatorLibrary oook() { + return translatorLibrary; } @Override @@ -485,24 +526,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 MultiMsgCollector getMultiMsgCollector(final RequestContext> requestContext) { + public MultiMsgCollector getMultiMsgCollector(final RequestContext> + 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 @@ -521,20 +557,18 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi } @Override - public void setSwitchFeaturesMandatory(boolean switchFeaturesMandatory) { - this.switchFeaturesMandatory = switchFeaturesMandatory; - } - - @Override - public ListenableFuture stopClusterServices() { - return initialized + public ListenableFuture closeServiceInstance() { + final ListenableFuture 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 @@ -543,43 +577,44 @@ 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() { + final ListenableFuture txChainShuttingDown = transactionChainManager.shuttingDown(); + + Futures.addCallback(txChainShuttingDown, new FutureCallback() { @Override - public void onSuccess(@Nullable final Void result) { + public void onSuccess(final Object result) { transactionChainManager.close(); transactionChainManager = null; } @Override - public void onFailure(final Throwable t) { + public void onFailure(final Throwable throwable) { transactionChainManager.close(); transactionChainManager = null; } - }); + }, MoreExecutors.directExecutor()); } - for (final Iterator> iterator = Iterators - .consumingIterator(requestContexts.iterator()); iterator.hasNext();) { - RequestContextUtil.closeRequestContextWithRpcError(iterator.next(), "Connection closed."); - } + requestContexts.forEach(requestContext -> RequestContextUtil + .closeRequestContextWithRpcError(requestContext, "Connection closed.")); + requestContexts.clear(); } @Override @@ -587,19 +622,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 { @@ -609,51 +635,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 java.util.Optional 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 initializer = deviceInitializerProvider + .lookup(deviceInfo.getVersion()); + + if (initializer.isPresent()) { + final Future 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>> deviceFlowRegistryFill = getDeviceFlowRegistry().fill(); + final ListenableFuture>> 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 @@ -672,81 +703,20 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi return abstractRequestContext; } - private ListenableFuture> sendRoleChangeToDevice(final OfpRole newRole) { - if (LOG.isDebugEnabled()) { - LOG.debug("Sending new role {} to device {}", newRole, deviceInfo.getNodeId()); - } - - final Future> 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> makeDeviceSlave() { - return sendRoleChangeToDevice(OfpRole.BECOMESLAVE); - } - @Override public void onStateAcquired(final ContextChainState state) { - hasState = true; - } - - private class RpcResultFutureCallback implements FutureCallback> { - - private final MastershipChangeListener mastershipChangeListener; - - RpcResultFutureCallback(final MastershipChangeListener mastershipChangeListener) { - this.mastershipChangeListener = mastershipChangeListener; - } - - @Override - public void onSuccess(@Nullable RpcResult 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>> { private final ListenableFuture>> deviceFlowRegistryFill; - private final MastershipChangeListener mastershipChangeListener; + private final ContextChainMastershipWatcher contextChainMastershipWatcher; DeviceFlowRegistryCallback( ListenableFuture>> deviceFlowRegistryFill, - MastershipChangeListener mastershipChangeListener) { + ContextChainMastershipWatcher contextChainMastershipWatcher) { this.deviceFlowRegistryFill = deviceFlowRegistryFill; - this.mastershipChangeListener = mastershipChangeListener; + this.contextChainMastershipWatcher = contextChainMastershipWatcher; } @Override @@ -755,10 +725,14 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi // Count all flows we read from datastore for debugging purposes. // This number do not always represent how many flows were actually added // to DeviceFlowRegistry, because of possible duplicates. - long flowCount = Optional.fromNullable(result).asSet().stream() + long flowCount = Optional.ofNullable(result) + .map(Collections::singleton) + .orElse(Collections.emptySet()) + .stream() .flatMap(Collection::stream) .filter(Objects::nonNull) - .flatMap(flowCapableNodeOptional -> flowCapableNodeOptional.asSet().stream()) + .flatMap(flowCapableNodeOptional + -> com.google.common.base.Optional.fromJavaUtil(flowCapableNodeOptional).asSet().stream()) .filter(Objects::nonNull) .filter(flowCapableNode -> Objects.nonNull(flowCapableNode.getTable())) .flatMap(flowCapableNode -> flowCapableNode.getTable().stream()) @@ -768,21 +742,22 @@ 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: {}", deviceInfo, throwable); } - mastershipChangeListener.onNotAbleToStartMastership( + contextChainMastershipWatcher.onNotAbleToStartMastership( deviceInfo, "Was not able to fill flow registry on device", false);