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=3ee059d1c0e06f45e7c14a832e088b3dfc906029;hb=6fa3aa30c3eb47ca13520f9b4090bd03bf4e191f;hp=7b7403f1c327f6492d81e0a1980510025b46e37e;hpb=7974eb6a8ede81ed2593fe3fb5cda65cee51ee5d;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 7b7403f1c3..3ee059d1c0 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 @@ -7,23 +7,27 @@ */ package org.opendaylight.controller.md.statistics.manager; -import java.util.ArrayList; -import java.util.List; +import java.util.Collection; +import java.util.Timer; +import java.util.TimerTask; import java.util.concurrent.ConcurrentHashMap; import java.util.concurrent.ConcurrentMap; import java.util.concurrent.ExecutionException; import java.util.concurrent.Future; +import java.util.concurrent.TimeUnit; -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.DataChangeListener; 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.TableKey; 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; @@ -63,6 +67,7 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216. 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.ListenerRegistration; import org.opendaylight.yangtools.concepts.Registration; import org.opendaylight.yangtools.yang.binding.DataObject; import org.opendaylight.yangtools.yang.binding.InstanceIdentifier; @@ -71,178 +76,118 @@ 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 + * 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 long STATS_COLLECTION_MILLIS = TimeUnit.SECONDS.toMillis(15); + + private static final Logger spLogger = LoggerFactory.getLogger(StatisticsProvider.class); - public final static Logger spLogger = LoggerFactory.getLogger(StatisticsProvider.class); - - private DataProviderService dps; - - private DataBrokerService dbs; + private final ConcurrentMap handlers = new ConcurrentHashMap<>(); + private final Timer timer = new Timer("statistics-manager", true); + private final DataProviderService dps; - private NotificationProviderService nps; - private OpendaylightGroupStatisticsService groupStatsService; - + private OpendaylightMeterStatisticsService meterStatsService; - + private OpendaylightFlowStatisticsService flowStatsService; - + private OpendaylightPortStatisticsService portStatsService; private OpendaylightFlowTableStatisticsService flowTableStatsService; private OpendaylightQueueStatisticsService queueStatsService; - private final MultipartMessageManager multipartMessageManager = new MultipartMessageManager(); - private StatisticsUpdateHandler statsUpdateHandler; - - private Thread statisticsRequesterThread; - - private Thread statisticsAgerThread; - - private final InstanceIdentifier nodesIdentifier = InstanceIdentifier.builder(Nodes.class).toInstance(); - - public static final int STATS_THREAD_EXECUTION_TIME= 30000; - //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 DataBrokerService getDataBrokerService() { - return this.dbs; - } - - public void setDataBrokerService(final DataBrokerService dataBrokerService) { - this.dbs = dataBrokerService; - } - 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() { - return multipartMessageManager; - } + private final StatisticsListener updateCommiter = new StatisticsListener(StatisticsProvider.this); - private final StatisticsUpdateCommiter updateCommiter = new StatisticsUpdateCommiter(StatisticsProvider.this); - private Registration listenerRegistration; - - public void start() { - - NotificationProviderService nps = this.getNotificationService(); - Registration registerNotificationListener = nps.registerNotificationListener(this.updateCommiter); - this.listenerRegistration = registerNotificationListener; - + + private ListenerRegistration flowCapableTrackerRegistration; + + public void start(final DataBrokerService dbs, final NotificationProviderService nps, final RpcConsumerRegistry rpcRegistry) { + + // Get Group/Meter statistics service instances + 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); + + // Start receiving notifications + this.listenerRegistration = nps.registerNotificationListener(this.updateCommiter); + + // Register for switch connect/disconnect notifications + final InstanceIdentifier fcnId = InstanceIdentifier.builder(Nodes.class) + .child(Node.class).augmentation(FlowCapableNode.class).build(); + spLogger.debug("Registering FlowCapable tracker to {}", fcnId); + this.flowCapableTrackerRegistration = dbs.registerDataChangeListener(fcnId, + new FlowCapableTracker(this, fcnId)); + statsUpdateHandler = new StatisticsUpdateHandler(StatisticsProvider.this); - - registerDataStoreUpdateListener(this.getDataBrokerService()); - - // Get Group/Meter statistics service instance - groupStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightGroupStatisticsService.class); - - meterStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightMeterStatisticsService.class); - - flowStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightFlowStatisticsService.class); - - portStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightPortStatisticsService.class); - - flowTableStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightFlowTableStatisticsService.class); - - queueStatsService = StatisticsManagerActivator.getProviderContext(). - getRpcService(OpendaylightQueueStatisticsService.class); - - statisticsRequesterThread = new Thread( new Runnable(){ + registerDataStoreUpdateListener(dbs); + timer.schedule(new TimerTask() { @Override public void run() { - while(true){ - try { - statsRequestSender(); - - Thread.sleep(STATS_THREAD_EXECUTION_TIME); - }catch (Exception e){ - spLogger.error("Exception occurred while sending stats request : {}",e); + try { + // Send stats requests + for (NodeStatisticsHandler h : handlers.values()) { + sendStatisticsRequestsToNode(h); } - } - } - }); - - spLogger.debug("Statistics requester thread started with timer interval : {}",STATS_THREAD_EXECUTION_TIME); - - statisticsRequesterThread.start(); - - statisticsAgerThread = new Thread( new Runnable(){ - @Override - public void run() { - while(true){ - try { - for(NodeStatisticsAger nodeStatisticsAger : statisticsCache.values()){ - nodeStatisticsAger.cleanStaleStatistics(); - } - - Thread.sleep(STATS_THREAD_EXECUTION_TIME); - }catch (Exception e){ - spLogger.error("Exception occurred while sending stats request : {}",e); + // Perform cleanup + for(NodeStatisticsHandler nodeStatisticsAger : handlers.values()){ + nodeStatisticsAger.cleanStaleStatistics(); } + + } catch (RuntimeException e) { + spLogger.warn("Failed to request statistics", e); } } - }); - - spLogger.debug("Statistics ager thread started with timer interval : {}",STATS_THREAD_EXECUTION_TIME); + }, 0, STATS_COLLECTION_MILLIS); - statisticsAgerThread.start(); - + spLogger.debug("Statistics timer task with timer interval : {}ms", STATS_COLLECTION_MILLIS); spLogger.info("Statistics Provider started."); } - + private void registerDataStoreUpdateListener(DataBrokerService dbs) { + // FIXME: the below should be broken out into StatisticsUpdateHandler + //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 + + //Register for group updates InstanceIdentifier pathGroup = InstanceIdentifier.builder(Nodes.class).child(Node.class) .augmentation(FlowCapableNode.class) .child(Group.class).toInstance(); @@ -257,263 +202,276 @@ public class StatisticsProvider implements AutoCloseable { } protected DataModificationTransaction startChange() { - - DataProviderService dps = this.getDataService(); return dps.beginTransaction(); } - - private void statsRequestSender(){ - - List targetNodes = getAllConnectedNodes(); - - if(targetNodes == null) - return; - - - for (Node targetNode : targetNodes){ - - if(targetNode.getAugmentation(FlowCapableNode.class) != null){ - - spLogger.info("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); - - sendAllGroupStatisticsRequest(targetNodeRef); - - sendAllMeterStatisticsRequest(targetNodeRef); - - sendGroupDescriptionRequest(targetNodeRef); - - sendMeterConfigStatisticsRequest(targetNodeRef); - }catch(Exception e){ - spLogger.error("Exception occured while sending statistics requests : {}", e); - } + + private void sendStatisticsRequestsToNode(final NodeStatisticsHandler h) { + NodeKey targetNode = h.getTargetNodeKey(); + spLogger.debug("Send requests for statistics collection to node : {}", targetNode.getId()); + + try{ + if(flowTableStatsService != null){ + sendAllFlowTablesStatisticsRequest(h); + } + if(flowStatsService != null){ + // FIXME: it does not make sense to trigger this before sendAllFlowTablesStatisticsRequest() + // comes back -- we do not have any tables anyway. + sendAggregateFlowsStatsFromAllTablesRequest(h); + + sendAllFlowsStatsFromAllTablesRequest(h); } + if(portStatsService != null){ + sendAllNodeConnectorsStatisticsRequest(h); + } + if(groupStatsService != null){ + sendAllGroupStatisticsRequest(h); + sendGroupDescriptionRequest(h); + } + if(meterStatsService != null){ + sendAllMeterStatisticsRequest(h); + sendMeterConfigStatisticsRequest(h); + } + if(queueStatsService != null){ + sendAllQueueStatsFromAllNodeConnector(h); + } + }catch(Exception e){ + spLogger.error("Exception occured while sending statistics requests : {}", e); } } - public void sendAllFlowTablesStatisticsRequest(NodeRef targetNodeRef) throws InterruptedException, ExecutionException { - final GetFlowTablesStatisticsInputBuilder input = + + private void sendAllFlowTablesStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException { + final GetFlowTablesStatisticsInputBuilder input = new GetFlowTablesStatisticsInputBuilder(); - - input.setNode(targetNodeRef); - Future> response = - flowTableStatsService.getFlowTablesStatistics(input.build()); + input.setNode(h.getTargetNodeRef()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_FLOW_TABLE); + Future> response = + flowTableStatsService.getFlowTablesStatistics(input.build()); + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_FLOW_TABLE); } - public void sendAllFlowsStatsFromAllTablesRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + private void sendAllFlowsStatsFromAllTablesRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ final GetAllFlowsStatisticsFromAllFlowTablesInputBuilder input = new GetAllFlowsStatisticsFromAllFlowTablesInputBuilder(); - - input.setNode(targetNode); - - Future> response = + + input.setNode(h.getTargetNodeRef()); + + Future> response = flowStatsService.getAllFlowsStatisticsFromAllFlowTables(input.build()); - - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_FLOW); - + + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_FLOW); + } + + public void sendFlowStatsFromTableRequest(NodeKey node, Flow flow) throws InterruptedException, ExecutionException { + final NodeStatisticsHandler h = getStatisticsHandler(node.getId()); + if (h != null) { + sendFlowStatsFromTableRequest(h, flow); + } } - - public void sendFlowStatsFromTableRequest(NodeRef targetNode,Flow flow) throws InterruptedException, ExecutionException{ + + private void sendFlowStatsFromTableRequest(NodeStatisticsHandler h, Flow flow) throws InterruptedException, ExecutionException{ final GetFlowStatisticsFromFlowTableInputBuilder input = - new GetFlowStatisticsFromFlowTableInputBuilder(); - - input.setNode(targetNode); - input.fieldsFrom(flow); - - Future> response = + new GetFlowStatisticsFromFlowTableInputBuilder(flow); + + input.setNode(h.getTargetNodeRef()); + + Future> response = flowStatsService.getFlowStatisticsFromFlowTable(input.build()); - - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_FLOW); - + + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_FLOW); } - public void sendAggregateFlowsStatsFromAllTablesRequest(NodeKey targetNodeKey) throws InterruptedException, ExecutionException{ - - List tablesId = getTablesFromNode(targetNodeKey); - - if(tablesId.size() != 0){ - for(Short id : tablesId){ - - spLogger.info("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); - } - }else{ - spLogger.debug("No details found in data store for flow tables associated with Node {}",targetNodeKey); + private void sendAggregateFlowsStatsFromAllTablesRequest(final NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ + final Collection tables = h.getKnownTables(); + spLogger.debug("Node {} supports {} table(s)", h, tables.size()); + + for (TableKey key : h.getKnownTables()) { + sendAggregateFlowsStatsFromTableRequest(h, key.getId().shortValue()); } } - public void sendAllNodeConnectorsStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ - + private void sendAggregateFlowsStatsFromTableRequest(final NodeStatisticsHandler h, Short tableId) throws InterruptedException, ExecutionException{ + + spLogger.debug("Send aggregate stats request for flow table {} to node {}",tableId, h.getTargetNodeKey()); + GetAggregateFlowStatisticsFromFlowTableForAllFlowsInputBuilder input = + new GetAggregateFlowStatisticsFromFlowTableForAllFlowsInputBuilder(); + + input.setNode(new NodeRef(InstanceIdentifier.builder(Nodes.class).child(Node.class, h.getTargetNodeKey()).toInstance())); + input.setTableId(new org.opendaylight.yang.gen.v1.urn.opendaylight.table.types.rev131026.TableId(tableId)); + Future> response = + flowStatsService.getAggregateFlowStatisticsFromFlowTableForAllFlows(input.build()); + + h.recordExpectedTableTransaction(response.get().getResult().getTransactionId(), tableId); + } + + private void sendAllNodeConnectorsStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ + final GetAllNodeConnectorsStatisticsInputBuilder input = new GetAllNodeConnectorsStatisticsInputBuilder(); - - input.setNode(targetNode); - Future> response = - portStatsService.getAllNodeConnectorsStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_PORT); + input.setNode(h.getTargetNodeRef()); + Future> response = + portStatsService.getAllNodeConnectorsStatistics(input.build()); + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_PORT); } - public void sendAllGroupStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ - + private void sendAllGroupStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ + final GetAllGroupStatisticsInputBuilder input = new GetAllGroupStatisticsInputBuilder(); - - input.setNode(targetNode); - Future> response = + input.setNode(h.getTargetNodeRef()); + + Future> response = groupStatsService.getAllGroupStatistics(input.build()); - - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_GROUP); + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_GROUP); } - - public void sendGroupDescriptionRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + + public void sendGroupDescriptionRequest(NodeKey node) throws InterruptedException, ExecutionException{ + final NodeStatisticsHandler h = getStatisticsHandler(node.getId()); + if (h != null) { + sendGroupDescriptionRequest(h); + } + } + + private void sendGroupDescriptionRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ final GetGroupDescriptionInputBuilder input = new GetGroupDescriptionInputBuilder(); - - input.setNode(targetNode); - Future> response = - groupStatsService.getGroupDescription(input.build()); + input.setNode(h.getTargetNodeRef()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.GROUP_DESC); + Future> response = + groupStatsService.getGroupDescription(input.build()); + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.GROUP_DESC); } - - public void sendAllMeterStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ - + + private void sendAllMeterStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ + GetAllMeterStatisticsInputBuilder input = new GetAllMeterStatisticsInputBuilder(); - - input.setNode(targetNode); - Future> response = + input.setNode(h.getTargetNodeRef()); + + Future> response = meterStatsService.getAllMeterStatistics(input.build()); - - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_METER);; + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_METER); + } + + public void sendMeterConfigStatisticsRequest(NodeKey node) throws InterruptedException, ExecutionException { + final NodeStatisticsHandler h = getStatisticsHandler(node.getId()); + if (h != null) { + sendMeterConfigStatisticsRequest(h); + } } - - public void sendMeterConfigStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ - + + private void sendMeterConfigStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ + GetAllMeterConfigStatisticsInputBuilder input = new GetAllMeterConfigStatisticsInputBuilder(); - - input.setNode(targetNode); - Future> response = + input.setNode(h.getTargetNodeRef()); + + Future> response = meterStatsService.getAllMeterConfigStatistics(input.build()); - - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.METER_CONFIG);; + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.METER_CONFIG);; } - - public void sendAllQueueStatsFromAllNodeConnector(NodeRef targetNode) throws InterruptedException, ExecutionException { + + private void sendAllQueueStatsFromAllNodeConnector(NodeStatisticsHandler h) throws InterruptedException, ExecutionException { GetAllQueuesStatisticsFromAllPortsInputBuilder input = new GetAllQueuesStatisticsFromAllPortsInputBuilder(); - - input.setNode(targetNode); - - Future> response = + + input.setNode(h.getTargetNodeRef()); + + Future> response = queueStatsService.getAllQueuesStatisticsFromAllPorts(input.build()); - - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_QUEUE_STATS);; + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_QUEUE_STATS);; + } + + public void sendQueueStatsFromGivenNodeConnector(NodeKey node,NodeConnectorId nodeConnectorId, QueueId queueId) throws InterruptedException, ExecutionException { + final NodeStatisticsHandler h = getStatisticsHandler(node.getId()); + if (h != null) { + sendQueueStatsFromGivenNodeConnector(h, nodeConnectorId, queueId); + } } - public void sendQueueStatsFromGivenNodeConnector(NodeRef targetNode,NodeConnectorId nodeConnectorId, QueueId queueId) throws InterruptedException, ExecutionException { + private void sendQueueStatsFromGivenNodeConnector(NodeStatisticsHandler h, NodeConnectorId nodeConnectorId, QueueId queueId) throws InterruptedException, ExecutionException { GetQueueStatisticsFromGivenPortInputBuilder input = new GetQueueStatisticsFromGivenPortInputBuilder(); - - input.setNode(targetNode); + + input.setNode(h.getTargetNodeRef()); input.setNodeConnectorId(nodeConnectorId); input.setQueueId(queueId); - Future> response = + Future> response = queueStatsService.getQueueStatisticsFromGivenPort(input.build()); - - this.multipartMessageManager.addTxIdToRequestTypeEntry(response.get().getResult().getTransactionId() - , StatsRequestType.ALL_QUEUE_STATS);; + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_QUEUE_STATS);; } - public ConcurrentMap getStatisticsCache() { - return statisticsCache; - } - - private List getAllConnectedNodes(){ - - Nodes nodes = (Nodes) dps.readOperationalData(nodesIdentifier); - if(nodes == null) - return null; - - spLogger.info("Number of connected nodes : {}",nodes.getNode().size()); - return nodes.getNode(); - } - - private List getTablesFromNode(NodeKey nodeKey){ - InstanceIdentifier nodesIdentifier = InstanceIdentifier.builder(Nodes.class).child(Node.class,nodeKey).augmentation(FlowCapableNode.class).toInstance(); - - FlowCapableNode node = (FlowCapableNode)dps.readOperationalData(nodesIdentifier); - List tablesId = new ArrayList(); - if(node != null && node.getTable()!=null){ - spLogger.info("Number of tables {} supported by node {}",node.getTable().size(),nodeKey); - for(Table table: node.getTable()){ - tablesId.add(table.getId()); - } + /** + * 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 NodeStatisticsHandler getStatisticsHandler(final NodeId nodeId) { + Preconditions.checkNotNull(nodeId); + NodeStatisticsHandler handler = handlers.get(nodeId); + if (handler == null) { + spLogger.info("Attempted to get non-existing handler for {}", nodeId); } - return tablesId; + return handler; } - @SuppressWarnings("deprecation") @Override - public void close(){ - + public void close() { try { - spLogger.info("Statistics Provider stopped."); if (this.listenerRegistration != null) { - this.listenerRegistration.close(); - - this.statisticsRequesterThread.destroy(); - - this.statisticsAgerThread.destroy(); - + this.listenerRegistration = null; + } + if (this.flowCapableTrackerRegistration != null) { + this.flowCapableTrackerRegistration.close(); + this.flowCapableTrackerRegistration = null; } - } catch (Throwable e) { - throw Exceptions.sneakyThrow(e); - } + timer.cancel(); + } catch (Exception e) { + spLogger.warn("Failed to stop Statistics Provider completely", e); + } finally { + spLogger.info("Statistics Provider stopped."); + } + } + + void startNodeHandlers(final Collection addedNodes) { + for (NodeKey key : addedNodes) { + if (handlers.containsKey(key.getId())) { + spLogger.warn("Attempted to start already-existing handler for {}, very strange", key.getId()); + continue; + } + + final NodeStatisticsHandler h = new NodeStatisticsHandler(dps, key); + final NodeStatisticsHandler old = handlers.putIfAbsent(key.getId(), h); + if (old == null) { + spLogger.debug("Started node handler for {}", key.getId()); + + // FIXME: this should be in the NodeStatisticsHandler itself + sendStatisticsRequestsToNode(h); + } else { + spLogger.debug("Prevented race on handler for {}", key.getId()); + } + } } + void stopNodeHandlers(final Collection removedNodes) { + for (NodeKey key : removedNodes) { + final NodeStatisticsHandler s = handlers.remove(key.getId()); + if (s != null) { + spLogger.debug("Stopping node handler for {}", key.getId()); + s.close(); + } else { + spLogger.warn("Attempted to remove non-existing handler for {}, very strange", key.getId()); + } + } + } }