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=966608079424ad29c84e875d2eda890e1a989e8c;hb=501d4d64c806ad39e90b97def853fa043dda5f30;hp=afe4d0085a704ae165c3c870da2ee33f424c7c2d;hpb=beaf57528af475963dc72aaa66c00f666d3ab7a6;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 afe4d0085a..9666080794 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 @@ -13,18 +13,13 @@ import com.google.common.base.Optional; import com.google.common.collect.Iterables; import com.google.common.util.concurrent.AsyncFunction; import com.google.common.util.concurrent.CheckedFuture; -import com.google.common.util.concurrent.FutureFallback; import com.google.common.util.concurrent.Futures; import com.google.common.util.concurrent.JdkFutureAdapters; import com.google.common.util.concurrent.ListenableFuture; -import java.text.SimpleDateFormat; -import java.util.Collections; -import java.util.Date; -import java.util.List; -import javax.annotation.Nullable; import org.opendaylight.controller.md.sal.binding.api.ReadOnlyTransaction; import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType; import org.opendaylight.controller.md.sal.common.api.data.ReadFailedException; +import org.opendaylight.controller.md.sal.common.api.data.TransactionChainClosedException; import org.opendaylight.openflowplugin.api.openflow.device.DeviceContext; import org.opendaylight.openflowplugin.api.openflow.device.DeviceInfo; import org.opendaylight.openflowplugin.api.openflow.device.DeviceRegistry; @@ -37,7 +32,7 @@ import org.opendaylight.openflowplugin.api.openflow.statistics.ofpspecific.Event 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.ietf.params.xml.ns.yang.ietf.yang.types.rev100924.DateAndTime; +import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.yang.types.rev130715.DateAndTime; 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.FlowCapableStatisticsGatheringStatus; @@ -111,15 +106,21 @@ import org.opendaylight.yangtools.yang.common.RpcResult; import org.slf4j.Logger; import org.slf4j.LoggerFactory; +import javax.annotation.Nullable; +import java.text.SimpleDateFormat; +import java.util.Collections; +import java.util.Date; +import java.util.List; +import java.util.concurrent.ExecutionException; + /** - * Utils for gatherig statistics + * Utils for gathering statistics. */ public final class StatisticsGatheringUtils { private static String DATE_AND_TIME_FORMAT = "yyyy-MM-dd'T'HH:mm:ss.SSSXXX"; private static final Logger LOG = LoggerFactory.getLogger(StatisticsGatheringUtils.class); - private static final SinglePurposeMultipartReplyTranslator MULTIPART_REPLY_TRANSLATOR = new SinglePurposeMultipartReplyTranslator(); private static final String QUEUE2_REQCTX = "QUEUE2REQCTX-"; private StatisticsGatheringUtils() { @@ -127,38 +128,54 @@ public final class StatisticsGatheringUtils { } //TODO: Flow-,Group- and Meter- registry should be not in device context, consider move it in separate class - static ListenableFuture gatherStatistics(final StatisticsGatherer statisticsGatheringService, - final DeviceInfo deviceInfo, - final MultipartType type, - final TxFacade txFacade, - final DeviceRegistry registry, - final Boolean initial) { + static ListenableFuture gatherStatistics( + final StatisticsGatherer statisticsGatheringService, + final DeviceInfo deviceInfo, + final MultipartType type, + final TxFacade txFacade, + final DeviceRegistry registry, + final Boolean initial, + final SinglePurposeMultipartReplyTranslator multipartReplyTranslator) { EventIdentifier wholeProcessEventIdentifier = null; if (MultipartType.OFPMPFLOW.equals(type)) { wholeProcessEventIdentifier = new EventIdentifier(type.toString(), deviceInfo.getNodeId().getValue()); EventsTimeCounter.markStart(wholeProcessEventIdentifier); } - final EventIdentifier ofpQueuToRequestContextEventIdentifier = new EventIdentifier(QUEUE2_REQCTX + type.toString(), deviceInfo.getNodeId().toString()); + final EventIdentifier ofpQueueToRequestContextEventIdentifier + = new EventIdentifier(QUEUE2_REQCTX + type.toString(), deviceInfo.getNodeId().toString()); final ListenableFuture>> statisticsDataInFuture = JdkFutureAdapters.listenInPoolThread(statisticsGatheringService.getStatisticsOfType( - ofpQueuToRequestContextEventIdentifier, type)); - return transformAndStoreStatisticsData(statisticsDataInFuture, deviceInfo, wholeProcessEventIdentifier, type, txFacade, registry, initial); + ofpQueueToRequestContextEventIdentifier, type)); + return transformAndStoreStatisticsData( + statisticsDataInFuture, + deviceInfo, + wholeProcessEventIdentifier, + type, + txFacade, + registry, + initial, + multipartReplyTranslator); } - private static ListenableFuture transformAndStoreStatisticsData(final ListenableFuture>> statisticsDataInFuture, - final DeviceInfo deviceInfo, - final EventIdentifier eventIdentifier, - final MultipartType type, - final TxFacade txFacade, - final DeviceRegistry registry, - final boolean initial) { + private static ListenableFuture transformAndStoreStatisticsData( + final ListenableFuture>> statisticsDataInFuture, + final DeviceInfo deviceInfo, + final EventIdentifier eventIdentifier, + final MultipartType type, + final TxFacade txFacade, + final DeviceRegistry registry, + final boolean initial, + final SinglePurposeMultipartReplyTranslator multipartReplyTranslator) { return Futures.transform(statisticsDataInFuture, new AsyncFunction>, Boolean>() { @Nullable @Override public ListenableFuture apply(final RpcResult> rpcResult) { boolean isMultipartProcessed = Boolean.TRUE; if (rpcResult.isSuccessful()) { - LOG.debug("Stats reply successfully received for node {} of type {}", deviceInfo.getNodeId(), type); + if (LOG.isDebugEnabled()) { + LOG.debug("Stats reply successfully received for node {} of type {}", + deviceInfo.getNodeId(), type); + } // 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 @@ -169,14 +186,14 @@ public final class StatisticsGatheringUtils { try { for (final MultipartReply singleReply : rpcResult.getResult()) { - final List multipartDataList = MULTIPART_REPLY_TRANSLATOR.translate( + final List multipartDataList = multipartReplyTranslator.translate( deviceInfo.getDatapathId(), deviceInfo.getVersion(), singleReply); multipartData = multipartDataList.get(0); allMultipartData = Iterables.concat(allMultipartData, multipartDataList); } - } catch (final Exception e) { - LOG.warn("stats processing of type {} for node {} failed during transfomation step", + } catch (final TransactionChainClosedException e) { + LOG.warn("stats processing of type {} for node {} failed during transformation step", type, deviceInfo.getNodeId(), e); return Futures.immediateFailedFuture(e); } @@ -184,42 +201,81 @@ public final class StatisticsGatheringUtils { try { if (multipartData instanceof GroupStatisticsUpdated) { - processGroupStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + processGroupStatistics( + (Iterable) allMultipartData, + deviceInfo, + txFacade); } else if (multipartData instanceof MeterStatisticsUpdated) { - processMetersStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + processMetersStatistics( + (Iterable) allMultipartData, + deviceInfo, + txFacade); } else if (multipartData instanceof NodeConnectorStatisticsUpdate) { - processNodeConnectorStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + processNodeConnectorStatistics( + (Iterable) allMultipartData, + deviceInfo, + txFacade); } else if (multipartData instanceof FlowTableStatisticsUpdate) { - processFlowTableStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + processFlowTableStatistics( + (Iterable) allMultipartData, + deviceInfo, + txFacade); } else if (multipartData instanceof QueueStatisticsUpdate) { - processQueueStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + processQueueStatistics( + (Iterable) allMultipartData, + deviceInfo, + txFacade); } else if (multipartData instanceof FlowsStatisticsUpdate) { - /* FlowStat Processing is realized by NettyThread only by initPhase, otherwise it is realized + /* FlowStat Processing is realized by NettyThread only by initPhase, + * otherwise it is realized * by MD-SAL thread */ - return processFlowStatistics((Iterable) allMultipartData, deviceInfo, txFacade, registry.getDeviceFlowRegistry(), initial, eventIdentifier); + return processFlowStatistics( + (Iterable) allMultipartData, + deviceInfo, + txFacade, + registry.getDeviceFlowRegistry(), + initial, + eventIdentifier); } else if (multipartData instanceof GroupDescStatsUpdated) { - processGroupDescStats((Iterable) allMultipartData, deviceInfo, txFacade, registry.getDeviceGroupRegistry()); + processGroupDescStats( + (Iterable) allMultipartData, + deviceInfo, + txFacade, + registry.getDeviceGroupRegistry()); } else if (multipartData instanceof MeterConfigStatsUpdated) { - processMeterConfigStatsUpdated((Iterable) allMultipartData, deviceInfo, txFacade, registry.getDeviceMeterRegistry()); + processMeterConfigStatsUpdated( + (Iterable) allMultipartData, + deviceInfo, + txFacade, + registry.getDeviceMeterRegistry()); } else { isMultipartProcessed = Boolean.FALSE; } - } catch (final Exception e) { + } catch (final TransactionChainClosedException e) { LOG.warn("stats processing of type {} for node {} failed during write-to-tx step", type, deviceInfo.getNodeId(), e); return Futures.immediateFailedFuture(e); } - LOG.debug("Stats reply added to transaction for node {} of type {}", deviceInfo.getNodeId(), type); + if (LOG.isDebugEnabled()) { + LOG.debug("Stats reply added to transaction for node {} of type {}", + deviceInfo.getNodeId(), type); + } //TODO : implement experimenter } else { - LOG.debug("Stats reply was empty for node {} of type {}", deviceInfo.getNodeId(), type); + if (LOG.isDebugEnabled()) { + LOG.debug("Stats reply was empty for node {} of type {}", + deviceInfo.getNodeId(), type); + } } } else { - LOG.debug("Stats reply FAILED for node {} of type {}: {}", deviceInfo.getNodeId(), type, rpcResult.getErrors()); + if (LOG.isDebugEnabled()) { + LOG.debug("Stats reply FAILED for node {} of type {}: {}", + deviceInfo.getNodeId(), type, rpcResult.getErrors()); + } isMultipartProcessed = Boolean.FALSE; } return Futures.immediateFuture(isMultipartProcessed); @@ -230,19 +286,24 @@ public final class StatisticsGatheringUtils { private static void processMeterConfigStatsUpdated(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade, - final DeviceMeterRegistry meterRegistry) throws Exception { + final DeviceMeterRegistry meterRegistry) + throws TransactionChainClosedException { final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); deleteAllKnownMeters(meterRegistry, fNodeIdent, txFacade); 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 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()); meterRegistry.store(meterId); - txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, meterInstanceIdentifier, meterBuilder.build()); + txFacade.writeToTransaction( + LogicalDatastoreType.OPERATIONAL, + meterInstanceIdentifier, + meterBuilder.build()); } } txFacade.submitTransaction(); @@ -254,17 +315,14 @@ public final class StatisticsGatheringUtils { final DeviceFlowRegistry flowRegistry, final boolean initial, final EventIdentifier eventIdentifier) { - final ListenableFuture deleteFuture = initial ? Futures.immediateFuture(null) : deleteAllKnownFlows(deviceInfo, - flowRegistry, txFacade); - return Futures.transform(deleteFuture, new Function() { - - @Override - public Boolean apply(final Void input) { - writeFlowStatistics(data, deviceInfo, flowRegistry, txFacade); - txFacade.submitTransaction(); - EventsTimeCounter.markEnd(eventIdentifier); - return Boolean.TRUE; - } + final ListenableFuture deleteFuture + = initial ? Futures.immediateFuture(null) : deleteAllKnownFlows(deviceInfo, flowRegistry, txFacade); + return Futures.transform(deleteFuture, (Function) input -> { + writeFlowStatistics(data, deviceInfo, flowRegistry, txFacade); + txFacade.submitTransaction(); + EventsTimeCounter.markEnd(eventIdentifier); + flowRegistry.processMarks(); + return Boolean.TRUE; }); } @@ -277,30 +335,34 @@ public final class StatisticsGatheringUtils { for (final FlowsStatisticsUpdate flowsStatistics : data) { for (final FlowAndStatisticsMapList flowStat : flowsStatistics.getFlowAndStatisticsMapList()) { final FlowBuilder flowBuilder = new FlowBuilder(flowStat); - flowBuilder.addAugmentation(FlowStatisticsData.class, refineFlowStatisticsAugmentation(flowStat).build()); + flowBuilder.addAugmentation(FlowStatisticsData.class, + refineFlowStatisticsAugmentation(flowStat).build()); final short tableId = flowStat.getTableId(); - final FlowRegistryKey flowRegistryKey = FlowRegistryKeyFactory.create(flowBuilder.build()); - final FlowId flowId = registry.storeIfNecessary(flowRegistryKey, tableId); + final FlowRegistryKey flowRegistryKey = FlowRegistryKeyFactory.create(deviceInfo.getVersion(), flowBuilder.build()); + registry.store(flowRegistryKey); + final FlowId flowId = registry.retrieveDescriptor(flowRegistryKey).getFlowId(); 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); + final InstanceIdentifier flowIdent + = fNodeIdent.child(Table.class, tableKey).child(Flow.class, flowKey); txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowIdent, flowBuilder.build()); } } - } catch (Exception e) { - LOG.warn("Not able to write to transaction: {}", e.getMessage()); + } catch (TransactionChainClosedException e) { + LOG.warn("Not able to write to transaction chain: {}", e.getMessage()); } } /** - * Method extracts flow statistics out of flowAndStatistics model + * Method extracts flow statistics out of flowAndStatistics model. * - * @param flowAndStats + * @param flowAndStats flow statistics map list */ - private static FlowStatisticsDataBuilder refineFlowStatisticsAugmentation(final FlowAndStatisticsMapList flowAndStats) { + private static FlowStatisticsDataBuilder refineFlowStatisticsAugmentation( + final FlowAndStatisticsMapList flowAndStats) { final FlowStatisticsBuilder flowStatisticsBuilder = new FlowStatisticsBuilder(flowAndStats); final FlowStatisticsDataBuilder flowStatisticsDataBld = new FlowStatisticsDataBuilder(); flowStatisticsDataBld.setFlowStatistics(flowStatisticsBuilder.build()); @@ -310,44 +372,68 @@ public final class StatisticsGatheringUtils { public static ListenableFuture deleteAllKnownFlows(final DeviceInfo deviceInfo, final DeviceFlowRegistry registry, final TxFacade txFacade) { - final InstanceIdentifier flowCapableNodePath = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); + final InstanceIdentifier flowCapableNodePath + = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); final ReadOnlyTransaction readTx = txFacade.getReadTransaction(); final CheckedFuture, ReadFailedException> flowCapableNodeFuture = readTx.read( LogicalDatastoreType.OPERATIONAL, flowCapableNodePath); /* we wish to close readTx for fallBack */ - Futures.withFallback(flowCapableNodeFuture, new FutureFallback>() { - - @Override - public ListenableFuture> create(final Throwable t) throws Exception { - readTx.close(); - return Futures.immediateFailedFuture(t); - } + Futures.withFallback(flowCapableNodeFuture, t -> { + readTx.close(); + return Futures.immediateFailedFuture(t); }); /* * we have to read actual tables with all information before we set empty Flow list, merge is expensive and * not applicable for lists */ - return Futures.transform(flowCapableNodeFuture, new AsyncFunction, Void>() { - - @Override - public ListenableFuture apply(final Optional flowCapNodeOpt) throws Exception { - if (flowCapNodeOpt.isPresent()) { - for (final Table tableData : flowCapNodeOpt.get().getTable()) { - final Table table = new TableBuilder(tableData).setFlow(Collections.emptyList()).build(); - final InstanceIdentifier iiToTable = flowCapableNodePath.child(Table.class, tableData.getKey()); - txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToTable, table); + return Futures.transform( + flowCapableNodeFuture, (AsyncFunction, Void>) flowCapNodeOpt -> { + if (flowCapNodeOpt.isPresent()) { + for (final Table tableData : flowCapNodeOpt.get().getTable()) { + final Table table = new TableBuilder(tableData).setFlow(Collections.emptyList()).build(); + final InstanceIdentifier
iiToTable + = flowCapableNodePath.child(Table.class, tableData.getKey()); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToTable, table); + } } + readTx.close(); + return Futures.immediateFuture(null); + }); + } + + public static Optional deleteAllKnownFlows(final DeviceInfo deviceInfo, + final TxFacade txFacade) { + final InstanceIdentifier flowCapableNodePath + = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); + final ReadOnlyTransaction readTx = txFacade.getReadTransaction(); + final CheckedFuture, ReadFailedException> flowCapableNodeFuture = readTx.read( + LogicalDatastoreType.OPERATIONAL, flowCapableNodePath); + + try { + Optional fcNodeOpt = flowCapableNodeFuture.get(); + if ( fcNodeOpt != null && fcNodeOpt.isPresent()){ + for (final Table tableData : flowCapableNodeFuture.get().get().getTable()) { + final Table table = new TableBuilder(tableData).setFlow(Collections.emptyList()).build(); + final InstanceIdentifier
iiToTable = flowCapableNodePath.child(Table.class, tableData.getKey()); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToTable, table); } - registry.removeMarked(); + return fcNodeOpt; + } + } catch (InterruptedException|ExecutionException e) { + LOG.error("Failed to read current OpenFlow node {] operational data", deviceInfo.getNodeId()); + } finally { + if (readTx != null){ readTx.close(); - return Futures.immediateFuture(null); } - - }); + } + return Optional.absent(); } - private static void processQueueStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + private static void processQueueStatistics( + final Iterable data, + final DeviceInfo deviceInfo, + final TxFacade txFacade) throws TransactionChainClosedException { // TODO: clean all queues of all node-connectors before writing up-to-date stats final InstanceIdentifier nodeIdent = deviceInfo.getNodeInstanceIdentifier(); for (final QueueStatisticsUpdate queueStatisticsUpdate : data) { @@ -366,7 +452,8 @@ public final class StatisticsGatheringUtils { 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 + // node-connector-id is already contained in parent node + // and the port-id here is of incompatible format .addAugmentation(FlowCapableNodeConnectorQueueStatisticsData.class, statBuild.build()); txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, queueIdent, queueBuilder.build()); } @@ -375,12 +462,16 @@ public final class StatisticsGatheringUtils { txFacade.submitTransaction(); } - private static void processFlowTableStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + private static void processFlowTableStatistics( + final Iterable data, + final DeviceInfo deviceInfo, + final TxFacade txFacade) throws TransactionChainClosedException { final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); for (final FlowTableStatisticsUpdate flowTableStatisticsUpdate : data) { for (final FlowTableAndStatisticsMap tableStat : flowTableStatisticsUpdate.getFlowTableAndStatisticsMap()) { - final InstanceIdentifier tStatIdent = fNodeIdent.child(Table.class, new TableKey(tableStat.getTableId().getValue())) + 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(); txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, tStatIdent, stats); @@ -389,12 +480,17 @@ public final class StatisticsGatheringUtils { txFacade.submitTransaction(); } - private static void processNodeConnectorStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + private static void processNodeConnectorStatistics( + final Iterable data, + final DeviceInfo deviceInfo, + final TxFacade txFacade) throws TransactionChainClosedException { final InstanceIdentifier nodeIdent = deviceInfo.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()); + for (final NodeConnectorStatisticsAndPortNumberMap nodeConnectPort : + nodeConnectorStatisticsUpdate.getNodeConnectorStatisticsAndPortNumberMap()) { + final FlowCapableNodeConnectorStatistics stats + = new FlowCapableNodeConnectorStatisticsBuilder(nodeConnectPort).build(); + final NodeConnectorKey key = new NodeConnectorKey(nodeConnectPort.getNodeConnectorId()); final InstanceIdentifier nodeConnectorIdent = nodeIdent.child(NodeConnector.class, key); final InstanceIdentifier nodeConnStatIdent = nodeConnectorIdent .augmentation(FlowCapableNodeConnectorStatisticsData.class); @@ -408,12 +504,12 @@ public final class StatisticsGatheringUtils { private static void processMetersStatistics(final Iterable data, final DeviceInfo deviceInfo, - final TxFacade txFacade) throws Exception { + final TxFacade txFacade) throws TransactionChainClosedException { final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); for (final MeterStatisticsUpdated meterStatisticsUpdated : data) { - for (final MeterStats mStat : meterStatisticsUpdated.getMeterStats()) { - final MeterStatistics stats = new MeterStatisticsBuilder(mStat).build(); - final MeterId meterId = mStat.getMeterId(); + for (final MeterStats meterStats : meterStatisticsUpdated.getMeterStats()) { + final MeterStatistics stats = new MeterStatisticsBuilder(meterStats).build(); + final MeterId meterId = meterStats.getMeterId(); final InstanceIdentifier meterIdent = fNodeIdent.child(Meter.class, new MeterKey(meterId)); final InstanceIdentifier nodeMeterStatIdent = meterIdent .augmentation(NodeMeterStatistics.class); @@ -424,15 +520,22 @@ public final class StatisticsGatheringUtils { txFacade.submitTransaction(); } - private static void deleteAllKnownMeters(final DeviceMeterRegistry meterRegistry, final InstanceIdentifier fNodeIdent, final TxFacade txFacade) throws Exception { - for (final MeterId meterId : meterRegistry.getAllMeterIds()) { - final InstanceIdentifier meterIdent = fNodeIdent.child(Meter.class, new MeterKey(meterId)); + private static void deleteAllKnownMeters( + final DeviceMeterRegistry meterRegistry, + final InstanceIdentifier flowNodeIdent, + final TxFacade txFacade) throws TransactionChainClosedException { + meterRegistry.forEach(meterId -> { + final InstanceIdentifier meterIdent = flowNodeIdent.child(Meter.class, new MeterKey(meterId)); txFacade.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, meterIdent); - } - meterRegistry.removeMarked(); + }); + meterRegistry.processMarks(); } - private static void processGroupDescStats(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade, final DeviceGroupRegistry groupRegistry) throws Exception { + private static void processGroupDescStats( + final Iterable data, + final DeviceInfo deviceInfo, + final TxFacade txFacade, + final DeviceGroupRegistry groupRegistry) throws TransactionChainClosedException { final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); deleteAllKnownGroups(txFacade, fNodeIdent, groupRegistry); @@ -453,20 +556,27 @@ public final class StatisticsGatheringUtils { txFacade.submitTransaction(); } - private static void deleteAllKnownGroups(final TxFacade txFacade, final InstanceIdentifier fNodeIdent, final DeviceGroupRegistry groupRegistry) throws Exception { - for (final GroupId groupId : groupRegistry.getAllGroupIds()) { - final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupId)); + private static void deleteAllKnownGroups( + final TxFacade txFacade, + final InstanceIdentifier flowNodeIdent, + final DeviceGroupRegistry groupRegistry) throws TransactionChainClosedException { + groupRegistry.forEach(groupId -> { + final InstanceIdentifier groupIdent = flowNodeIdent.child(Group.class, new GroupKey(groupId)); txFacade.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, groupIdent); - } - groupRegistry.removeMarked(); + }); + groupRegistry.processMarks(); } - private static void processGroupStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + private static void processGroupStatistics( + final Iterable data, + final DeviceInfo deviceInfo, + final TxFacade txFacade) throws TransactionChainClosedException { final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); for (final GroupStatisticsUpdated groupStatistics : data) { for (final GroupStats groupStats : groupStatistics.getGroupStats()) { - final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupStats.getGroupId())); + final InstanceIdentifier groupIdent + = fNodeIdent.child(Group.class, new GroupKey(groupStats.getGroupId())); final InstanceIdentifier nGroupStatIdent = groupIdent .augmentation(NodeGroupStatistics.class); @@ -478,12 +588,13 @@ public final class StatisticsGatheringUtils { txFacade.submitTransaction(); } - private static InstanceIdentifier assembleFlowCapableNodeInstanceIdentifier(final DeviceInfo deviceInfo) { + private static InstanceIdentifier assembleFlowCapableNodeInstanceIdentifier( + final DeviceInfo deviceInfo) { return deviceInfo.getNodeInstanceIdentifier().augmentation(FlowCapableNode.class); } /** - * Writes snapshot gathering start timestamp + cleans end mark + * Writes snapshot gathering start timestamp + cleans end mark. * * @param deviceContext txManager + node path keeper */ @@ -500,15 +611,16 @@ public final class StatisticsGatheringUtils { .build(); try { deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, statusPath, gatheringStatus); - } catch (final Exception e) { - LOG.warn("Can't write to transaction: {}", e); + } catch (final TransactionChainClosedException e) { + LOG.warn("Can't write to transaction, transaction chain probably closed."); + LOG.trace("Write to transaction exception: ", e); } deviceContext.submitTransaction(); } /** - * Writes snapshot gathering end timestamp + outcome + * Writes snapshot gathering end timestamp + outcome. * * @param deviceContext txManager + node path keeper * @param succeeded outcome of currently finished gathering @@ -525,8 +637,9 @@ public final class StatisticsGatheringUtils { .build(); try { deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, statusEndPath, gatheringStatus); - } catch (Exception e) { - LOG.warn("Can't write to transaction: {}", e); + } catch (TransactionChainClosedException e) { + LOG.warn("Can't write to transaction, transaction chain probably closed."); + LOG.trace("Write to transaction exception: ", e); } deviceContext.submitTransaction();