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=b7fb4e9473f740a842d190dec7f916bd4eaa7c33;hpb=51f23bab3264b691066a2954aeb65c5049ce29ca;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 b7fb4e9473..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 @@ -8,11 +8,13 @@ package org.opendaylight.controller.md.statistics.manager; import java.util.Collection; -import java.util.List; +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.opendaylight.controller.md.statistics.manager.MultipartMessageManager.StatsRequestType; import org.opendaylight.controller.sal.binding.api.NotificationProviderService; @@ -25,6 +27,7 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.Fl 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; @@ -88,15 +91,13 @@ import com.google.common.base.Preconditions; * */ public class StatisticsProvider implements AutoCloseable { - public static final int STATS_THREAD_EXECUTION_TIME= 15000; + public static final long STATS_COLLECTION_MILLIS = TimeUnit.SECONDS.toMillis(15); private static final Logger spLogger = LoggerFactory.getLogger(StatisticsProvider.class); - private final MultipartMessageManager multipartMessageManager = new MultipartMessageManager(); - private final DataProviderService dps; - - //Local caching of stats private final ConcurrentMap handlers = new ConcurrentHashMap<>(); + private final Timer timer = new Timer("statistics-manager", true); + private final DataProviderService dps; private OpendaylightGroupStatisticsService groupStatsService; @@ -112,19 +113,10 @@ public class StatisticsProvider implements AutoCloseable { private StatisticsUpdateHandler statsUpdateHandler; - private Thread statisticsRequesterThread; - - private Thread statisticsAgerThread; - - public StatisticsProvider(final DataProviderService dataService) { this.dps = Preconditions.checkNotNull(dataService); } - public MultipartMessageManager getMultipartMessageManager() { - return multipartMessageManager; - } - private final StatisticsListener updateCommiter = new StatisticsListener(StatisticsProvider.this); private Registration listenerRegistration; @@ -147,55 +139,34 @@ public class StatisticsProvider implements AutoCloseable { // 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(dbs); - statisticsRequesterThread = new Thread( new Runnable(){ - + 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(NodeStatisticsHandler nodeStatisticsAger : handlers.values()){ - nodeStatisticsAger.cleanStaleStatistics(); - } - multipartMessageManager.cleanStaleTransactionIds(); - - 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); - - statisticsAgerThread.start(); + }, 0, STATS_COLLECTION_MILLIS); + spLogger.debug("Statistics timer task with timer interval : {}ms", STATS_COLLECTION_MILLIS); spLogger.info("Statistics Provider started."); } @@ -234,41 +205,34 @@ public class StatisticsProvider implements AutoCloseable { return dps.beginTransaction(); } - private void statsRequestSender() { - for (NodeStatisticsHandler h : handlers.values()) { - sendStatisticsRequestsToNode(h.getTargetNodeKey()); - } - } - - private void sendStatisticsRequestsToNode(NodeKey targetNode){ - - spLogger.debug("Send requests for statistics collection to node : {})",targetNode.getId()); - - InstanceIdentifier targetInstanceId = InstanceIdentifier.builder(Nodes.class).child(Node.class,targetNode).toInstance(); - - NodeRef targetNodeRef = new NodeRef(targetInstanceId); + private void sendStatisticsRequestsToNode(final NodeStatisticsHandler h) { + NodeKey targetNode = h.getTargetNodeKey(); + spLogger.debug("Send requests for statistics collection to node : {}", targetNode.getId()); try{ - if(flowStatsService != null){ - sendAggregateFlowsStatsFromAllTablesRequest(targetNode); - sendAllFlowsStatsFromAllTablesRequest(targetNodeRef); - } if(flowTableStatsService != null){ - sendAllFlowTablesStatisticsRequest(targetNodeRef); + 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(targetNodeRef); + sendAllNodeConnectorsStatisticsRequest(h); } if(groupStatsService != null){ - sendAllGroupStatisticsRequest(targetNodeRef); - sendGroupDescriptionRequest(targetNodeRef); + sendAllGroupStatisticsRequest(h); + sendGroupDescriptionRequest(h); } if(meterStatsService != null){ - sendAllMeterStatisticsRequest(targetNodeRef); - sendMeterConfigStatisticsRequest(targetNodeRef); + sendAllMeterStatisticsRequest(h); + sendMeterConfigStatisticsRequest(h); } if(queueStatsService != null){ - sendAllQueueStatsFromAllNodeConnector (targetNodeRef); + sendAllQueueStatsFromAllNodeConnector(h); } }catch(Exception e){ spLogger.error("Exception occured while sending statistics requests : {}", e); @@ -276,176 +240,172 @@ public class StatisticsProvider implements AutoCloseable { } - private void sendAllFlowTablesStatisticsRequest(NodeRef targetNodeRef) throws InterruptedException, ExecutionException { + private void sendAllFlowTablesStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException { final GetFlowTablesStatisticsInputBuilder input = new GetFlowTablesStatisticsInputBuilder(); - input.setNode(targetNodeRef); + input.setNode(h.getTargetNodeRef()); Future> response = flowTableStatsService.getFlowTablesStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNodeRef),response.get().getResult().getTransactionId() - , StatsRequestType.ALL_FLOW_TABLE); - + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_FLOW_TABLE); } - private void sendAllFlowsStatsFromAllTablesRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + private void sendAllFlowsStatsFromAllTablesRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ final GetAllFlowsStatisticsFromAllFlowTablesInputBuilder input = new GetAllFlowsStatisticsFromAllFlowTablesInputBuilder(); - input.setNode(targetNode); + input.setNode(h.getTargetNodeRef()); Future> response = flowStatsService.getAllFlowsStatisticsFromAllFlowTables(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), 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(); + new GetFlowStatisticsFromFlowTableInputBuilder(flow); - input.setNode(targetNode); - input.fieldsFrom(flow); + input.setNode(h.getTargetNodeRef()); Future> response = flowStatsService.getFlowStatisticsFromFlowTable(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() - , StatsRequestType.ALL_FLOW); - + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_FLOW); } - private void sendAggregateFlowsStatsFromAllTablesRequest(final NodeKey nodeKey) throws InterruptedException, ExecutionException{ - FlowCapableNode node = (FlowCapableNode)dps.readOperationalData( - InstanceIdentifier.builder(Nodes.class).child(Node.class,nodeKey).augmentation(FlowCapableNode.class).build()); - if (node != null) { - final List tables = node.getTable(); - if (tables != null) { - spLogger.debug("Node {} supports {} table(s)", nodeKey, tables.size()); - for(Table table : tables) { - sendAggregateFlowsStatsFromTableRequest(nodeKey, table.getId()); - } - } else { - spLogger.debug("Node {} has no associated tables", nodeKey); - } - } else { - spLogger.debug("Node {} not found", nodeKey); + 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()); } } - private void sendAggregateFlowsStatsFromTableRequest(NodeKey targetNodeKey,Short tableId) 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,targetNodeKey); + 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, targetNodeKey).toInstance())); + 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()); - multipartMessageManager.setTxIdAndTableIdMapEntry(targetNodeKey.getId(), response.get().getResult().getTransactionId(), tableId); - this.multipartMessageManager.addTxIdToRequestTypeEntry(targetNodeKey.getId(), response.get().getResult().getTransactionId() - , StatsRequestType.AGGR_FLOW); + h.recordExpectedTableTransaction(response.get().getResult().getTransactionId(), tableId); } - private void sendAllNodeConnectorsStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + private void sendAllNodeConnectorsStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ final GetAllNodeConnectorsStatisticsInputBuilder input = new GetAllNodeConnectorsStatisticsInputBuilder(); - input.setNode(targetNode); + input.setNode(h.getTargetNodeRef()); Future> response = portStatsService.getAllNodeConnectorsStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() - , StatsRequestType.ALL_PORT); - + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_PORT); } - private void sendAllGroupStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + private void sendAllGroupStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ final GetAllGroupStatisticsInputBuilder input = new GetAllGroupStatisticsInputBuilder(); - input.setNode(targetNode); + input.setNode(h.getTargetNodeRef()); Future> response = groupStatsService.getAllGroupStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() - , StatsRequestType.ALL_GROUP); + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_GROUP); + } + public void sendGroupDescriptionRequest(NodeKey node) throws InterruptedException, ExecutionException{ + final NodeStatisticsHandler h = getStatisticsHandler(node.getId()); + if (h != null) { + sendGroupDescriptionRequest(h); + } } - public void sendGroupDescriptionRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + private void sendGroupDescriptionRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ final GetGroupDescriptionInputBuilder input = new GetGroupDescriptionInputBuilder(); - input.setNode(targetNode); + input.setNode(h.getTargetNodeRef()); Future> response = groupStatsService.getGroupDescription(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() - , StatsRequestType.GROUP_DESC); - + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.GROUP_DESC); } - private void sendAllMeterStatisticsRequest(NodeRef targetNode) throws InterruptedException, ExecutionException{ + private void sendAllMeterStatisticsRequest(NodeStatisticsHandler h) throws InterruptedException, ExecutionException{ GetAllMeterStatisticsInputBuilder input = new GetAllMeterStatisticsInputBuilder(); - input.setNode(targetNode); + input.setNode(h.getTargetNodeRef()); Future> response = meterStatsService.getAllMeterStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), 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); + input.setNode(h.getTargetNodeRef()); Future> response = meterStatsService.getAllMeterConfigStatistics(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() - , StatsRequestType.METER_CONFIG);; - + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.METER_CONFIG);; } - private void sendAllQueueStatsFromAllNodeConnector(NodeRef targetNode) throws InterruptedException, ExecutionException { + private void sendAllQueueStatsFromAllNodeConnector(NodeStatisticsHandler h) throws InterruptedException, ExecutionException { GetAllQueuesStatisticsFromAllPortsInputBuilder input = new GetAllQueuesStatisticsFromAllPortsInputBuilder(); - input.setNode(targetNode); + input.setNode(h.getTargetNodeRef()); Future> response = queueStatsService.getAllQueuesStatisticsFromAllPorts(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), 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 = queueStatsService.getQueueStatisticsFromGivenPort(input.build()); - this.multipartMessageManager.addTxIdToRequestTypeEntry(getNodeId(targetNode), response.get().getResult().getTransactionId() - , StatsRequestType.ALL_QUEUE_STATS);; - + h.recordExpectedTransaction(response.get().getResult().getTransactionId(), StatsRequestType.ALL_QUEUE_STATS);; } /** @@ -464,25 +424,18 @@ public class StatisticsProvider implements AutoCloseable { return handler; } - @SuppressWarnings("unchecked") - private NodeId getNodeId(NodeRef nodeRef){ - InstanceIdentifier nodeII = (InstanceIdentifier) nodeRef.getValue(); - NodeKey nodeKey = InstanceIdentifier.keyOf(nodeII); - return nodeKey.getId(); - } - @Override public void close() { try { 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; } + timer.cancel(); } catch (Exception e) { spLogger.warn("Failed to stop Statistics Provider completely", e); } finally { @@ -490,23 +443,27 @@ public class StatisticsProvider implements AutoCloseable { } } - synchronized void startNodeHandlers(final Collection addedNodes) { + 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(this, key); - handlers.put(key.getId(), h); - spLogger.debug("Started node handler for {}", key.getId()); + 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(key); + // FIXME: this should be in the NodeStatisticsHandler itself + sendStatisticsRequestsToNode(h); + } else { + spLogger.debug("Prevented race on handler for {}", key.getId()); + } } } - synchronized void stopNodeHandlers(final Collection removedNodes) { + void stopNodeHandlers(final Collection removedNodes) { for (NodeKey key : removedNodes) { final NodeStatisticsHandler s = handlers.remove(key.getId()); if (s != null) {