X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?a=blobdiff_plain;ds=sidebyside;f=openflowplugin-impl%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fopenflowplugin%2Fimpl%2Fdevice%2FDeviceContextImpl.java;h=aed3f3c79ecaf3f510cffdabf7f39f69cf846cfa;hb=84e9a29a401256b949527776c345153aaab2b6d1;hp=3aed9d60b670a4e2e8c558784846cf5e5875abf4;hpb=babb9c1862957f1fa720ad66d143e1b2a728b1b5;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 3aed9d60b6..aed3f3c79e 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 @@ -8,47 +8,36 @@ package org.opendaylight.openflowplugin.impl.device; import com.google.common.annotations.VisibleForTesting; -import com.google.common.base.Function; -import com.google.common.base.Optional; import com.google.common.base.Preconditions; -import com.google.common.util.concurrent.AsyncFunction; -import com.google.common.util.concurrent.CheckedFuture; +import com.google.common.base.Verify; import com.google.common.util.concurrent.FutureCallback; -import com.google.common.util.concurrent.FutureFallback; import com.google.common.util.concurrent.Futures; import com.google.common.util.concurrent.ListenableFuture; -import io.netty.util.HashedWheelTimer; import io.netty.util.Timeout; import java.math.BigInteger; -import java.util.Collection; -import java.util.Collections; import java.util.HashMap; -import java.util.HashSet; -import java.util.LinkedList; import java.util.List; import java.util.Map; import java.util.concurrent.ConcurrentHashMap; -import javax.annotation.CheckForNull; import javax.annotation.Nonnull; 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.NotificationService; import org.opendaylight.controller.md.sal.binding.api.ReadOnlyTransaction; import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType; -import org.opendaylight.controller.md.sal.common.api.data.ReadFailedException; import org.opendaylight.openflowjava.protocol.api.connection.ConnectionAdapter; import org.opendaylight.openflowjava.protocol.api.connection.OutboundQueue; import org.opendaylight.openflowjava.protocol.api.keys.MessageTypeKey; import org.opendaylight.openflowplugin.api.openflow.connection.ConnectionContext; import org.opendaylight.openflowplugin.api.openflow.connection.OutboundQueueProvider; import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext; +import org.opendaylight.openflowplugin.api.openflow.device.DeviceInfo; import org.opendaylight.openflowplugin.api.openflow.device.DeviceState; import org.opendaylight.openflowplugin.api.openflow.device.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.DeviceContextClosedHandler; import org.opendaylight.openflowplugin.api.openflow.device.handlers.MultiMsgCollector; +import org.opendaylight.openflowplugin.api.openflow.lifecycle.LifecycleConductor; import org.opendaylight.openflowplugin.api.openflow.md.core.SwitchConnectionDistinguisher; import org.opendaylight.openflowplugin.api.openflow.md.core.TranslatorKey; import org.opendaylight.openflowplugin.api.openflow.registry.ItemLifeCycleRegistry; @@ -58,9 +47,7 @@ import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowRegistryKe 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.RpcContext; import org.opendaylight.openflowplugin.api.openflow.rpc.listener.ItemLifecycleListener; -import org.opendaylight.openflowplugin.api.openflow.statistics.StatisticsContext; import org.opendaylight.openflowplugin.api.openflow.statistics.ofpspecific.MessageSpy; import org.opendaylight.openflowplugin.extension.api.ConvertorMessageFromOFJava; import org.opendaylight.openflowplugin.extension.api.ExtensionConverterProviderKeeper; @@ -74,8 +61,6 @@ 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.util.DeviceInitializationUtils; -import org.opendaylight.openflowplugin.impl.util.MdSalRegistrationUtils; import org.opendaylight.openflowplugin.openflow.md.core.session.SwitchConnectionCookieOFImpl; 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; @@ -105,7 +90,6 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.openflowplugin.experimenter import org.opendaylight.yang.gen.v1.urn.opendaylight.packet.service.rev130709.PacketReceived; 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.yangtools.yang.binding.DataObject; import org.opendaylight.yangtools.yang.binding.InstanceIdentifier; import org.opendaylight.yangtools.yang.binding.KeyedInstanceIdentifier; @@ -120,7 +104,7 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi private static final Logger LOG = LoggerFactory.getLogger(DeviceContextImpl.class); // TODO: drain factor should be parametrized - public static final float REJECTED_DRAIN_FACTOR = 0.25f; + private static final float REJECTED_DRAIN_FACTOR = 0.25f; // TODO: low water mark factor should be parametrized private static final float LOW_WATERMARK_FACTOR = 0.75f; // TODO: high water mark factor should be parametrized @@ -129,73 +113,64 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi private final ConnectionContext primaryConnectionContext; private final DeviceState deviceState; private final DataBroker dataBroker; - private final HashedWheelTimer hashedWheelTimer; private final Map auxiliaryConnectionContexts; private final TransactionChainManager transactionChainManager; private final DeviceFlowRegistry deviceFlowRegistry; private final DeviceGroupRegistry deviceGroupRegistry; private final DeviceMeterRegistry deviceMeterRegistry; - private final Collection closeHandlers = new HashSet<>(); private final PacketInRateLimiter packetInLimiter; private final MessageSpy messageSpy; private final ItemLifeCycleKeeper flowLifeCycleKeeper; private NotificationPublishService notificationPublishService; - private NotificationService notificationService; private final OutboundQueue outboundQueueProvider; private Timeout barrierTaskTimeout; private final MessageTranslator portStatusTranslator; private final MessageTranslator packetInTranslator; private final MessageTranslator flowRemovedTranslator; private final TranslatorLibrary translatorLibrary; - private final Map nodeConnectorCache; private final ItemLifeCycleRegistry itemLifeCycleSourceRegistry; - private RpcContext rpcContext; private ExtensionConverterProvider extensionConverterProvider; - private final boolean switchFeaturesMandatory; - private StatisticsContext statisticsContext; + private final DeviceInfo deviceInfo; + private volatile DEVICE_CONTEXT_STATE deviceCtxState; @VisibleForTesting DeviceContextImpl(@Nonnull final ConnectionContext primaryConnectionContext, @Nonnull final DeviceState deviceState, @Nonnull final DataBroker dataBroker, - @Nonnull final HashedWheelTimer hashedWheelTimer, - @Nonnull final MessageSpy _messageSpy, + @Nonnull final LifecycleConductor conductor, @Nonnull final OutboundQueueProvider outboundQueueProvider, - @Nonnull final TranslatorLibrary translatorLibrary, - final boolean switchFeaturesMandatory) { - this.switchFeaturesMandatory = switchFeaturesMandatory; + @Nonnull final TranslatorLibrary translatorLibrary) { this.primaryConnectionContext = Preconditions.checkNotNull(primaryConnectionContext); this.deviceState = Preconditions.checkNotNull(deviceState); this.dataBroker = Preconditions.checkNotNull(dataBroker); - this.hashedWheelTimer = Preconditions.checkNotNull(hashedWheelTimer); + Preconditions.checkNotNull(conductor); this.outboundQueueProvider = Preconditions.checkNotNull(outboundQueueProvider); - primaryConnectionContext.setDeviceDisconnectedHandler(DeviceContextImpl.this); - this.transactionChainManager = new TransactionChainManager(dataBroker, deviceState); + deviceInfo = primaryConnectionContext.getDeviceInfo(); + this.transactionChainManager = new TransactionChainManager(dataBroker, deviceInfo, conductor); auxiliaryConnectionContexts = new HashMap<>(); deviceFlowRegistry = new DeviceFlowRegistryImpl(); deviceGroupRegistry = new DeviceGroupRegistryImpl(); deviceMeterRegistry = new DeviceMeterRegistryImpl(); - messageSpy = _messageSpy; + messageSpy = conductor.getMessageIntelligenceAgency(); + packetInLimiter = new PacketInRateLimiter(primaryConnectionContext.getConnectionAdapter(), /*initial*/ 1000, /*initial*/2000, messageSpy, REJECTED_DRAIN_FACTOR); this.translatorLibrary = translatorLibrary; portStatusTranslator = translatorLibrary.lookupTranslator( - new TranslatorKey(deviceState.getVersion(), PortGrouping.class.getName())); + new TranslatorKey(deviceInfo.getVersion(), PortGrouping.class.getName())); packetInTranslator = translatorLibrary.lookupTranslator( - new TranslatorKey(deviceState.getVersion(), PacketIn.class.getName())); + new TranslatorKey(deviceInfo.getVersion(), PacketIn.class.getName())); flowRemovedTranslator = translatorLibrary.lookupTranslator( - new TranslatorKey(deviceState.getVersion(), FlowRemoved.class.getName())); - - - nodeConnectorCache = new ConcurrentHashMap<>(); + new TranslatorKey(deviceInfo.getVersion(), FlowRemoved.class.getName())); itemLifeCycleSourceRegistry = new ItemLifeCycleRegistryImpl(); flowLifeCycleKeeper = new ItemLifeCycleSourceImpl(); itemLifeCycleSourceRegistry.registerLifeCycleSource(flowLifeCycleKeeper); + deviceCtxState = DEVICE_CONTEXT_STATE.INITIALIZATION; } /** @@ -207,7 +182,7 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi } @Override - public Long reservedXidForDeviceMessage() { + public Long reserveXidForDeviceMessage() { return outboundQueueProvider.reserveEntry(); } @@ -224,9 +199,9 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi @Override public void removeAuxiliaryConnectionContext(final ConnectionContext connectionContext) { final SwitchConnectionDistinguisher connectionDistinguisher = createConnectionDistinguisher(connectionContext); - if (null != connectionDistinguisher) { - auxiliaryConnectionContexts.remove(connectionDistinguisher); - } + LOG.debug("auxiliary connection dropped: {}, nodeId:{}", connectionContext.getConnectionAdapter() + .getRemoteAddress(), deviceInfo.getNodeId()); + auxiliaryConnectionContexts.remove(connectionDistinguisher); } @Override @@ -235,129 +210,28 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi } @Override - public ReadOnlyTransaction getReadTransaction() { - return dataBroker.newReadOnlyTransaction(); + public DeviceInfo getDeviceInfo() { + return this.deviceInfo; } @Override - public ListenableFuture onClusterRoleChange(final OfpRole oldRole, @CheckForNull final OfpRole role) { - LOG.trace("onClusterRoleChange {} for node:", role, deviceState.getNodeId()); - Preconditions.checkArgument(role != null); - if (role.equals(oldRole)) { - LOG.debug("Demanded role change for device {} is not change OldRole: {}, NewRole {}", deviceState.getNodeId(), oldRole, role); - return Futures.immediateFuture(null); - } - if (OfpRole.BECOMEMASTER.equals(role)) { - if (!deviceState.deviceSynchronized()) { - //TODO: no necessary code for yet - it needs for initialization phase only - LOG.debug("Setup Empty TxManager {} for initialization phase", getDeviceState().getNodeId()); - transactionChainManager.activateTransactionManager(); - return Futures.immediateCheckedFuture(null); - } - return asyncClusterRoleChange(); - - } else if (OfpRole.BECOMESLAVE.equals(role)) { - if (null != rpcContext) { - MdSalRegistrationUtils.registerSlaveServices(rpcContext, role); - } - return transactionChainManager.deactivateTransactionManager(); - } else { - LOG.warn("Unknown OFCluster Role {} for Node {}", role, deviceState.getNodeId()); - if (null != rpcContext) { - MdSalRegistrationUtils.unregisterServices(rpcContext); - } - return transactionChainManager.deactivateTransactionManager(); - } + public ReadOnlyTransaction getReadTransaction() { + return dataBroker.newReadOnlyTransaction(); } - /* - * we don't have active TxManager so anything will not be stored to DS yet, but we have - * check all NodeInformation for statistics otherwise statistics will not contains - * all possible MultipartTypes for polling in StatTypeList - */ - private ListenableFuture asyncClusterRoleChange() { - if (statisticsContext == null) { - final String errMsg = String.format("DeviceCtx %s is up but we are missing StatisticsContext", deviceState.getNodeId()); - LOG.warn(errMsg); - return Futures.immediateFailedFuture(new IllegalStateException(errMsg)); - } - if (rpcContext == null) { - final String errMsg = String.format("DeviceCtx %s is up but we are missing RpcContext", deviceState.getNodeId()); - LOG.warn(errMsg); - return Futures.immediateFailedFuture(new IllegalStateException(errMsg)); - } - - final InstanceIdentifier ofNodeII = deviceState.getNodeInstanceIdentifier() - .augmentation(FlowCapableNode.class); - final ReadOnlyTransaction readTx = getReadTransaction(); - final CheckedFuture, ReadFailedException> readOfNodeFuture = readTx.read( - LogicalDatastoreType.OPERATIONAL, ofNodeII); - - final ListenableFuture nodeInitInfoFuture = Futures.transform(readOfNodeFuture, - new AsyncFunction, Void>() { - @Override - public ListenableFuture apply(final Optional input) throws Exception { - if (!input.isPresent() || input.get().getTable() == null || input.get().getTable().isEmpty()) { - /* Last master close fail scenario so we would like to activate TxManager */ - LOG.debug("Operational DS for Device {} has to be replaced", deviceState.getNodeId()); - getDeviceState().setDeviceSynchronized(false); - transactionChainManager.activateTransactionManager(); - } - return DeviceInitializationUtils.initializeNodeInformation(DeviceContextImpl.this, switchFeaturesMandatory); - } - }); - - final ListenableFuture statPollFuture = Futures.transform(nodeInitInfoFuture, - new AsyncFunction() { - - @Override - public ListenableFuture apply(final Void input) throws Exception { - getStatisticsContext().statListForCollectingInitialization(); - if (getDeviceState().deviceSynchronized()) { - return Futures.immediateFuture(Boolean.TRUE); - } - return getStatisticsContext().gatherDynamicData(); - } - }); - - return Futures.transform(statPollFuture, new Function() { - - @Override - public Void apply(final Boolean input) { - if (ConnectionContext.CONNECTION_STATE.RIP.equals(getPrimaryConnectionContext().getConnectionState())) { - final String errMsg = String.format("We lost connection for Device %s, context has to be closed.", - getDeviceState().getNodeId()); - LOG.warn(errMsg); - transactionChainManager.clearUnsubmittedTransaction(); - throw new IllegalStateException(errMsg); - } - if (!input.booleanValue()) { - final String errMsg = String.format("Get Initial Device %s information fails", - getDeviceState().getNodeId()); - LOG.warn(errMsg); - transactionChainManager.clearUnsubmittedTransaction(); - throw new IllegalStateException(errMsg); - } - LOG.debug("Get Initial Device {} information is successful", getDeviceState().getNodeId()); - getDeviceState().setDeviceSynchronized(true); - transactionChainManager.activateTransactionManager(); - MdSalRegistrationUtils.registerMasterServices(getRpcContext(), DeviceContextImpl.this, OfpRole.BECOMEMASTER); - getRpcContext().registerStatCompatibilityServices(); - initialSubmitTransaction(); - getDeviceState().setStatisticsPollingEnabledProp(true); - return null; - } - }); + @Override + public void writeToTransaction(final LogicalDatastoreType store, + final InstanceIdentifier path, final T data) throws Exception { + transactionChainManager.writeToTransaction(store, path, data, false); } @Override - public void writeToTransaction(final LogicalDatastoreType store, - final InstanceIdentifier path, final T data) { - transactionChainManager.writeToTransaction(store, path, data); + public void writeToTransactionWithParentsSlow(LogicalDatastoreType store, InstanceIdentifier path, T data) throws Exception { + transactionChainManager.writeToTransaction(store, path, data, true); } @Override - public void addDeleteToTxChain(final LogicalDatastoreType store, final InstanceIdentifier path) { + public void addDeleteToTxChain(final LogicalDatastoreType store, final InstanceIdentifier path) throws Exception { transactionChainManager.addDeleteOperationTotTxChain(store, path); } @@ -413,7 +287,7 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi if (itemLifecycleListener != null) { //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, this, null); + flowRemovedTranslator.translate(flowRemoved, deviceInfo, null); //2. create registry key final FlowRegistryKey flowRegKey = FlowRegistryKeyFactory.create(flowRemovedNotification); //3. lookup flowId @@ -421,15 +295,17 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi //4. if flowId present: if (flowDescriptor != null) { // a) construct flow path - final KeyedInstanceIdentifier flowPath = getDeviceState().getNodeInstanceIdentifier() + 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); + // c) trigger off a notification + notificationPublishService.offerNotification(flowRemovedNotification); } else { LOG.debug("flow id not found: nodeId={} tableId={}, priority={}", - getDeviceState().getNodeId(), flowRegKey.getTableId(), flowRemovedNotification.getPriority()); + getDeviceInfo().getNodeId(), flowRegKey.getTableId(), flowRemovedNotification.getPriority()); } } } @@ -437,24 +313,28 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi @Override public void processPortStatusMessage(final PortStatusMessage portStatus) { messageSpy.spyMessage(portStatus.getImplementedInterface(), MessageSpy.STATISTIC_GROUP.FROM_SWITCH_PUBLISHED_SUCCESS); - final FlowCapableNodeConnector flowCapableNodeConnector = portStatusTranslator.translate(portStatus, this, null); + final FlowCapableNodeConnector flowCapableNodeConnector = portStatusTranslator.translate(portStatus, deviceInfo, null); final KeyedInstanceIdentifier iiToNodeConnector = provideIIToNodeConnector(portStatus.getPortNo(), portStatus.getVersion()); - if (portStatus.getReason().equals(PortReason.OFPPRADD) || portStatus.getReason().equals(PortReason.OFPPRMODIFY)) { - // because of ADD status node connector has to be created - final NodeConnectorBuilder nConnectorBuilder = new NodeConnectorBuilder().setKey(iiToNodeConnector.getKey()); - nConnectorBuilder.addAugmentation(FlowCapableNodeConnectorStatisticsData.class, new FlowCapableNodeConnectorStatisticsDataBuilder().build()); - nConnectorBuilder.addAugmentation(FlowCapableNodeConnector.class, flowCapableNodeConnector); - writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToNodeConnector, nConnectorBuilder.build()); - } else if (portStatus.getReason().equals(PortReason.OFPPRDELETE)) { - addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, iiToNodeConnector); + try { + if (portStatus.getReason().equals(PortReason.OFPPRADD) || portStatus.getReason().equals(PortReason.OFPPRMODIFY)) { + // because of ADD status node connector has to be created + final NodeConnectorBuilder nConnectorBuilder = new NodeConnectorBuilder().setKey(iiToNodeConnector.getKey()); + nConnectorBuilder.addAugmentation(FlowCapableNodeConnectorStatisticsData.class, new FlowCapableNodeConnectorStatisticsDataBuilder().build()); + nConnectorBuilder.addAugmentation(FlowCapableNodeConnector.class, flowCapableNodeConnector); + writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToNodeConnector, nConnectorBuilder.build()); + } else if (portStatus.getReason().equals(PortReason.OFPPRDELETE)) { + addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, iiToNodeConnector); + } + submitTransaction(); + } catch (final Exception e) { + LOG.warn("Error processing port status message: {}", e.getMessage()); } - submitTransaction(); } private KeyedInstanceIdentifier provideIIToNodeConnector(final long portNo, final short version) { - final InstanceIdentifier iiToNodes = deviceState.getNodeInstanceIdentifier(); - final BigInteger dataPathId = deviceState.getFeatures().getDatapathId(); + final InstanceIdentifier iiToNodes = deviceInfo.getNodeInstanceIdentifier(); + final BigInteger dataPathId = deviceInfo.getDatapathId(); final NodeConnectorId nodeConnectorId = NodeStaticReplyTranslatorUtil.nodeConnectorId(dataPathId.toString(), portNo, version); return iiToNodes.child(NodeConnector.class, new NodeConnectorKey(nodeConnectorId)); } @@ -463,7 +343,7 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi public void processPacketInMessage(final PacketInMessage packetInMessage) { messageSpy.spyMessage(packetInMessage.getImplementedInterface(), MessageSpy.STATISTIC_GROUP.FROM_SWITCH); final ConnectionAdapter connectionAdapter = getPrimaryConnectionContext().getConnectionAdapter(); - final PacketReceived packetReceived = packetInTranslator.translate(packetInMessage, this, null); + final PacketReceived packetReceived = packetInTranslator.translate(packetInMessage, deviceInfo, null); if (packetReceived == null) { LOG.debug("Received a null packet from switch {}", connectionAdapter.getRemoteAddress()); @@ -480,7 +360,7 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi return; } - final ListenableFuture offerNotification = notificationPublishService.offerNotification(packetReceived); + final ListenableFuture offerNotification = notificationPublishService.offerNotification(packetReceived); if (NotificationPublishService.REJECTED.equals(offerNotification)) { LOG.debug("notification offer rejected"); messageSpy.spyMessage(packetReceived.getImplementedInterface(), MessageSpy.STATISTIC_GROUP.FROM_SWITCH_NOTIFICATION_REJECTED); @@ -511,13 +391,13 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi // lookup converter final ExperimenterDataOfChoice vendorData = notification.getExperimenterDataOfChoice(); final MessageTypeKey key = new MessageTypeKey<>( - deviceState.getVersion(), + deviceInfo.getVersion(), (Class) vendorData.getImplementedInterface()); final ConvertorMessageFromOFJava messageConverter = extensionConverterProvider.getMessageConverter(key); if (messageConverter == null) { LOG.warn("custom converter for {}[OF:{}] not found", notification.getExperimenterDataOfChoice().getImplementedInterface(), - deviceState.getVersion()); + deviceInfo.getVersion()); return; } // build notification @@ -525,12 +405,12 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi try { messageOfChoice = messageConverter.convert(vendorData, MessagePath.MESSAGE_NOTIFICATION); final ExperimenterMessageFromDevBuilder experimenterMessageFromDevBld = new ExperimenterMessageFromDevBuilder() - .setNode(new NodeRef(deviceState.getNodeInstanceIdentifier())) + .setNode(new NodeRef(deviceInfo.getNodeInstanceIdentifier())) .setExperimenterMessageOfChoice(messageOfChoice); // publish notificationPublishService.offerNotification(experimenterMessageFromDevBld.build()); } catch (final ConversionException e) { - LOG.warn("Conversion of experimenter notification failed", e); + LOG.error("Conversion of experimenter notification failed", e); } } @@ -539,81 +419,13 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi return translatorLibrary; } - @Override - public HashedWheelTimer getTimer() { - return hashedWheelTimer; - } - @Override public synchronized void close() { LOG.debug("closing deviceContext: {}, nodeId:{}", getPrimaryConnectionContext().getConnectionAdapter().getRemoteAddress(), - getDeviceState().getNodeId()); - - if (deviceState.isValid()) { - primaryConnectionContext.closeConnection(false); - tearDown(); - } - } - - private synchronized void tearDown() { - LOG.trace("tearDown method for node {}", deviceState.getNodeId()); - if (deviceState.isValid()) { - deviceState.setValid(false); - - for (final ConnectionContext connectionContext : auxiliaryConnectionContexts.values()) { - connectionContext.closeConnection(false); - } - - deviceGroupRegistry.close(); - deviceFlowRegistry.close(); - deviceMeterRegistry.close(); - - final ListenableFuture future = transactionChainManager.shuttingDown(); - Futures.addCallback(future, new FutureCallback() { - - @Override - public void onSuccess(final Void result) { - LOG.info("TxChain {} was shutdown successful.", getDeviceState().getNodeId()); - tearDownClean(); - } - - @Override - public void onFailure(final Throwable t) { - LOG.warn("Shutdown TxChain {} fail.", getDeviceState().getNodeId(), t); - tearDownClean(); - } - }); - } - } - - private void tearDownClean() { - LOG.info("Closing transaction chain manager without cleaning inventory operational"); - transactionChainManager.close(); - - final LinkedList reversedCloseHandlers = new LinkedList<>(closeHandlers); - Collections.reverse(reversedCloseHandlers); - for (final DeviceContextClosedHandler deviceContextClosedHandler : reversedCloseHandlers) { - deviceContextClosedHandler.onDeviceContextClosed(this); - } - closeHandlers.clear(); - } - - @Override - public void onDeviceDisconnected(final ConnectionContext connectionContext) { - if (getPrimaryConnectionContext().equals(connectionContext)) { - try { - tearDown(); - } catch (final Exception e) { - LOG.trace("Error closing device context."); - } - } else { - LOG.debug("auxiliary connection dropped: {}, nodeId:{}", - connectionContext.getConnectionAdapter().getRemoteAddress(), - getDeviceState().getNodeId()); - final SwitchConnectionDistinguisher connectionDistinguisher = createConnectionDistinguisher(connectionContext); - auxiliaryConnectionContexts.remove(connectionDistinguisher); - } + getDeviceInfo().getNodeId()); + // NOOP + throw new UnsupportedOperationException("Autocloseble.close will be removed soon"); } @Override @@ -626,11 +438,6 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi return barrierTaskTimeout; } - @Override - public void setNotificationService(final NotificationService notificationService) { - this.notificationService = notificationService; - } - @Override public void setNotificationPublishService(final NotificationPublishService notificationPublishService) { this.notificationPublishService = notificationPublishService; @@ -641,13 +448,10 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi return messageSpy; } - @Override - public void addDeviceContextClosedHandler(final DeviceContextClosedHandler deviceContextClosedHandler) { - closeHandlers.add(deviceContextClosedHandler); - } - @Override public void onPublished() { + Verify.verify(DEVICE_CONTEXT_STATE.INITIALIZATION.equals(deviceCtxState)); + deviceCtxState = DEVICE_CONTEXT_STATE.WORKING; primaryConnectionContext.getConnectionAdapter().setPacketInFiltering(false); for (final ConnectionContext switchAuxConnectionContext : auxiliaryConnectionContexts.values()) { switchAuxConnectionContext.getConnectionAdapter().setPacketInFiltering(false); @@ -659,18 +463,6 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi return new MultiMsgCollectorImpl(this, requestContext); } - @Override - public NodeConnectorRef lookupNodeConnectorRef(final Long portNumber) { - return nodeConnectorCache.get(portNumber); - } - - @Override - public void storeNodeConnectorRef(final Long portNumber, final NodeConnectorRef nodeConnectorRef) { - nodeConnectorCache.put( - Preconditions.checkNotNull(portNumber), - Preconditions.checkNotNull(nodeConnectorRef)); - } - @Override public void updatePacketInRateLimit(final long upperBound) { packetInLimiter.changeWaterMarks((int) (LOW_WATERMARK_FACTOR * upperBound), (int) (HIGH_WATERMARK_FACTOR * upperBound)); @@ -682,32 +474,53 @@ public class DeviceContextImpl implements DeviceContext, ExtensionConverterProvi } @Override - public void setRpcContext(final RpcContext rpcContext) { - this.rpcContext = rpcContext; + public void setExtensionConverterProvider(final ExtensionConverterProvider extensionConverterProvider) { + this.extensionConverterProvider = extensionConverterProvider; } @Override - public RpcContext getRpcContext() { - return rpcContext; + public ExtensionConverterProvider getExtensionConverterProvider() { + return extensionConverterProvider; } @Override - public void setExtensionConverterProvider(final ExtensionConverterProvider extensionConverterProvider) { - this.extensionConverterProvider = extensionConverterProvider; + public synchronized void shutdownConnection() { + LOG.debug("Shutdown method for node {}", deviceInfo.getNodeId()); + if (DEVICE_CONTEXT_STATE.TERMINATION.equals(deviceCtxState)) { + LOG.debug("DeviceCtx for Node {} is in termination process.", deviceInfo.getNodeId()); + return; + } + deviceCtxState = DEVICE_CONTEXT_STATE.TERMINATION; + + if (ConnectionContext.CONNECTION_STATE.RIP.equals(getPrimaryConnectionContext().getConnectionState())) { + LOG.debug("ConnectionCtx for Node {} is in RIP state.", deviceInfo.getNodeId()); + return; + } + /* Terminate Auxiliary Connection */ + for (final ConnectionContext connectionContext : auxiliaryConnectionContexts.values()) { + LOG.debug("Closing auxiliary connection {}", connectionContext.getNodeId()); + connectionContext.closeConnection(false); + } + /* Terminate Primary Connection */ + getPrimaryConnectionContext().closeConnection(true); + /* Close all Group Registry */ + deviceGroupRegistry.close(); + deviceFlowRegistry.close(); + deviceMeterRegistry.close(); } @Override - public ExtensionConverterProvider getExtensionConverterProvider() { - return extensionConverterProvider; + public DEVICE_CONTEXT_STATE getDeviceContextState() { + return deviceCtxState; } @Override - public void setStatisticsContext(final StatisticsContext statisticsContext) { - this.statisticsContext = statisticsContext; + public ListenableFuture shuttingDownDataStoreTransactions() { + return transactionChainManager.shuttingDown(); } - @Override - public StatisticsContext getStatisticsContext() { - return statisticsContext; + @VisibleForTesting + TransactionChainManager getTransactionChainManager() { + return this.transactionChainManager; } }