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=afe4d0085a704ae165c3c870da2ee33f424c7c2d;hb=e1ef8b31e7f6c908e06d947bd10f51e498378ab5;hp=9c9a215afb415c9f8314c67c728c45c3df9d03bb;hpb=caf2edd4861e96db47027a8ef656b32656a862e7;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 9c9a215afb..afe4d0085a 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 @@ -8,48 +8,65 @@ package org.opendaylight.openflowplugin.impl.statistics; -import java.util.concurrent.ExecutionException; +import com.google.common.base.Function; import com.google.common.base.Optional; -import com.google.common.util.concurrent.CheckedFuture; -import org.opendaylight.controller.md.sal.common.api.data.ReadFailedException; -import org.opendaylight.controller.md.sal.binding.api.ReadTransaction; -import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.tables.TableBuilder; import com.google.common.collect.Iterables; -import java.util.Collections; -import com.google.common.base.Function; +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.openflowplugin.api.openflow.device.DeviceContext; +import org.opendaylight.openflowplugin.api.openflow.device.DeviceInfo; +import org.opendaylight.openflowplugin.api.openflow.device.DeviceRegistry; +import org.opendaylight.openflowplugin.api.openflow.device.TxFacade; import org.opendaylight.openflowplugin.api.openflow.registry.flow.DeviceFlowRegistry; -import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowDescriptor; -import org.opendaylight.openflowplugin.api.openflow.registry.flow.FlowHash; -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.registry.group.DeviceGroupRegistry; +import org.opendaylight.openflowplugin.api.openflow.registry.meter.DeviceMeterRegistry; +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.ietf.params.xml.ns.yang.ietf.yang.types.rev100924.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; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowCapableStatisticsGatheringStatusBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowId; import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.meters.Meter; 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.snapshot.gathering.status.grouping.SnapshotGatheringStatusEnd; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.snapshot.gathering.status.grouping.SnapshotGatheringStatusEndBuilder; +import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.snapshot.gathering.status.grouping.SnapshotGatheringStatusStartBuilder; 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; @@ -63,12 +80,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; @@ -93,167 +107,250 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216. import org.opendaylight.yang.gen.v1.urn.opendaylight.queue.statistics.rev131216.queue.id.and.statistics.map.QueueIdAndStatisticsMap; import org.opendaylight.yangtools.yang.binding.DataObject; import org.opendaylight.yangtools.yang.binding.InstanceIdentifier; -import org.opendaylight.yangtools.yang.binding.KeyedInstanceIdentifier; import org.opendaylight.yangtools.yang.common.RpcResult; import org.slf4j.Logger; import org.slf4j.LoggerFactory; /** - * Created by Martin Bobak <mbobak@cisco.com> on 2.4.2015. + * Utils for gatherig 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() { 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, - 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 + //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) { + 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 ListenableFuture>> statisticsDataInFuture = - JdkFutureAdapters.listenInPoolThread(statisticsGatheringService.getStatisticsOfType(type)); - return transformAndStoreStatisticsData(statisticsDataInFuture, deviceContext); + JdkFutureAdapters.listenInPoolThread(statisticsGatheringService.getStatisticsOfType( + ofpQueuToRequestContextEventIdentifier, type)); + return transformAndStoreStatisticsData(statisticsDataInFuture, deviceInfo, wholeProcessEventIdentifier, type, txFacade, registry, initial); } private static ListenableFuture transformAndStoreStatisticsData(final ListenableFuture>> statisticsDataInFuture, - final DeviceContext deviceContext) { - return Futures.transform(statisticsDataInFuture, new Function>, Boolean>() { + final DeviceInfo deviceInfo, + final EventIdentifier eventIdentifier, + final MultipartType type, + final TxFacade txFacade, + final DeviceRegistry registry, + final boolean initial) { + return Futures.transform(statisticsDataInFuture, new AsyncFunction>, Boolean>() { @Nullable @Override - public Boolean apply(final RpcResult> rpcResult) { + public ListenableFuture apply(final RpcResult> rpcResult) { + boolean isMultipartProcessed = Boolean.TRUE; if (rpcResult.isSuccessful()) { - boolean isMultipartProcessed = Boolean.TRUE; - 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); - } + LOG.debug("Stats reply successfully received for node {} of type {}", deviceInfo.getNodeId(), type); - if (deviceContext.getDeviceState().isValid()) { - deviceContext.startGatheringOperationsToOneTransaction(); - } + // 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; - 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); - } else if (multipartData instanceof GroupDescStatsUpdated) { - processGroupDescStats((Iterable) allMultipartData, deviceContext); - } else if (multipartData instanceof MeterConfigStatsUpdated) { - processMeterConfigStatsUpdated((Iterable) allMultipartData, deviceContext); + + try { + for (final MultipartReply singleReply : rpcResult.getResult()) { + final List multipartDataList = MULTIPART_REPLY_TRANSLATOR.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", + type, deviceInfo.getNodeId(), e); + return Futures.immediateFailedFuture(e); + } + + + try { + if (multipartData instanceof GroupStatisticsUpdated) { + processGroupStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + } else if (multipartData instanceof MeterStatisticsUpdated) { + processMetersStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + } else if (multipartData instanceof NodeConnectorStatisticsUpdate) { + processNodeConnectorStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + } else if (multipartData instanceof FlowTableStatisticsUpdate) { + processFlowTableStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + } else if (multipartData instanceof QueueStatisticsUpdate) { + processQueueStatistics((Iterable) allMultipartData, deviceInfo, txFacade); + } else if (multipartData instanceof FlowsStatisticsUpdate) { + /* 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); + + } else if (multipartData instanceof GroupDescStatsUpdated) { + processGroupDescStats((Iterable) allMultipartData, deviceInfo, txFacade, registry.getDeviceGroupRegistry()); + } else if (multipartData instanceof MeterConfigStatsUpdated) { + processMeterConfigStatsUpdated((Iterable) allMultipartData, deviceInfo, txFacade, registry.getDeviceMeterRegistry()); + } else { + isMultipartProcessed = Boolean.FALSE; + } + } catch (final Exception 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); + + //TODO : implement experimenter } else { - isMultipartProcessed = Boolean.FALSE; + LOG.debug("Stats reply was empty for node {} of type {}", deviceInfo.getNodeId(), type); } - //TODO : implement experimenter - if (deviceContext.getDeviceState().isValid()) { - deviceContext.commitOperationsGatheredInOneTransaction(); - } - return isMultipartProcessed; + } else { + LOG.debug("Stats reply FAILED for node {} of type {}: {}", deviceInfo.getNodeId(), type, rpcResult.getErrors()); + isMultipartProcessed = Boolean.FALSE; } - return Boolean.FALSE; + return Futures.immediateFuture(isMultipartProcessed); } }); } - private static void processMeterConfigStatsUpdated(final Iterable data, final DeviceContext deviceContext) { + private static void processMeterConfigStatsUpdated(final Iterable data, + final DeviceInfo deviceInfo, + final TxFacade txFacade, + final DeviceMeterRegistry meterRegistry) throws Exception { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); + deleteAllKnownMeters(meterRegistry, fNodeIdent, txFacade); for (final MeterConfigStatsUpdated meterConfigStatsUpdated : data) { - NodeId nodeId = meterConfigStatsUpdated.getId(); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(nodeId); - for (MeterConfigStats meterConfigStats : meterConfigStatsUpdated.getMeterConfigStats()) { + 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()); + meterRegistry.store(meterId); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, meterInstanceIdentifier, meterBuilder.build()); } } + txFacade.submitTransaction(); } - private static void processFlowStatistics(final Iterable data, final DeviceContext deviceContext) { - boolean isFirstLoop = true; - for (final FlowsStatisticsUpdate flowsStatistics : data) { - if (isFirstLoop) { - final InstanceIdentifier nodeIdent = InstanceIdentifier.create(Nodes.class) - .child(Node.class, new NodeKey(flowsStatistics.getId())); - deleteAllKnownFlows(deviceContext, nodeIdent); - isFirstLoop = false; + private static ListenableFuture processFlowStatistics(final Iterable data, + final DeviceInfo deviceInfo, + final TxFacade txFacade, + 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; } - for (final FlowAndStatisticsMapList flowStat : flowsStatistics.getFlowAndStatisticsMapList()) { - final FlowBuilder flowBuilder = new FlowBuilder(flowStat); - FlowId flowId = null; - FlowHash flowHash = FlowHashFactory.create(flowBuilder.build(), deviceContext.getPrimaryConnectionContext().getFeatures().getVersion()); - short tableId = flowStat.getTableId(); - final DeviceFlowRegistry deviceFlowRegistry = deviceContext.getDeviceFlowRegistry(); - FlowDescriptor flowDescriptor; - flowDescriptor = deviceFlowRegistry.retrieveIdForFlow(flowHash); - if (null != flowDescriptor) { - flowId = flowDescriptor.getFlowId(); - } else { - LOG.trace("Flow descriptor for flow hash {} wasn't found.", flowHash.hashCode()); - flowId = FlowUtil.createAlienFlowId(tableId); - flowDescriptor = FlowDescriptorFactory.create(tableId, flowId); - deviceFlowRegistry.store(flowHash, flowDescriptor); + }); + } + + public static void writeFlowStatistics(final Iterable data, + final DeviceInfo deviceInfo, + final DeviceFlowRegistry registry, + final TxFacade txFacade) { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); + try { + 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 = registry.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); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowIdent, flowBuilder.build()); } - FlowKey flowKey = new FlowKey(flowId); - flowBuilder.setKey(flowKey); - final TableKey tableKey = new TableKey(tableId); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(flowsStatistics.getId()); - final InstanceIdentifier flowIdent = fNodeIdent.child(Table.class, tableKey).child(Flow.class, flowKey); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowIdent, flowBuilder.build()); } + } catch (Exception e) { + LOG.warn("Not able to write to transaction: {}", e.getMessage()); } } - private static void deleteAllKnownFlows(final DeviceContext deviceContext, final InstanceIdentifier nodeIdent) { - if (deviceContext.getDeviceState().deviceSynchronized()) { - final Short numOfTablesOnDevice = deviceContext.getDeviceState().getFeatures().getTables(); - for (short i=0; i iiToTable - = nodeIdent.augmentation(FlowCapableNode.class).child( Table.class, new TableKey(i) ); - final ReadTransaction readTx = deviceContext.getReadTransaction(); - CheckedFuture, ReadFailedException> tableDataFuture = readTx.read(LogicalDatastoreType.OPERATIONAL, iiToTable); - try { - Optional tableDataOpt = tableDataFuture.get(); - if (tableDataOpt.isPresent()) { - final Table tableData = tableDataOpt.get(); + /** + * 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 ListenableFuture deleteAllKnownFlows(final DeviceInfo deviceInfo, + final DeviceFlowRegistry registry, + final TxFacade txFacade) { + 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); + } + }); + /* + * 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(); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToTable, table); + final InstanceIdentifier
iiToTable = flowCapableNodePath.child(Table.class, tableData.getKey()); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, iiToTable, table); } - } catch (InterruptedException e) { - LOG.trace("Reading of table features for table wit ID {} was interrputed.",i); - } catch (ExecutionException e) { - LOG.trace("Reading of table features for table wit ID {} encountered execution exception {}.",i,e); } + registry.removeMarked(); + readTx.close(); + return Futures.immediateFuture(null); } - } + + }); } - private static void processQueueStatistics(final Iterable data, final DeviceContext deviceContext) { + private static void processQueueStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + // TODO: clean all queues of all node-connectors before writing up-to-date stats + final InstanceIdentifier nodeIdent = deviceInfo.getNodeInstanceIdentifier(); for (final QueueStatisticsUpdate queueStatisticsUpdate : data) { - 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 = @@ -266,30 +363,35 @@ public final class StatisticsGatheringUtils { .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()); + 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()); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, queueIdent, queueBuilder.build()); } } } + txFacade.submitTransaction(); } - private static void processFlowTableStatistics(final Iterable data, final DeviceContext deviceContext) { - for(final FlowTableStatisticsUpdate flowTableStatisticsUpdate : data) { - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(flowTableStatisticsUpdate.getId()); - + private static void processFlowTableStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + 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())) .augmentation(FlowTableStatisticsData.class).child(FlowTableStatistics.class); final FlowTableStatistics stats = new FlowTableStatisticsBuilder(tableStat).build(); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, tStatIdent, stats); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, tStatIdent, stats); } } + txFacade.submitTransaction(); } - private static void processNodeConnectorStatistics(final Iterable data, final DeviceContext deviceContext) { + private static void processNodeConnectorStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + final InstanceIdentifier nodeIdent = deviceInfo.getNodeInstanceIdentifier(); for (final NodeConnectorStatisticsUpdate nodeConnectorStatisticsUpdate : data) { - 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()); @@ -298,20 +400,17 @@ public final class StatisticsGatheringUtils { .augmentation(FlowCapableNodeConnectorStatisticsData.class); final InstanceIdentifier flowCapNodeConnStatIdent = nodeConnStatIdent.child(FlowCapableNodeConnectorStatistics.class); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowCapNodeConnStatIdent, stats); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, flowCapNodeConnStatIdent, stats); } } + txFacade.submitTransaction(); } private static void processMetersStatistics(final Iterable data, - final DeviceContext deviceContext) { - boolean isFirstLoop = true; - for (MeterStatisticsUpdated meterStatisticsUpdated : data) { - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(meterStatisticsUpdated.getId()); - if (isFirstLoop) { - deleteAllKnownMeters(deviceContext, fNodeIdent); - isFirstLoop = false; - } + final DeviceInfo deviceInfo, + final TxFacade txFacade) throws Exception { + 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(); @@ -319,73 +418,117 @@ public final class StatisticsGatheringUtils { final InstanceIdentifier nodeMeterStatIdent = meterIdent .augmentation(NodeMeterStatistics.class); final InstanceIdentifier msIdent = nodeMeterStatIdent.child(MeterStatistics.class); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, msIdent, stats); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, msIdent, stats); } } + txFacade.submitTransaction(); } - private static void deleteAllKnownMeters(final DeviceContext deviceContext, final InstanceIdentifier fNodeIdent) { - for (MeterId meterId : deviceContext.getDeviceMeterRegistry().getAllMeterIds()) { + 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)); - deviceContext.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, meterIdent); + txFacade.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, meterIdent); } - deviceContext.getDeviceMeterRegistry().removeMarked(); + meterRegistry.removeMarked(); } - private static void processGroupDescStats(final Iterable data, final DeviceContext deviceContext) { - for ( GroupDescStatsUpdated groupDescStatsUpdated : data) { - NodeId nodeId = groupDescStatsUpdated.getId(); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(nodeId); - - for (GroupDescStats groupDescStats : groupDescStatsUpdated.getGroupDescStats()) { + private static void processGroupDescStats(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade, final DeviceGroupRegistry groupRegistry) throws Exception { + final InstanceIdentifier fNodeIdent = assembleFlowCapableNodeInstanceIdentifier(deviceInfo); + deleteAllKnownGroups(txFacade, fNodeIdent, groupRegistry); + + for (final GroupDescStatsUpdated groupDescStatsUpdated : data) { + for (final 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()); - + final InstanceIdentifier groupIdent = fNodeIdent.child(Group.class, new GroupKey(groupId)); - - deviceContext.getDeviceGroupRegistry().store(groupId); - deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, groupIdent, groupBuilder.build()); + + groupRegistry.store(groupId); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, groupIdent, groupBuilder.build()); } } + txFacade.submitTransaction(); } - private static void deleteAllKnownGroups(final DeviceContext deviceContext, final InstanceIdentifier fNodeIdent) { - for (GroupId groupId : deviceContext.getDeviceGroupRegistry().getAllGroupIds()) { + 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)); - deviceContext.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, groupIdent); + txFacade.addDeleteToTxChain(LogicalDatastoreType.OPERATIONAL, groupIdent); } - deviceContext.getDeviceGroupRegistry().removeMarked(); + groupRegistry.removeMarked(); } - private static void processGroupStatistics(final Iterable data, final DeviceContext deviceContext) { - boolean isFirstLoop = true; - for (GroupStatisticsUpdated groupStatistics : data) { - NodeId nodeId = groupStatistics.getId(); - final InstanceIdentifier fNodeIdent = getFlowCapableNodeInstanceIdentifier(nodeId); - if (isFirstLoop) { - deleteAllKnownGroups(deviceContext, fNodeIdent); - isFirstLoop = false; - } - + private static void processGroupStatistics(final Iterable data, final DeviceInfo deviceInfo, final TxFacade txFacade) throws Exception { + 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 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); + txFacade.writeToTransaction(LogicalDatastoreType.OPERATIONAL, gsIdent, stats); } } + txFacade.submitTransaction(); + } + + private static InstanceIdentifier assembleFlowCapableNodeInstanceIdentifier(final DeviceInfo deviceInfo) { + return deviceInfo.getNodeInstanceIdentifier().augmentation(FlowCapableNode.class); + } + + /** + * Writes snapshot gathering start timestamp + cleans end mark + * + * @param deviceContext txManager + node path keeper + */ + static void markDeviceStateSnapshotStart(final DeviceContext deviceContext) { + final InstanceIdentifier statusPath = deviceContext.getDeviceInfo() + .getNodeInstanceIdentifier().augmentation(FlowCapableStatisticsGatheringStatus.class); + + final SimpleDateFormat simpleDateFormat = new SimpleDateFormat(DATE_AND_TIME_FORMAT); + final FlowCapableStatisticsGatheringStatus gatheringStatus = new FlowCapableStatisticsGatheringStatusBuilder() + .setSnapshotGatheringStatusStart(new SnapshotGatheringStatusStartBuilder() + .setBegin(new DateAndTime(simpleDateFormat.format(new Date()))) + .build()) + .setSnapshotGatheringStatusEnd(null) // TODO: reconsider if really need to clean end mark here + .build(); + try { + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, statusPath, gatheringStatus); + } catch (final Exception e) { + LOG.warn("Can't write to transaction: {}", e); + } + + 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); + /** + * Writes snapshot gathering end timestamp + outcome + * + * @param deviceContext txManager + node path keeper + * @param succeeded outcome of currently finished gathering + */ + static void markDeviceStateSnapshotEnd(final DeviceContext deviceContext, final boolean succeeded) { + final InstanceIdentifier statusEndPath = deviceContext.getDeviceInfo() + .getNodeInstanceIdentifier().augmentation(FlowCapableStatisticsGatheringStatus.class) + .child(SnapshotGatheringStatusEnd.class); + + final SimpleDateFormat simpleDateFormat = new SimpleDateFormat(DATE_AND_TIME_FORMAT); + final SnapshotGatheringStatusEnd gatheringStatus = new SnapshotGatheringStatusEndBuilder() + .setEnd(new DateAndTime(simpleDateFormat.format(new Date()))) + .setSucceeded(succeeded) + .build(); + try { + deviceContext.writeToTransaction(LogicalDatastoreType.OPERATIONAL, statusEndPath, gatheringStatus); + } catch (Exception e) { + LOG.warn("Can't write to transaction: {}", e); + } + + deviceContext.submitTransaction(); } }