X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?a=blobdiff_plain;f=openflowplugin-impl%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fopenflowplugin%2Fimpl%2Fdevice%2FDeviceManagerImpl.java;h=c112b0e7393bcccd03267a2572a74ab530dbba26;hb=f78c825bca62ce6f41967e92a45b004485b404c5;hp=f4f03f1e2922c7d2c55df52c37d05ba352482ca3;hpb=42323a46aba0a398027f08bd0da0657813e9aa0a;p=openflowplugin.git diff --git a/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceManagerImpl.java b/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceManagerImpl.java index f4f03f1e29..c112b0e739 100644 --- a/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceManagerImpl.java +++ b/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/device/DeviceManagerImpl.java @@ -10,9 +10,7 @@ package org.opendaylight.openflowplugin.impl.device; import com.google.common.base.Preconditions; 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.SettableFuture; import io.netty.util.HashedWheelTimer; import java.math.BigInteger; import java.util.ArrayList; @@ -30,16 +28,17 @@ 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.WriteTransaction; import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType; +import org.opendaylight.openflowjava.protocol.api.connection.OutboundQueue; 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.connection.ThrottledConnectionsHolder; +import org.opendaylight.openflowplugin.api.openflow.connection.OutboundQueueProvider; +import org.opendaylight.openflowplugin.api.openflow.connection.ThrottledNotificationsOfferer; import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext; 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.RequestContextStack; import org.opendaylight.openflowplugin.api.openflow.device.TranslatorLibrary; import org.opendaylight.openflowplugin.api.openflow.device.Xid; import org.opendaylight.openflowplugin.api.openflow.device.handlers.DeviceInitializationPhaseHandler; @@ -48,11 +47,10 @@ import org.opendaylight.openflowplugin.api.openflow.md.core.TranslatorKey; import org.opendaylight.openflowplugin.api.openflow.statistics.ofpspecific.MessageIntelligenceAgency; import org.opendaylight.openflowplugin.impl.common.MultipartRequestInputFactory; import org.opendaylight.openflowplugin.impl.common.NodeStaticReplyTranslatorUtil; -import org.opendaylight.openflowplugin.impl.connection.ThrottledConnectionsHolderImpl; +import org.opendaylight.openflowplugin.impl.connection.OutboundQueueProviderImpl; +import org.opendaylight.openflowplugin.impl.connection.ThrottledNotificationsOffererImpl; import org.opendaylight.openflowplugin.impl.device.listener.OpenflowProtocolListenerFullImpl; -import org.opendaylight.openflowplugin.impl.rpc.RequestContextImpl; -import org.opendaylight.openflowplugin.impl.services.OFJResult2RequestCtxFuture; -import org.opendaylight.openflowplugin.impl.statistics.ofpspecific.MessageIntelligenceAgencyImpl; +import org.opendaylight.openflowplugin.impl.rpc.AbstractRequestContext; import org.opendaylight.openflowplugin.impl.util.DeviceStateUtil; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowCapableNode; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowCapableNodeBuilder; @@ -75,6 +73,7 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.common.types.rev13 import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.common.types.rev130731.CapabilitiesV10; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.common.types.rev130731.MultipartType; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.MultipartReply; +import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.OfHeader; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.PortGrouping; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.multipart.reply.MultipartReplyBody; import org.opendaylight.yang.gen.v1.urn.opendaylight.openflow.protocol.rev130731.multipart.reply.multipart.reply.body.MultipartReplyDescCase; @@ -109,47 +108,31 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { private final DataBroker dataBroker; private final HashedWheelTimer hashedWheelTimer; - private RequestContextStack emptyRequestContextStack; private TranslatorLibrary translatorLibrary; private DeviceInitializationPhaseHandler deviceInitPhaseHandler; private NotificationService notificationService; private NotificationPublishService notificationPublishService; + private ThrottledNotificationsOfferer throttledNotificationsOfferer; private final List deviceContexts = new ArrayList(); private final MessageIntelligenceAgency messageIntelligenceAgency; - private final ThrottledConnectionsHolder throttledConnectionsHolder; + + private final long barrierNanos = TimeUnit.MILLISECONDS.toNanos(500); + private final int maxQueueDepth = 25600; public DeviceManagerImpl(@Nonnull final DataBroker dataBroker, @Nonnull final MessageIntelligenceAgency messageIntelligenceAgency) { this.dataBroker = Preconditions.checkNotNull(dataBroker); - hashedWheelTimer = new HashedWheelTimer(TICK_DURATION, TimeUnit.MILLISECONDS, 10); + hashedWheelTimer = new HashedWheelTimer(TICK_DURATION, TimeUnit.MILLISECONDS, 500); /* merge empty nodes to oper DS to predict any problems with missing parent for Node */ final WriteTransaction tx = dataBroker.newWriteOnlyTransaction(); - tx.merge(LogicalDatastoreType.OPERATIONAL, InstanceIdentifier.create(Nodes.class), new NodesBuilder().build()); + + final NodesBuilder nodesBuilder = new NodesBuilder(); + nodesBuilder.setNode(Collections.emptyList()); + tx.merge(LogicalDatastoreType.OPERATIONAL, InstanceIdentifier.create(Nodes.class), nodesBuilder.build()); tx.submit(); this.messageIntelligenceAgency = messageIntelligenceAgency; - - emptyRequestContextStack = new RequestContextStack() { - @Override - public void forgetRequestContext(final RequestContext requestContext) { - //NOOP - } - - @Override - public SettableFuture> storeOrFail(final RequestContext data) { - return data.getFuture(); - } - - @Override - public RequestContext createRequestContext() { - return new RequestContextImpl<>(this); - } - }; - spyPool = new ScheduledThreadPoolExecutor(1); - spyPool.scheduleAtFixedRate(messageIntelligenceAgency, spyRate, spyRate, TimeUnit.SECONDS); - - throttledConnectionsHolder = new ThrottledConnectionsHolderImpl(hashedWheelTimer); } @Override @@ -162,16 +145,20 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { // final phase - we have to add new Device to MD-SAL DataStore Preconditions.checkNotNull(deviceContext); ((DeviceContextImpl) deviceContext).submitTransaction(); - new BarrierTaskBuilder(deviceContext).buildAndFireBarrierTask(); } @Override public void deviceConnected(@CheckForNull final ConnectionContext connectionContext) { Preconditions.checkArgument(connectionContext != null); + final Short version = connectionContext.getFeatures().getVersion(); + OutboundQueueProvider outboundQueueProvider = new OutboundQueueProviderImpl(version); + connectionContext.getConnectionAdapter().registerOutboundQueueHandler(outboundQueueProvider, maxQueueDepth, barrierNanos); + connectionContext.setOutboundQueueProvider(outboundQueueProvider); + final DeviceState deviceState = new DeviceStateImpl(connectionContext.getFeatures(), connectionContext.getNodeId()); - final DeviceContext deviceContext = new DeviceContextImpl(connectionContext, deviceState, dataBroker, hashedWheelTimer, messageIntelligenceAgency, throttledConnectionsHolder); + final DeviceContext deviceContext = new DeviceContextImpl(connectionContext, deviceState, dataBroker, hashedWheelTimer, messageIntelligenceAgency, throttledNotificationsOfferer); deviceContext.setNotificationService(notificationService); deviceContext.setNotificationPublishService(notificationPublishService); @@ -184,17 +171,15 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { final OpenflowProtocolListenerFullImpl messageListener = new OpenflowProtocolListenerFullImpl( connectionContext.getConnectionAdapter(), deviceContext); - deviceContext.attachOpenflowMessageListener(messageListener); - final ListenableFuture>>> deviceFeaturesFuture; - final Short version = connectionContext.getFeatures().getVersion(); + if (OFConstants.OFP_VERSION_1_0 == version) { final CapabilitiesV10 capabilitiesV10 = connectionContext.getFeatures().getCapabilitiesV10(); DeviceStateUtil.setDeviceStateBasedOnV10Capabilities(deviceState, capabilitiesV10); - deviceFeaturesFuture = createDeviceFeaturesForOF10(messageListener, deviceContext, deviceState); + deviceFeaturesFuture = createDeviceFeaturesForOF10(deviceContext, deviceState); // create empty tables after device description is processed chainTableTrunkWriteOF10(deviceContext, deviceFeaturesFuture); @@ -215,8 +200,9 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { } } else if (OFConstants.OFP_VERSION_1_3 == version) { final Capabilities capabilities = connectionContext.getFeatures().getCapabilities(); + LOG.debug("Setting capabilities for device {}", deviceContext.getDeviceState().getNodeId()); DeviceStateUtil.setDeviceStateBasedOnV13Capabilities(deviceState, capabilities); - deviceFeaturesFuture = createDeviceFeaturesForOF13(messageListener, deviceContext, deviceState); + deviceFeaturesFuture = createDeviceFeaturesForOF13(deviceContext, deviceState); } else { deviceFeaturesFuture = Futures.immediateFailedFuture(new ConnectionException("Unsupported version " + version)); } @@ -237,7 +223,7 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { }); } - private void chainTableTrunkWriteOF10(final DeviceContext deviceContext, final ListenableFuture>>> deviceFeaturesFuture) { + private static void chainTableTrunkWriteOF10(final DeviceContext deviceContext, final ListenableFuture>>> deviceFeaturesFuture) { Futures.addCallback(deviceFeaturesFuture, new FutureCallback>>>() { @Override public void onSuccess(final List>> results) { @@ -259,37 +245,44 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { }); } - - private ListenableFuture>> processReplyDesc(final OpenflowProtocolListenerFullImpl messageListener, - final DeviceContext deviceContext, + private ListenableFuture>> processReplyDesc(final DeviceContext deviceContext, final DeviceState deviceState) { - final ListenableFuture>> replyDesc = getNodeStaticInfo(messageListener, - MultipartType.OFPMPDESC, deviceContext, deviceState.getNodeInstanceIdentifier(), deviceState.getVersion()); + + final ListenableFuture>> replyDesc = getNodeStaticInfo(MultipartType.OFPMPDESC, + deviceContext, + deviceState.getNodeInstanceIdentifier(), + deviceState.getVersion()); return replyDesc; } - private ListenableFuture>>> createDeviceFeaturesForOF10(final OpenflowProtocolListenerFullImpl messageListener, - final DeviceContext deviceContext, + private ListenableFuture>>> createDeviceFeaturesForOF10(final DeviceContext deviceContext, final DeviceState deviceState) { - return Futures.allAsList(Arrays.asList(processReplyDesc(messageListener, deviceContext, deviceState))); + return Futures.allAsList(Arrays.asList(processReplyDesc(deviceContext, deviceState))); } - private ListenableFuture>>> createDeviceFeaturesForOF13(final OpenflowProtocolListenerFullImpl messageListener, - final DeviceContext deviceContext, + private ListenableFuture>>> createDeviceFeaturesForOF13(final DeviceContext deviceContext, final DeviceState deviceState) { - final ListenableFuture>> replyDesc = processReplyDesc(messageListener, deviceContext, deviceState); + final ListenableFuture>> replyDesc = processReplyDesc(deviceContext, deviceState); - final ListenableFuture>> replyMeterFeature = getNodeStaticInfo(messageListener, - MultipartType.OFPMPMETERFEATURES, deviceContext, deviceState.getNodeInstanceIdentifier(), deviceState.getVersion()); + final ListenableFuture>> replyMeterFeature = getNodeStaticInfo(MultipartType.OFPMPMETERFEATURES, + deviceContext, + deviceState.getNodeInstanceIdentifier(), + deviceState.getVersion()); - final ListenableFuture>> replyGroupFeatures = getNodeStaticInfo(messageListener, - MultipartType.OFPMPGROUPFEATURES, deviceContext, deviceState.getNodeInstanceIdentifier(), deviceState.getVersion()); + final ListenableFuture>> replyGroupFeatures = getNodeStaticInfo(MultipartType.OFPMPGROUPFEATURES, + deviceContext, + deviceState.getNodeInstanceIdentifier(), + deviceState.getVersion()); - final ListenableFuture>> replyTableFeatures = getNodeStaticInfo(messageListener, - MultipartType.OFPMPTABLEFEATURES, deviceContext, deviceState.getNodeInstanceIdentifier(), deviceState.getVersion()); + final ListenableFuture>> replyTableFeatures = getNodeStaticInfo(MultipartType.OFPMPTABLEFEATURES, + deviceContext, + deviceState.getNodeInstanceIdentifier(), + deviceState.getVersion()); - final ListenableFuture>> replyPortDescription = getNodeStaticInfo(messageListener, - MultipartType.OFPMPPORTDESC, deviceContext, deviceState.getNodeInstanceIdentifier(), deviceState.getVersion()); + final ListenableFuture>> replyPortDescription = getNodeStaticInfo(MultipartType.OFPMPPORTDESC, + deviceContext, + deviceState.getNodeInstanceIdentifier(), + deviceState.getVersion()); return Futures.allAsList(Arrays.asList(replyDesc, replyMeterFeature, @@ -309,23 +302,63 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { this.translatorLibrary = translatorLibrary; } - private ListenableFuture>> getNodeStaticInfo(final MultiMsgCollector multiMsgCollector, final MultipartType type, final DeviceContext deviceContext, + private static ListenableFuture>> getNodeStaticInfo(final MultipartType type, final DeviceContext deviceContext, final InstanceIdentifier nodeII, final short version) { - final Xid xid = deviceContext.getNextXid(); - final RequestContext> requestContext = emptyRequestContextStack.createRequestContext(); - requestContext.setXid(xid); + final OutboundQueue queue = deviceContext.getPrimaryConnectionContext().getOutboundQueueProvider(); + + final Long reserved = deviceContext.getReservedXid(); + final RequestContext> requestContext = new AbstractRequestContext>(reserved) { + @Override + public void close() { + //NOOP + } + }; + + final Xid xid = requestContext.getXid(); - LOG.trace("Hooking xid {} to device context - precaution.", requestContext.getXid().getValue()); - deviceContext.hookRequestCtx(requestContext.getXid(), requestContext); + LOG.trace("Hooking xid {} to device context - precaution.", reserved); + final ListenableFuture>> requestContextFuture = requestContext.getFuture(); - multiMsgCollector.registerMultipartXid(xid.getValue()); - Futures.addCallback(requestContext.getFuture(), new FutureCallback>>() { + final MultiMsgCollector multiMsgCollector = deviceContext.getMultiMsgCollector(); + multiMsgCollector.registerMultipartRequestContext(requestContext); + + createSuccessProcessingCallback(type, deviceContext, nodeII, requestContextFuture); + + queue.commitEntry(xid.getValue(), MultipartRequestInputFactory.makeMultipartRequestInput(xid.getValue(), version, type), new FutureCallback() { + @Override + public void onSuccess(final OfHeader ofHeader) { + if (ofHeader instanceof MultipartReply) { + MultipartReply multipartReply = (MultipartReply) ofHeader; + multiMsgCollector.addMultipartMsg(multipartReply); + } else { + if (null != ofHeader) { + LOG.info("Unexpected response type received {}.", ofHeader.getClass()); + } else { + LOG.info("Response received is null."); + } + } + + } + + @Override + public void onFailure(final Throwable t) { + LOG.info("Fail response from OutboundQueue."); + } + }); + + + return requestContext.getFuture(); + } + + private static void createSuccessProcessingCallback(final MultipartType type, final DeviceContext deviceContext, final InstanceIdentifier nodeII, final ListenableFuture>> requestContextFuture) { + Futures.addCallback(requestContextFuture, new FutureCallback>>() { @Override public void onSuccess(final RpcResult> rpcResult) { final List result = rpcResult.getResult(); if (result != null) { + LOG.info("Static node {} info: {} collected", nodeII.toString(), type); translateAndWriteReply(type, deviceContext, nodeII, result); } else { final Iterator rpcErrorIterator = rpcResult.getErrors().iterator(); @@ -343,17 +376,10 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { } @Override - public void onFailure(final Throwable t) { - LOG.info("Failed to retrieve static node {} info: {}", type, t.getMessage()); + public void onFailure(final Throwable throwable) { + LOG.info("Request of type {} for static info of node {} failed.", type, nodeII); } }); - - final ListenableFuture> rpcFuture = JdkFutureAdapters.listenInPoolThread(deviceContext.getPrimaryConnectionContext().getConnectionAdapter() - .multipartRequest(MultipartRequestInputFactory.makeMultipartRequestInput(xid.getValue(), version, type))); - final OFJResult2RequestCtxFuture OFJResult2RequestCtxFuture = new OFJResult2RequestCtxFuture(requestContext, deviceContext); - OFJResult2RequestCtxFuture.processResultFromOfJava(rpcFuture); - - return requestContext.getFuture(); } // FIXME : remove after ovs tableFeatures fix @@ -455,6 +481,9 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { for (final DeviceContext deviceContext : deviceContexts) { deviceContext.close(); } + if (throttledNotificationsOfferer != null) { + throttledNotificationsOfferer.close(); + } } private static void createEmptyFlowCapableNodeInDs(final DeviceContext deviceContext) { @@ -467,4 +496,12 @@ public class DeviceManagerImpl implements DeviceManager, AutoCloseable { public void onDeviceContextClosed(final DeviceContext deviceContext) { deviceContexts.remove(deviceContext); } + + @Override + public void initialize() { + spyPool = new ScheduledThreadPoolExecutor(1); + spyPool.scheduleAtFixedRate(messageIntelligenceAgency, spyRate, spyRate, TimeUnit.SECONDS); + + throttledNotificationsOfferer = new ThrottledNotificationsOffererImpl(notificationPublishService, messageIntelligenceAgency); + } }