X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?a=blobdiff_plain;f=openflowplugin-impl%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fopenflowplugin%2Fimpl%2Fstatistics%2FStatisticsGatheringUtils.java;h=ec74cc43b8055ebfc59069425ed8877f886206ad;hb=52f69b2f96908053793d76807ee5e82b4dc21e4f;hp=8634c1abcb51ded5bf598e4b68e1d63c48e14ce6;hpb=d1cecf72132dc1fbaf2074f21530cb51919a55c4;p=openflowplugin.git diff --git a/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/statistics/StatisticsGatheringUtils.java b/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/statistics/StatisticsGatheringUtils.java index 8634c1abcb..ec74cc43b8 100644 --- a/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/statistics/StatisticsGatheringUtils.java +++ b/openflowplugin-impl/src/main/java/org/opendaylight/openflowplugin/impl/statistics/StatisticsGatheringUtils.java @@ -9,21 +9,25 @@ package org.opendaylight.openflowplugin.impl.statistics; import com.google.common.base.Function; +import com.google.common.base.Optional; +import com.google.common.collect.Iterables; +import com.google.common.util.concurrent.CheckedFuture; import com.google.common.util.concurrent.Futures; import com.google.common.util.concurrent.JdkFutureAdapters; import com.google.common.util.concurrent.ListenableFuture; +import java.util.Collections; import java.util.List; -import java.util.Map; +import java.util.concurrent.ExecutionException; import javax.annotation.Nullable; +import org.opendaylight.controller.md.sal.binding.api.ReadTransaction; import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType; +import org.opendaylight.controller.md.sal.common.api.data.ReadFailedException; import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext; -import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowDescriptor; -import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowHash; -import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowRegistryException; -import org.opendaylight.openflowplugin.impl.registry.flow.FlowDescriptorFactory; -import org.opendaylight.openflowplugin.impl.registry.flow.FlowHashFactory; -import org.opendaylight.openflowplugin.impl.statistics.services.dedicated.StatisticsGatheringService; -import org.opendaylight.openflowplugin.impl.util.FlowUtil; +import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowRegistryKey; +import org.opendaylight.openflowplugin.api.openflow.statistics.ofpspecific.EventIdentifier; +import org.opendaylight.openflowplugin.api.openflow.statistics.ofpspecific.StatisticsGatherer; +import org.opendaylight.openflowplugin.impl.registry.flow.FlowRegistryKeyFactory; +import org.opendaylight.openflowplugin.impl.statistics.ofpspecific.EventsTimeCounter; 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.FlowId; @@ -31,18 +35,23 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.me import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.meters.MeterBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.meters.MeterKey; 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.TableBuilder; 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.inventory.rev130819.tables.table.FlowBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.tables.table.FlowKey; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.FlowStatisticsData; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.FlowStatisticsDataBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.FlowsStatisticsUpdate; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.flow.and.statistics.map.list.FlowAndStatisticsMapList; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.statistics.rev130819.flow.statistics.FlowStatisticsBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.FlowTableStatisticsData; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.FlowTableStatisticsUpdate; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.flow.table.and.statistics.map.FlowTableAndStatisticsMap; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.flow.table.statistics.FlowTableStatistics; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.table.statistics.rev131215.flow.table.statistics.FlowTableStatisticsBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.types.port.rev130925.queues.Queue; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.types.port.rev130925.queues.QueueBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.types.port.rev130925.queues.QueueKey; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.statistics.rev131111.GroupDescStatsUpdated; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.statistics.rev131111.GroupStatisticsUpdated; @@ -56,12 +65,9 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.group import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.groups.Group; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.groups.GroupBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.groups.GroupKey; -import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId; -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.node.NodeConnectorKey; 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.MeterConfigStatsUpdated; import org.opendaylight.yang.gen.v1.urn.opendaylight.meter.statistics.rev131111.MeterStatisticsUpdated; import org.opendaylight.yang.gen.v1.urn.opendaylight.meter.statistics.rev131111.NodeMeterStatistics; @@ -98,255 +104,294 @@ public final class StatisticsGatheringUtils { private static final Logger LOG = LoggerFactory.getLogger(StatisticsGatheringUtils.class); private static final SinglePurposeMultipartReplyTranslator MULTIPART_REPLY_TRANSLATOR = new SinglePurposeMultipartReplyTranslator(); + public static final String QUEUE2_REQCTX = "QUEUE2REQCTX-"; private StatisticsGatheringUtils() { throw new IllegalStateException("This class should not be instantiated."); } - private static KeyedInstanceIdentifier getInstanceIdentifier(final DeviceContext deviceContext) { - return InstanceIdentifier.create(Nodes.class).child(Node.class, new NodeKey(deviceContext.getPrimaryConnectionContext().getNodeId())); - } - public static ListenableFuture gatherStatistics(final StatisticsGatheringService statisticsGatheringService, + public static ListenableFuture gatherStatistics(final StatisticsGatherer statisticsGatheringService, final DeviceContext deviceContext, final MultipartType type) { //FIXME : anytype listener must not be send as parameter, it has to be extracted from device context inside service + final String deviceId = deviceContext.getPrimaryConnectionContext().getNodeId().toString(); + EventIdentifier wholeProcessEventIdentifier = null; + if (MultipartType.OFPMPFLOW.equals(type)) { + wholeProcessEventIdentifier = new EventIdentifier(type.toString(), deviceId); + EventsTimeCounter.markStart(wholeProcessEventIdentifier); + } + EventIdentifier ofpQueuToRequestContextEventIdentifier = new EventIdentifier(QUEUE2_REQCTX + type.toString(), deviceId); final ListenableFuture>> statisticsDataInFuture = - JdkFutureAdapters.listenInPoolThread(statisticsGatheringService.getStatisticsOfType(type)); - return transformAndStoreStatisticsData(statisticsDataInFuture, deviceContext); + JdkFutureAdapters.listenInPoolThread(statisticsGatheringService.getStatisticsOfType( + ofpQueuToRequestContextEventIdentifier, type)); + return transformAndStoreStatisticsData(statisticsDataInFuture, deviceContext, wholeProcessEventIdentifier); } private static ListenableFuture transformAndStoreStatisticsData(final ListenableFuture>> statisticsDataInFuture, - final DeviceContext deviceContext) { + final DeviceContext deviceContext, + final EventIdentifier eventIdentifier) { return Futures.transform(statisticsDataInFuture, new Function>, Boolean>() { @Nullable @Override public Boolean apply(final RpcResult> rpcResult) { if (rpcResult.isSuccessful()) { - for (final MultipartReply singleReply : rpcResult.getResult()) { - final List multipartDataList = MULTIPART_REPLY_TRANSLATOR.translate(deviceContext, singleReply); - for (final DataObject singleMultipartData : multipartDataList) { - if (singleMultipartData instanceof GroupStatisticsUpdated) { - processGroupStatistics((GroupStatisticsUpdated) singleMultipartData, deviceContext); - } - - if (singleMultipartData instanceof MeterStatisticsUpdated) { - processMetersStatistics((MeterStatisticsUpdated) singleMultipartData, deviceContext); - } - if (singleMultipartData instanceof NodeConnectorStatisticsUpdate) { - processNodeConnectorStatistics((NodeConnectorStatisticsUpdate) singleMultipartData, deviceContext); - } - if (singleMultipartData instanceof FlowTableStatisticsUpdate) { - processFlowTableStatistics((FlowTableStatisticsUpdate) singleMultipartData, deviceContext); - } - if (singleMultipartData instanceof QueueStatisticsUpdate) { - processQueueStatistics((QueueStatisticsUpdate) singleMultipartData, deviceContext); - } - if (singleMultipartData instanceof FlowsStatisticsUpdate) { - processFlowStatistics((FlowsStatisticsUpdate) singleMultipartData, deviceContext); - } - if (singleMultipartData instanceof GroupDescStatsUpdated) { - processGroupDescStats((GroupDescStatsUpdated) singleMultipartData, deviceContext); - } - if (singleMultipartData instanceof MeterConfigStatsUpdated) { - processMeterConfigStatsUpdated((MeterConfigStatsUpdated) singleMultipartData, deviceContext); - } - - //TODO : implement experimenter + boolean isMultipartProcessed = Boolean.TRUE; + + // TODO: in case the result value is null then multipart data probably got processed on the fly - + // TODO: this contract should by clearly stated and enforced - now simple true value is returned + if (null != rpcResult.getResult()) { + Iterable allMultipartData = Collections.emptyList(); + DataObject multipartData = null; + for (final MultipartReply singleReply : rpcResult.getResult()) { + final List multipartDataList = MULTIPART_REPLY_TRANSLATOR.translate(deviceContext, singleReply); + multipartData = multipartDataList.get(0); + allMultipartData = Iterables.concat(allMultipartData, multipartDataList); + } + + if (multipartData instanceof GroupStatisticsUpdated) { + processGroupStatistics((Iterable) allMultipartData, deviceContext); + } else if (multipartData instanceof MeterStatisticsUpdated) { + processMetersStatistics((Iterable) allMultipartData, deviceContext); + } else if (multipartData instanceof NodeConnectorStatisticsUpdate) { + processNodeConnectorStatistics((Iterable) allMultipartData, deviceContext); + } else if (multipartData instanceof FlowTableStatisticsUpdate) { + processFlowTableStatistics((Iterable) allMultipartData, deviceContext); + } else if (multipartData instanceof QueueStatisticsUpdate) { + processQueueStatistics((Iterable) allMultipartData, deviceContext); + } else if (multipartData instanceof FlowsStatisticsUpdate) { + processFlowStatistics((Iterable) allMultipartData, deviceContext); + EventsTimeCounter.markEnd(eventIdentifier); + } else if (multipartData instanceof GroupDescStatsUpdated) { + processGroupDescStats((Iterable) allMultipartData, deviceContext); + } else if (multipartData instanceof MeterConfigStatsUpdated) { + processMeterConfigStatsUpdated((Iterable) allMultipartData, deviceContext); + } else { + isMultipartProcessed = Boolean.FALSE; } + //TODO : implement experimenter } - return Boolean.TRUE; + + return isMultipartProcessed; } return Boolean.FALSE; } }); } - private static void processMeterConfigStatsUpdated(final MeterConfigStatsUpdated meterConfigStatsUpdated, final DeviceContext deviceContext) { - NodeId nodeId = meterConfigStatsUpdated.getId(); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(nodeId); + private static void processMeterConfigStatsUpdated(final Iterable data, final DeviceContext deviceContext) { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceContext); deleteAllKnownMeters(deviceContext, fNodeIdent); - for (MeterConfigStats meterConfigStats : meterConfigStatsUpdated.getMeterConfigStats()) { - final MeterId meterId = meterConfigStats.getMeterId(); - final InstanceIdentifier meterInstanceIdentifier = fNodeIdent.child(Meter.class, new MeterKey(meterId)); - - final MeterBuilder meterBuilder = new MeterBuilder(meterConfigStats); - meterBuilder.setKey(new MeterKey(meterId)); - meterBuilder.addAugmentation(NodeMeterStatistics.class, new NodeMeterStatisticsBuilder().build()); - - deviceContext.getDeviceMeterRegistry().store(meterId); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, meterInstanceIdentifier, meterBuilder.build()); + for (final MeterConfigStatsUpdated meterConfigStatsUpdated : data) { + for (final MeterConfigStats meterConfigStats : meterConfigStatsUpdated.getMeterConfigStats()) { + final MeterId meterId = meterConfigStats.getMeterId(); + final InstanceIdentifier meterInstanceIdentifier = fNodeIdent.child(Meter.class, new MeterKey(meterId)); + + final MeterBuilder meterBuilder = new MeterBuilder(meterConfigStats); + meterBuilder.setKey(new MeterKey(meterId)); + meterBuilder.addAugmentation(NodeMeterStatistics.class, new NodeMeterStatisticsBuilder().build()); + deviceContext.getDeviceMeterRegistry().store(meterId); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, meterInstanceIdentifier, meterBuilder.build()); + } } + deviceContext.submitTransaction(); + } + + private static void processFlowStatistics(final Iterable data, final DeviceContext deviceContext) { + deleteAllKnownFlows(deviceContext); + writeFlowStatistics(data, deviceContext); + deviceContext.submitTransaction(); } - private static void processFlowStatistics(final FlowsStatisticsUpdate singleMultipartData, final DeviceContext deviceContext) { - final FlowsStatisticsUpdate flowsStatistics = singleMultipartData; - final InstanceIdentifier nodeIdent = InstanceIdentifier.create(Nodes.class) - .child(Node.class, new NodeKey(flowsStatistics.getId())); - - deleteAllKnownFlows(deviceContext, nodeIdent); - - for (final FlowAndStatisticsMapList flowStat : flowsStatistics.getFlowAndStatisticsMapList()) { - final FlowBuilder flowBuilder = new FlowBuilder(flowStat); - FlowId flowId = null; - FlowHash flowHash = FlowHashFactory.create(flowBuilder.build(), deviceContext); - short tableId = flowStat.getTableId(); - try { - FlowDescriptor flowDescriptor = deviceContext.getDeviceFlowRegistry().retrieveIdForFlow(flowHash); - flowId = flowDescriptor.getFlowId(); - } catch (FlowRegistryException e) { - LOG.trace("Flow descriptor for flow hash {} wasn't found.", flowHash.hashCode()); - flowId = FlowUtil.createAlienFlowId(tableId); - FlowDescriptor flowDescriptor = FlowDescriptorFactory.create(tableId, flowId); - deviceContext.getDeviceFlowRegistry().store(flowHash, flowDescriptor); + public static void writeFlowStatistics(Iterable data, DeviceContext deviceContext) { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceContext); + for (final FlowsStatisticsUpdate flowsStatistics : data) { + for (final FlowAndStatisticsMapList flowStat : flowsStatistics.getFlowAndStatisticsMapList()) { + final FlowBuilder flowBuilder = new FlowBuilder(flowStat); + flowBuilder.addAugmentation(FlowStatisticsData.class, refineFlowStatisticsAugmentation(flowStat).build()); + + final short tableId = flowStat.getTableId(); + final FlowRegistryKey flowRegistryKey = FlowRegistryKeyFactory.create(flowBuilder.build()); + final FlowId flowId = deviceContext.getDeviceFlowRegistry().storeIfNecessary(flowRegistryKey, tableId); + + final FlowKey flowKey = new FlowKey(flowId); + flowBuilder.setKey(flowKey); + final TableKey tableKey = new TableKey(tableId); + final InstanceIdentifier flowIdent = fNodeIdent.child(Table.class, tableKey).child(Flow.class, flowKey); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowIdent, flowBuilder.build()); } - FlowKey flowKey = new FlowKey(flowId); - flowBuilder.setKey(flowKey); - final TableKey tableKey = new TableKey(tableId); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(singleMultipartData.getId()); - final InstanceIdentifier flowIdent = fNodeIdent.child(Table.class, tableKey).child(Flow.class, flowKey); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowIdent, flowBuilder.build()); } } - private static void deleteAllKnownFlows(final DeviceContext deviceContext, final InstanceIdentifier nodeIdent) { + /** + * Method extracts flow statistics out of flowAndStatistics model + * + * @param flowAndStats + */ + private static FlowStatisticsDataBuilder refineFlowStatisticsAugmentation(final FlowAndStatisticsMapList flowAndStats) { + final FlowStatisticsBuilder flowStatisticsBuilder = new FlowStatisticsBuilder(flowAndStats); + final FlowStatisticsDataBuilder flowStatisticsDataBld = new FlowStatisticsDataBuilder(); + flowStatisticsDataBld.setFlowStatistics(flowStatisticsBuilder.build()); + return flowStatisticsDataBld; + } + + public static void deleteAllKnownFlows(final DeviceContext deviceContext) { if (deviceContext.getDeviceState().deviceSynchronized()) { - for (Map.Entry registryEntry : deviceContext.getDeviceFlowRegistry().getAllFlowDescriptors().entrySet()) { - FlowDescriptor flowDescriptor = registryEntry.getValue(); - - FlowId flowId = flowDescriptor.getFlowId(); - FlowKey flowKey = new FlowKey(flowId); - final InstanceIdentifier flowInstanceIdentifier = nodeIdent - .augmentation(FlowCapableNode.class) - .child(Table.class, flowDescriptor.getTableKey()) - .child(Flow.class, flowKey); - - LOG.trace("Deleting flow with id {}", flowInstanceIdentifier); - deviceContext.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, flowInstanceIdentifier); + InstanceIdentifier flowCapableNodePath = assembleFlowCapableNodeInstanceIdentifier(deviceContext); + final Short numOfTablesOnDevice = deviceContext.getDeviceState().getFeatures().getTables(); + for (short i = 0; i < numOfTablesOnDevice; i++) { + final KeyedInstanceIdentifier iiToTable = flowCapableNodePath.child(Table.class, new TableKey(i)); + final ReadTransaction readTx = deviceContext.getReadTransaction(); + final CheckedFuture, ReadFailedException> tableDataFuture = readTx.read(LogicalDatastoreType.OPERATIONAL, iiToTable); + try { + final Optional tableDataOpt = tableDataFuture.get(); + if (tableDataOpt.isPresent()) { + final Table tableData = tableDataOpt.get(); + final Table table = new TableBuilder(tableData).setFlow(Collections.emptyList()).build(); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToTable, table); + } + } catch (final InterruptedException e) { + LOG.trace("Reading of table features for table wit ID {} was interrputed.", i); + } catch (final ExecutionException e) { + LOG.trace("Reading of table features for table wit ID {} encountered execution exception {}.", i, e); + } } + deviceContext.getDeviceFlowRegistry().removeMarked(); } - deviceContext.getDeviceFlowRegistry().removeMarked(); } - private static void processQueueStatistics(final QueueStatisticsUpdate singleMultipartData, final DeviceContext deviceContext) { - final QueueStatisticsUpdate queueStatisticsUpdate = singleMultipartData; - final InstanceIdentifier nodeIdent = InstanceIdentifier.create(Nodes.class) - .child(Node.class, new NodeKey(queueStatisticsUpdate.getId())); - for (final QueueIdAndStatisticsMap queueStat : queueStatisticsUpdate.getQueueIdAndStatisticsMap()) { - if (queueStat.getQueueId() != null) { - final FlowCapableNodeConnectorQueueStatistics statChild = - new FlowCapableNodeConnectorQueueStatisticsBuilder(queueStat).build(); - final FlowCapableNodeConnectorQueueStatisticsDataBuilder statBuild = - new FlowCapableNodeConnectorQueueStatisticsDataBuilder(); - statBuild.setFlowCapableNodeConnectorQueueStatistics(statChild); - final QueueKey qKey = new QueueKey(queueStat.getQueueId()); - final InstanceIdentifier queueIdent = nodeIdent - .child(NodeConnector.class, new NodeConnectorKey(queueStat.getNodeConnectorId())) - .augmentation(FlowCapableNodeConnector.class) - .child(Queue.class, qKey); - final InstanceIdentifier queueStatIdent = queueIdent.augmentation(FlowCapableNodeConnectorQueueStatisticsData.class); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, queueStatIdent, statBuild.build()); + private static void processQueueStatistics(final Iterable data, final DeviceContext deviceContext) { + // TODO: clean all queues of all node-connectors before writing up-to-date stats + final InstanceIdentifier nodeIdent = deviceContext.getDeviceState().getNodeInstanceIdentifier(); + for (final QueueStatisticsUpdate queueStatisticsUpdate : data) { + for (final QueueIdAndStatisticsMap queueStat : queueStatisticsUpdate.getQueueIdAndStatisticsMap()) { + if (queueStat.getQueueId() != null) { + final FlowCapableNodeConnectorQueueStatistics statChild = + new FlowCapableNodeConnectorQueueStatisticsBuilder(queueStat).build(); + final FlowCapableNodeConnectorQueueStatisticsDataBuilder statBuild = + new FlowCapableNodeConnectorQueueStatisticsDataBuilder(); + statBuild.setFlowCapableNodeConnectorQueueStatistics(statChild); + final QueueKey qKey = new QueueKey(queueStat.getQueueId()); + final InstanceIdentifier queueIdent = nodeIdent + .child(NodeConnector.class, new NodeConnectorKey(queueStat.getNodeConnectorId())) + .augmentation(FlowCapableNodeConnector.class) + .child(Queue.class, qKey); + final QueueBuilder queueBuilder = new QueueBuilder() + .setKey(qKey) + .setQueueId(queueStat.getQueueId()) + // node-connector-id is already contained in parent node and the port-id here is of incompatible format + .addAugmentation(FlowCapableNodeConnectorQueueStatisticsData.class, statBuild.build()); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, queueIdent, queueBuilder.build()); + } } } + deviceContext.submitTransaction(); } - private static void processFlowTableStatistics(final FlowTableStatisticsUpdate singleMultipartData, final DeviceContext deviceContext) { - final FlowTableStatisticsUpdate flowTableStatisticsUpdate = singleMultipartData; - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(flowTableStatisticsUpdate.getId()); + private static void processFlowTableStatistics(final Iterable data, final DeviceContext deviceContext) { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceContext); + for (final FlowTableStatisticsUpdate flowTableStatisticsUpdate : data) { - for (final FlowTableAndStatisticsMap tableStat : flowTableStatisticsUpdate.getFlowTableAndStatisticsMap()) { - final InstanceIdentifier tStatIdent = fNodeIdent.child(Table.class, new TableKey(tableStat.getTableId().getValue())) - .augmentation(FlowTableStatisticsData.class).child(FlowTableStatistics.class); - final FlowTableStatistics stats = new FlowTableStatisticsBuilder(tableStat).build(); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, tStatIdent, stats); + for (final FlowTableAndStatisticsMap tableStat : flowTableStatisticsUpdate.getFlowTableAndStatisticsMap()) { + final InstanceIdentifier tStatIdent = fNodeIdent.child(Table.class, new TableKey(tableStat.getTableId().getValue())) + .augmentation(FlowTableStatisticsData.class).child(FlowTableStatistics.class); + final FlowTableStatistics stats = new FlowTableStatisticsBuilder(tableStat).build(); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, tStatIdent, stats); + } } + deviceContext.submitTransaction(); } - private static void processNodeConnectorStatistics(final NodeConnectorStatisticsUpdate singleMultipartData, final DeviceContext deviceContext) { - final NodeConnectorStatisticsUpdate nodeConnectorStatisticsUpdate = singleMultipartData; - final InstanceIdentifier nodeIdent = InstanceIdentifier.create(Nodes.class) - .child(Node.class, new NodeKey(nodeConnectorStatisticsUpdate.getId())); - for (final NodeConnectorStatisticsAndPortNumberMap nConnectPort : nodeConnectorStatisticsUpdate.getNodeConnectorStatisticsAndPortNumberMap()) { - final FlowCapableNodeConnectorStatistics stats = new FlowCapableNodeConnectorStatisticsBuilder(nConnectPort).build(); - final NodeConnectorKey key = new NodeConnectorKey(nConnectPort.getNodeConnectorId()); - final InstanceIdentifier nodeConnectorIdent = nodeIdent.child(NodeConnector.class, key); - final InstanceIdentifier nodeConnStatIdent = nodeConnectorIdent - .augmentation(FlowCapableNodeConnectorStatisticsData.class); - final InstanceIdentifier flowCapNodeConnStatIdent = - nodeConnStatIdent.child(FlowCapableNodeConnectorStatistics.class); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowCapNodeConnStatIdent, stats); + private static void processNodeConnectorStatistics(final Iterable data, final DeviceContext deviceContext) { + final InstanceIdentifier nodeIdent = deviceContext.getDeviceState().getNodeInstanceIdentifier(); + for (final NodeConnectorStatisticsUpdate nodeConnectorStatisticsUpdate : data) { + for (final NodeConnectorStatisticsAndPortNumberMap nConnectPort : nodeConnectorStatisticsUpdate.getNodeConnectorStatisticsAndPortNumberMap()) { + final FlowCapableNodeConnectorStatistics stats = new FlowCapableNodeConnectorStatisticsBuilder(nConnectPort).build(); + final NodeConnectorKey key = new NodeConnectorKey(nConnectPort.getNodeConnectorId()); + final InstanceIdentifier nodeConnectorIdent = nodeIdent.child(NodeConnector.class, key); + final InstanceIdentifier nodeConnStatIdent = nodeConnectorIdent + .augmentation(FlowCapableNodeConnectorStatisticsData.class); + final InstanceIdentifier flowCapNodeConnStatIdent = + nodeConnStatIdent.child(FlowCapableNodeConnectorStatistics.class); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowCapNodeConnStatIdent, stats); + } } + deviceContext.submitTransaction(); } - private static void processMetersStatistics(final MeterStatisticsUpdated singleMultipartData, final DeviceContext deviceContext) { - final MeterStatisticsUpdated meterStatisticsUpdated = singleMultipartData; - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(meterStatisticsUpdated.getId()); - - - for (final MeterStats mStat : meterStatisticsUpdated.getMeterStats()) { - final MeterStatistics stats = new MeterStatisticsBuilder(mStat).build(); - final MeterId meterId = mStat.getMeterId(); - final InstanceIdentifier meterIdent = fNodeIdent.child(Meter.class, new MeterKey(meterId)); - final InstanceIdentifier nodeMeterStatIdent = meterIdent - .augmentation(NodeMeterStatistics.class); - final InstanceIdentifier msIdent = nodeMeterStatIdent.child(MeterStatistics.class); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, msIdent, stats); + private static void processMetersStatistics(final Iterable data, + final DeviceContext deviceContext) { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceContext); + for (final MeterStatisticsUpdated meterStatisticsUpdated : data) { + for (final MeterStats mStat : meterStatisticsUpdated.getMeterStats()) { + final MeterStatistics stats = new MeterStatisticsBuilder(mStat).build(); + final MeterId meterId = mStat.getMeterId(); + final InstanceIdentifier meterIdent = fNodeIdent.child(Meter.class, new MeterKey(meterId)); + final InstanceIdentifier nodeMeterStatIdent = meterIdent + .augmentation(NodeMeterStatistics.class); + final InstanceIdentifier msIdent = nodeMeterStatIdent.child(MeterStatistics.class); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, msIdent, stats); + } } + deviceContext.submitTransaction(); } private static void deleteAllKnownMeters(final DeviceContext deviceContext, final InstanceIdentifier fNodeIdent) { - for (MeterId meterId : deviceContext.getDeviceMeterRegistry().getAllMeterIds()) { + for (final MeterId meterId : deviceContext.getDeviceMeterRegistry().getAllMeterIds()) { final InstanceIdentifier meterIdent = fNodeIdent.child(Meter.class, new MeterKey(meterId)); deviceContext.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, meterIdent); } deviceContext.getDeviceMeterRegistry().removeMarked(); } - private static void processGroupDescStats(GroupDescStatsUpdated groupDescStatsUpdated, final DeviceContext deviceContext) { - NodeId nodeId = groupDescStatsUpdated.getId(); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(nodeId); + private static void processGroupDescStats(final Iterable data, final DeviceContext deviceContext) { + final InstanceIdentifier fNodeIdent = + deviceContext.getDeviceState().getNodeInstanceIdentifier().augmentation(FlowCapableNode.class); deleteAllKnownGroups(deviceContext, fNodeIdent); - for (GroupDescStats groupDescStats : groupDescStatsUpdated.getGroupDescStats()) { - final GroupId groupId = groupDescStats.getGroupId(); - final GroupBuilder groupBuilder = new GroupBuilder(groupDescStats); - groupBuilder.setKey(new GroupKey(groupId)); - groupBuilder.addAugmentation(NodeGroupStatistics.class, new NodeGroupStatisticsBuilder().build()); + for (final GroupDescStatsUpdated groupDescStatsUpdated : data) { + for (final GroupDescStats groupDescStats : groupDescStatsUpdated.getGroupDescStats()) { + final GroupId groupId = groupDescStats.getGroupId(); - final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupId)); - deviceContext.getDeviceGroupRegistry().store(groupId); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, groupIdent, groupBuilder.build()); + final GroupBuilder groupBuilder = new GroupBuilder(groupDescStats); + groupBuilder.setKey(new GroupKey(groupId)); + groupBuilder.addAugmentation(NodeGroupStatistics.class, new NodeGroupStatisticsBuilder().build()); + + final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupId)); + + deviceContext.getDeviceGroupRegistry().store(groupId); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, groupIdent, groupBuilder.build()); + } } + deviceContext.submitTransaction(); } private static void deleteAllKnownGroups(final DeviceContext deviceContext, final InstanceIdentifier fNodeIdent) { - for (GroupId groupId : deviceContext.getDeviceGroupRegistry().getAllGroupIds()) { + for (final GroupId groupId : deviceContext.getDeviceGroupRegistry().getAllGroupIds()) { final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupId)); deviceContext.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, groupIdent); } deviceContext.getDeviceGroupRegistry().removeMarked(); } - private static void processGroupStatistics(final GroupStatisticsUpdated singleMultipartData, final DeviceContext deviceContext) { - final GroupStatisticsUpdated groupStatistics = singleMultipartData; - NodeId nodeId = groupStatistics.getId(); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(nodeId); - - for (final GroupStats groupStats : groupStatistics.getGroupStats()) { + private static void processGroupStatistics(final Iterable data, final DeviceContext deviceContext) { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceContext); + for (final GroupStatisticsUpdated groupStatistics : data) { + for (final GroupStats groupStats : groupStatistics.getGroupStats()) { - final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupStats.getGroupId())); - final InstanceIdentifier nGroupStatIdent = groupIdent - .augmentation(NodeGroupStatistics.class); + final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupStats.getGroupId())); + final InstanceIdentifier nGroupStatIdent = groupIdent + .augmentation(NodeGroupStatistics.class); - final InstanceIdentifier gsIdent = nGroupStatIdent.child(GroupStatistics.class); - final GroupStatistics stats = new GroupStatisticsBuilder(groupStats).build(); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, gsIdent, stats); + final InstanceIdentifier gsIdent = nGroupStatIdent.child(GroupStatistics.class); + final GroupStatistics stats = new GroupStatisticsBuilder(groupStats).build(); + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, gsIdent, stats); + } } + deviceContext.submitTransaction(); } - private static InstanceIdentifier getFlowCapableNodeInstanceIdentifier(final NodeId nodeId) { - final InstanceIdentifier nodeIdent = InstanceIdentifier - .create(Nodes.class).child(Node.class, new NodeKey(nodeId)); - return nodeIdent.augmentation(FlowCapableNode.class); + private static InstanceIdentifier assembleFlowCapableNodeInstanceIdentifier(final DeviceContext deviceContext) { + return deviceContext.getDeviceState().getNodeInstanceIdentifier().augmentation(FlowCapableNode.class); } }