X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?a=blobdiff_plain;f=opendaylight%2Fmd-sal%2Fstatistics-manager%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fcontroller%2Fmd%2Fstatistics%2Fmanager%2FStatisticsProvider.java;h=1269c1c6d8287fda41ec1fce515895e32fa50abd;hb=cb016426ddc0f08cee3c9475f4214388c0035edd;hp=4eaad427381cac032d6e6b48de81d2da0f5e3445;hpb=2db9424fea93b515367614389b82665dc0987c4b;p=controller.git diff --git a/opendaylight/md-sal/statistics-manager/src/main/java/org/opendaylight/controller/md/statistics/manager/StatisticsProvider.java b/opendaylight/md-sal/statistics-manager/src/main/java/org/opendaylight/controller/md/statistics/manager/StatisticsProvider.java index 4eaad42738..1269c1c6d8 100644 --- a/opendaylight/md-sal/statistics-manager/src/main/java/org/opendaylight/controller/md/statistics/manager/StatisticsProvider.java +++ b/opendaylight/md-sal/statistics-manager/src/main/java/org/opendaylight/controller/md/statistics/manager/StatisticsProvider.java @@ -17,26 +17,38 @@ import java.util.concurrent.Future; import org.eclipse.xtext.xbase.lib.Exceptions; import org.opendaylight.controller.md.statistics.manager.MultipartMessageManager.StatsRequestType; import org.opendaylight.controller.sal.binding.api.NotificationProviderService; +import org.opendaylight.controller.sal.binding.api.RpcConsumerRegistry; +import org.opendaylight.controller.sal.binding.api.data.DataBrokerService; import org.opendaylight.controller.sal.binding.api.data.DataModificationTransaction; import org.opendaylight.controller.sal.binding.api.data.DataProviderService; 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.meters.Meter; 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.statistics.rev130819.GetAggregateFlowStatisticsFromFlowTableForAllFlowsInputBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.GetAggregateFlowStatisticsFromFlowTableForAllFlowsOutput; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.GetAllFlowsStatisticsFromAllFlowTablesInputBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.GetAllFlowsStatisticsFromAllFlowTablesOutput; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.GetFlowStatisticsFromFlowTableInputBuilder; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.GetFlowStatisticsFromFlowTableOutput; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.OpendaylightFlowStatisticsService; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.GetFlowTablesStatisticsInputBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.GetFlowTablesStatisticsOutput; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.OpendaylightFlowTableStatisticsService; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.types.port.rev130925.queues.Queue; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.types.queue.rev130925.QueueId; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.statistics.rev131111.GetAllGroupStatisticsInputBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.statistics.rev131111.GetAllGroupStatisticsOutput; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.statistics.rev131111.GetGroupDescriptionInputBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.statistics.rev131111.GetGroupDescriptionOutput; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.statistics.rev131111.OpendaylightGroupStatisticsService; +import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.groups.Group; +import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeConnectorId; import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId; import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef; import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Nodes; +import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.node.NodeConnector; import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.Node; import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.NodeKey; import org.opendaylight.yang.gen.v1.urn.opendaylight.meter.statistics.rev131111.GetAllMeterConfigStatisticsInputBuilder; @@ -49,21 +61,42 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.port.statistics.rev131214.G import org.opendaylight.yang.gen.v1.urn.opendaylight.port.statistics.rev131214.OpendaylightPortStatisticsService; import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216.GetAllQueuesStatisticsFromAllPortsInputBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216.GetAllQueuesStatisticsFromAllPortsOutput; +import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216.GetQueueStatisticsFromGivenPortInputBuilder; +import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216.GetQueueStatisticsFromGivenPortOutput; import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216.OpendaylightQueueStatisticsService; import org.opendaylight.yangtools.concepts.Registration; +import org.opendaylight.yangtools.yang.binding.DataObject; import org.opendaylight.yangtools.yang.binding.InstanceIdentifier; import org.opendaylight.yangtools.yang.binding.NotificationListener; import org.opendaylight.yangtools.yang.common.RpcResult; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import com.google.common.base.Preconditions; + +/** + * Following are main responsibilities of the class: + * 1) Invoke statistics request thread to send periodic statistics request to all the + * flow capable switch connected to the controller. It sends statistics request for + * Group,Meter,Table,Flow,Queue,Aggregate stats. + * + * 2) Invoke statistics ager thread, to clean up all the stale statistics data from + * operational data store. + * + * @author avishnoi@in.ibm.com + * + */ public class StatisticsProvider implements AutoCloseable { + public static final int STATS_THREAD_EXECUTION_TIME= 15000; - public final static Logger spLogger = LoggerFactory.getLogger(StatisticsProvider.class); + private static final Logger spLogger = LoggerFactory.getLogger(StatisticsProvider.class); - private DataProviderService dps; + private final MultipartMessageManager multipartMessageManager = new MultipartMessageManager(); + private final InstanceIdentifier nodesIdentifier = InstanceIdentifier.builder(Nodes.class).toInstance(); + private final DataProviderService dps; - private NotificationProviderService nps; + //Local caching of stats + private final ConcurrentMap statisticsCache = new ConcurrentHashMap<>(); private OpendaylightGroupStatisticsService groupStatsService; @@ -77,32 +110,15 @@ public class StatisticsProvider implements AutoCloseable { private OpendaylightQueueStatisticsService queueStatsService; - private final MultipartMessageManager multipartMessageManager = new MultipartMessageManager(); + private StatisticsUpdateHandler statsUpdateHandler; private Thread statisticsRequesterThread; - private final InstanceIdentifier nodesIdentifier = InstanceIdentifier.builder(Nodes.class).toInstance(); + private Thread statisticsAgerThread; - private final int STATS_THREAD_EXECUTION_TIME= 50000; - //Local caching of stats - private final ConcurrentMap statisticsCache = - new ConcurrentHashMap(); - - public DataProviderService getDataService() { - return this.dps; - } - - public void setDataService(final DataProviderService dataService) { - this.dps = dataService; - } - - public NotificationProviderService getNotificationService() { - return this.nps; - } - - public void setNotificationService(final NotificationProviderService notificationService) { - this.nps = notificationService; + public StatisticsProvider(final DataProviderService dataService) { + this.dps = Preconditions.checkNotNull(dataService); } public MultipartMessageManager getMultipartMessageManager() { @@ -113,38 +129,51 @@ public class StatisticsProvider implements AutoCloseable { private Registration listenerRegistration; - public void start() { + public void start(final DataBrokerService dbs, final NotificationProviderService nps, final RpcConsumerRegistry rpcRegistry) { - NotificationProviderService nps = this.getNotificationService(); - Registration registerNotificationListener = nps.registerNotificationListener(this.updateCommiter); - this.listenerRegistration = registerNotificationListener; + this.listenerRegistration = nps.registerNotificationListener(this.updateCommiter); + + statsUpdateHandler = new StatisticsUpdateHandler(StatisticsProvider.this); + registerDataStoreUpdateListener(dbs); // Get Group/Meter statistics service instance - groupStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightGroupStatisticsService.class); + groupStatsService = rpcRegistry.getRpcService(OpendaylightGroupStatisticsService.class); + meterStatsService = rpcRegistry.getRpcService(OpendaylightMeterStatisticsService.class); + flowStatsService = rpcRegistry.getRpcService(OpendaylightFlowStatisticsService.class); + portStatsService = rpcRegistry.getRpcService(OpendaylightPortStatisticsService.class); + flowTableStatsService = rpcRegistry.getRpcService(OpendaylightFlowTableStatisticsService.class); + queueStatsService = rpcRegistry.getRpcService(OpendaylightQueueStatisticsService.class); - meterStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightMeterStatisticsService.class); + statisticsRequesterThread = new Thread( new Runnable(){ - flowStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightFlowStatisticsService.class); + @Override + public void run() { + while(true){ + try { + statsRequestSender(); - portStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightPortStatisticsService.class); + Thread.sleep(STATS_THREAD_EXECUTION_TIME); + }catch (Exception e){ + spLogger.error("Exception occurred while sending stats request : {}",e); + } + } + } + }); - flowTableStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightFlowTableStatisticsService.class); + spLogger.debug("Statistics requester thread started with timer interval : {}",STATS_THREAD_EXECUTION_TIME); - queueStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightQueueStatisticsService.class); + statisticsRequesterThread.start(); - statisticsRequesterThread = new Thread( new Runnable(){ + statisticsAgerThread = new Thread( new Runnable(){ @Override public void run() { while(true){ try { - statsRequestSender(); + for(NodeStatisticsAger nodeStatisticsAger : statisticsCache.values()){ + nodeStatisticsAger.cleanStaleStatistics(); + } + multipartMessageManager.cleanStaleTransactionIds(); Thread.sleep(STATS_THREAD_EXECUTION_TIME); }catch (Exception e){ @@ -154,16 +183,48 @@ public class StatisticsProvider implements AutoCloseable { } }); - spLogger.debug("Statistics requester thread started with timer interval : {}",STATS_THREAD_EXECUTION_TIME); + spLogger.debug("Statistics ager thread started with timer interval : {}",STATS_THREAD_EXECUTION_TIME); - statisticsRequesterThread.start(); + statisticsAgerThread.start(); spLogger.info("Statistics Provider started."); } - protected DataModificationTransaction startChange() { + private void registerDataStoreUpdateListener(DataBrokerService dbs) { + //Register for Node updates + InstanceIdentifier pathNode = InstanceIdentifier.builder(Nodes.class) + .child(Node.class).toInstance(); + dbs.registerDataChangeListener(pathNode, statsUpdateHandler); + + //Register for flow updates + InstanceIdentifier pathFlow = InstanceIdentifier.builder(Nodes.class).child(Node.class) + .augmentation(FlowCapableNode.class) + .child(Table.class) + .child(Flow.class).toInstance(); + dbs.registerDataChangeListener(pathFlow, statsUpdateHandler); + + //Register for meter updates + InstanceIdentifier pathMeter = InstanceIdentifier.builder(Nodes.class).child(Node.class) + .augmentation(FlowCapableNode.class) + .child(Meter.class).toInstance(); + + dbs.registerDataChangeListener(pathMeter, statsUpdateHandler); + + //Register for group updates + InstanceIdentifier pathGroup = InstanceIdentifier.builder(Nodes.class).child(Node.class) + .augmentation(FlowCapableNode.class) + .child(Group.class).toInstance(); + dbs.registerDataChangeListener(pathGroup, statsUpdateHandler); + + //Register for queue updates + InstanceIdentifier pathQueue = InstanceIdentifier.builder(Nodes.class).child(Node.class) + .child(NodeConnector.class) + .augmentation(FlowCapableNodeConnector.class) + .child(Queue.class).toInstance(); + dbs.registerDataChangeListener(pathQueue, statsUpdateHandler); + } - DataProviderService dps = this.getDataService(); + protected DataModificationTransaction startChange() { return dps.beginTransaction(); } @@ -178,39 +239,48 @@ public class StatisticsProvider implements AutoCloseable { for (Node targetNode : targetNodes){ if(targetNode.getAugmentation(FlowCapableNode.class) != null){ + sendStatisticsRequestsToNode(targetNode); + } + } + } - spLogger.trace("Send request for stats collection to node : {})",targetNode.getId()); - - InstanceIdentifier targetInstanceId = InstanceIdentifier.builder(Nodes.class).child(Node.class,targetNode.getKey()).toInstance(); - - NodeRef targetNodeRef = new NodeRef(targetInstanceId); - - try{ - sendAggregateFlowsStatsFromAllTablesRequest(targetNode.getKey()); - - sendAllFlowsStatsFromAllTablesRequest(targetNodeRef); - - sendAllNodeConnectorsStatisticsRequest(targetNodeRef); - - sendAllFlowTablesStatisticsRequest(targetNodeRef); - - sendAllQueueStatsFromAllNodeConnector (targetNodeRef); + public void sendStatisticsRequestsToNode(Node targetNode){ - sendAllGroupStatisticsRequest(targetNodeRef); + spLogger.debug("Send requests for statistics collection to node : {})",targetNode.getId()); - sendAllMeterStatisticsRequest(targetNodeRef); + InstanceIdentifier targetInstanceId = InstanceIdentifier.builder(Nodes.class).child(Node.class,targetNode.getKey()).toInstance(); - sendGroupDescriptionRequest(targetNodeRef); + NodeRef targetNodeRef = new NodeRef(targetInstanceId); - sendMeterConfigStatisticsRequest(targetNodeRef); - }catch(Exception e){ - spLogger.error("Exception occured while sending statistics requests : {}", e); - } + try{ + if(flowStatsService != null){ + sendAggregateFlowsStatsFromAllTablesRequest(targetNode.getKey()); + sendAllFlowsStatsFromAllTablesRequest(targetNodeRef); + } + if(flowTableStatsService != null){ + sendAllFlowTablesStatisticsRequest(targetNodeRef); + } + if(portStatsService != null){ + sendAllNodeConnectorsStatisticsRequest(targetNodeRef); + } + if(groupStatsService != null){ + sendAllGroupStatisticsRequest(targetNodeRef); + sendGroupDescriptionRequest(targetNodeRef); } + if(meterStatsService != null){ + sendAllMeterStatisticsRequest(targetNodeRef); + sendMeterConfigStatisticsRequest(targetNodeRef); + } + if(queueStatsService != null){ + sendAllQueueStatsFromAllNodeConnector (targetNodeRef); + } + }catch(Exception e){ + spLogger.error("Exception occured while sending statistics requests : {}", e); } } - private void sendAllFlowTablesStatisticsRequest(NodeRef targetNodeRef) throws InterruptedException, ExecutionException { + + public void sendAllFlowTablesStatisticsRequest(NodeRef targetNodeRef) throws InterruptedException, ExecutionException { final GetFlowTablesStatisticsInputBuilder input = new GetFlowTablesStatisticsInputBuilder(); @@ -219,12 +289,12 @@ public class StatisticsProvider implements AutoCloseable { Future> response = flowTableStatsService.getFlowTablesStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNodeRef),response.get().getResult().getTransactionId() , StatsRequestType.ALL_FLOW_TABLE); } - private void sendAllFlowsStatsFromAllTablesRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + public void sendAllFlowsStatsFromAllTablesRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ final GetAllFlowsStatisticsFromAllFlowTablesInputBuilder input = new GetAllFlowsStatisticsFromAllFlowTablesInputBuilder(); @@ -233,37 +303,57 @@ public class StatisticsProvider implements AutoCloseable { Future> response = flowStatsService.getAllFlowsStatisticsFromAllFlowTables(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() + , StatsRequestType.ALL_FLOW); + + } + + public void sendFlowStatsFromTableRequest(NodeRef targetNode,Flow flow) throws InterruptedException, ExecutionException{ + final GetFlowStatisticsFromFlowTableInputBuilder input = + new GetFlowStatisticsFromFlowTableInputBuilder(); + + input.setNode(targetNode); + input.fieldsFrom(flow); + + Future> response = + flowStatsService.getFlowStatisticsFromFlowTable(input.build()); + + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() , StatsRequestType.ALL_FLOW); } - private void sendAggregateFlowsStatsFromAllTablesRequest(NodeKey targetNodeKey) throws InterruptedException, ExecutionException{ + public void sendAggregateFlowsStatsFromAllTablesRequest(NodeKey targetNodeKey) throws InterruptedException, ExecutionException{ List tablesId = getTablesFromNode(targetNodeKey); if(tablesId.size() != 0){ for(Short id : tablesId){ - spLogger.trace("Send aggregate stats request for flow table {} to node {}",id,targetNodeKey); - GetAggregateFlowStatisticsFromFlowTableForAllFlowsInputBuilder input = - new GetAggregateFlowStatisticsFromFlowTableForAllFlowsInputBuilder(); - - input.setNode(new NodeRef(InstanceIdentifier.builder(Nodes.class).child(Node.class, targetNodeKey).toInstance())); - input.setTableId(new org.opendaylight.yang.gen.v1.urn.opendaylight.table.types.rev131026.TableId(id)); - Future> response = - flowStatsService.getAggregateFlowStatisticsFromFlowTableForAllFlows(input.build()); - - multipartMessageManager.setTxIdAndTableIdMapEntry(response.get().getResult().getTransactionId(), id); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.AGGR_FLOW); + sendAggregateFlowsStatsFromTableRequest(targetNodeKey,id); } }else{ spLogger.debug("No details found in data store for flow tables associated with Node {}",targetNodeKey); } } - private void sendAllNodeConnectorsStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + public void sendAggregateFlowsStatsFromTableRequest(NodeKey targetNodeKey,Short tableId) throws InterruptedException, ExecutionException{ + + spLogger.debug("Send aggregate stats request for flow table {} to node {}",tableId,targetNodeKey); + GetAggregateFlowStatisticsFromFlowTableForAllFlowsInputBuilder input = + new GetAggregateFlowStatisticsFromFlowTableForAllFlowsInputBuilder(); + + input.setNode(new NodeRef(InstanceIdentifier.builder(Nodes.class).child(Node.class, targetNodeKey).toInstance())); + input.setTableId(new org.opendaylight.yang.gen.v1.urn.opendaylight.table.types.rev131026.TableId(tableId)); + Future> response = + flowStatsService.getAggregateFlowStatisticsFromFlowTableForAllFlows(input.build()); + + multipartMessageManager.setTxIdAndTableIdMapEntry(targetNodeKey.getId(), response.get().getResult().getTransactionId(), tableId); + this.multipartMessageManager.addTxIdToRequestTypeEntry(targetNodeKey.getId(), response.get().getResult().getTransactionId() + , StatsRequestType.AGGR_FLOW); + } + + public void sendAllNodeConnectorsStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ final GetAllNodeConnectorsStatisticsInputBuilder input = new GetAllNodeConnectorsStatisticsInputBuilder(); @@ -271,12 +361,12 @@ public class StatisticsProvider implements AutoCloseable { Future> response = portStatsService.getAllNodeConnectorsStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() , StatsRequestType.ALL_PORT); } - private void sendAllGroupStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + public void sendAllGroupStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ final GetAllGroupStatisticsInputBuilder input = new GetAllGroupStatisticsInputBuilder(); @@ -285,12 +375,12 @@ public class StatisticsProvider implements AutoCloseable { Future> response = groupStatsService.getAllGroupStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() , StatsRequestType.ALL_GROUP); } - private void sendGroupDescriptionRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + public void sendGroupDescriptionRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ final GetGroupDescriptionInputBuilder input = new GetGroupDescriptionInputBuilder(); input.setNode(targetNode); @@ -298,12 +388,12 @@ public class StatisticsProvider implements AutoCloseable { Future> response = groupStatsService.getGroupDescription(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() , StatsRequestType.GROUP_DESC); } - private void sendAllMeterStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + public void sendAllMeterStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ GetAllMeterStatisticsInputBuilder input = new GetAllMeterStatisticsInputBuilder(); @@ -312,12 +402,12 @@ public class StatisticsProvider implements AutoCloseable { Future> response = meterStatsService.getAllMeterStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() , StatsRequestType.ALL_METER);; } - private void sendMeterConfigStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + public void sendMeterConfigStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ GetAllMeterConfigStatisticsInputBuilder input = new GetAllMeterConfigStatisticsInputBuilder(); @@ -326,12 +416,12 @@ public class StatisticsProvider implements AutoCloseable { Future> response = meterStatsService.getAllMeterConfigStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() , StatsRequestType.METER_CONFIG);; } - private void sendAllQueueStatsFromAllNodeConnector(NodeRef targetNode) throws InterruptedException, ExecutionException { + public void sendAllQueueStatsFromAllNodeConnector(NodeRef targetNode) throws InterruptedException, ExecutionException { GetAllQueuesStatisticsFromAllPortsInputBuilder input = new GetAllQueuesStatisticsFromAllPortsInputBuilder(); input.setNode(targetNode); @@ -339,22 +429,49 @@ public class StatisticsProvider implements AutoCloseable { Future> response = queueStatsService.getAllQueuesStatisticsFromAllPorts(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() , StatsRequestType.ALL_QUEUE_STATS);; } - public ConcurrentMap getStatisticsCache() { - return statisticsCache; + public void sendQueueStatsFromGivenNodeConnector(NodeRef targetNode,NodeConnectorId nodeConnectorId, QueueId queueId) throws InterruptedException, ExecutionException { + GetQueueStatisticsFromGivenPortInputBuilder input = new GetQueueStatisticsFromGivenPortInputBuilder(); + + input.setNode(targetNode); + input.setNodeConnectorId(nodeConnectorId); + input.setQueueId(queueId); + Future> response = + queueStatsService.getQueueStatisticsFromGivenPort(input.build()); + + this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() + , StatsRequestType.ALL_QUEUE_STATS);; + } - private List getAllConnectedNodes(){ + /** + * Get the handler for a particular node. + * + * @param nodeId source node + * @return Node statistics handler for that node. Null if the statistics should + * not handled. + */ + public final NodeStatisticsAger getStatisticsHandler(final NodeId nodeId) { + Preconditions.checkNotNull(nodeId); + NodeStatisticsAger ager = statisticsCache.get(nodeId); + if (ager == null) { + ager = new NodeStatisticsAger(this, new NodeKey(nodeId)); + statisticsCache.put(nodeId, ager); + } + + return ager; + } + private List getAllConnectedNodes(){ Nodes nodes = (Nodes) dps.readOperationalData(nodesIdentifier); if(nodes == null) return null; - spLogger.trace("Number of connected nodes : {}",nodes.getNode().size()); + spLogger.debug("Number of connected nodes : {}",nodes.getNode().size()); return nodes.getNode(); } @@ -364,7 +481,7 @@ public class StatisticsProvider implements AutoCloseable { FlowCapableNode node = (FlowCapableNode)dps.readOperationalData(nodesIdentifier); List tablesId = new ArrayList(); if(node != null && node.getTable()!=null){ - spLogger.trace("Number of tables {} supported by node {}",node.getTable().size(),nodeKey); + spLogger.debug("Number of tables {} supported by node {}",node.getTable().size(),nodeKey); for(Table table: node.getTable()){ tablesId.add(table.getId()); } @@ -372,18 +489,27 @@ public class StatisticsProvider implements AutoCloseable { return tablesId; } + @SuppressWarnings("unchecked") + private NodeId getNodeId(NodeRef nodeRef){ + InstanceIdentifier nodeII = (InstanceIdentifier) nodeRef.getValue(); + NodeKey nodeKey = InstanceIdentifier.keyOf(nodeII); + return nodeKey.getId(); + } + @SuppressWarnings("deprecation") @Override public void close(){ try { - spLogger.trace("Statistics Provider stopped."); + spLogger.info("Statistics Provider stopped."); if (this.listenerRegistration != null) { this.listenerRegistration.close(); this.statisticsRequesterThread.destroy(); + this.statisticsAgerThread.destroy(); + } } catch (Throwable e) { throw Exceptions.sneakyThrow(e);