Merge "Added JSON and XML payloads tabs with RFC 8040 URL"
[openflowplugin.git] / applications / forwardingrules-manager / src / main / java / org / opendaylight / openflowplugin / applications / frm / impl / FlowForwarder.java
index b9ac9d3d15c5c3fd165c052d267bba8c37171dee..5c9600f34ce706d9505393cbe63a4157b0d02638 100644 (file)
@@ -1,4 +1,4 @@
-/**
+/*
  * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
@@ -10,24 +10,26 @@ package org.opendaylight.openflowplugin.applications.frm.impl;
 import static org.opendaylight.openflowplugin.applications.frm.util.FrmUtil.buildGroupInstanceIdentifier;
 import static org.opendaylight.openflowplugin.applications.frm.util.FrmUtil.getActiveBundle;
 import static org.opendaylight.openflowplugin.applications.frm.util.FrmUtil.getFlowId;
-import static org.opendaylight.openflowplugin.applications.frm.util.FrmUtil.getNodeIdFromNodeIdentifier;
+import static org.opendaylight.openflowplugin.applications.frm.util.FrmUtil.getNodeIdValueFromNodeIdentifier;
 import static org.opendaylight.openflowplugin.applications.frm.util.FrmUtil.isFlowDependentOnGroup;
 import static org.opendaylight.openflowplugin.applications.frm.util.FrmUtil.isGroupExistsOnDevice;
 
-import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
+import com.google.common.util.concurrent.FluentFuture;
 import com.google.common.util.concurrent.FutureCallback;
 import com.google.common.util.concurrent.Futures;
 import com.google.common.util.concurrent.ListenableFuture;
 import com.google.common.util.concurrent.MoreExecutors;
 import com.google.common.util.concurrent.SettableFuture;
+import java.util.Optional;
 import java.util.concurrent.ExecutionException;
 import java.util.concurrent.Future;
-import org.opendaylight.controller.md.sal.binding.api.DataBroker;
-import org.opendaylight.controller.md.sal.binding.api.DataTreeIdentifier;
-import org.opendaylight.controller.md.sal.binding.api.WriteTransaction;
-import org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType;
-import org.opendaylight.infrautils.utils.concurrent.JdkFutures;
+import org.opendaylight.infrautils.utils.concurrent.LoggingFutures;
+import org.opendaylight.mdsal.binding.api.DataBroker;
+import org.opendaylight.mdsal.binding.api.DataTreeIdentifier;
+import org.opendaylight.mdsal.binding.api.ReadTransaction;
+import org.opendaylight.mdsal.binding.api.WriteTransaction;
+import org.opendaylight.mdsal.common.api.LogicalDatastoreType;
 import org.opendaylight.openflowplugin.applications.frm.ForwardingRulesManager;
 import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.inet.types.rev130715.Uri;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.flow.inventory.rev130819.FlowCapableNode;
@@ -55,7 +57,6 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.group.service.rev130918.Add
 import org.opendaylight.yang.gen.v1.urn.opendaylight.group.service.rev130918.AddGroupOutput;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.GroupRef;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.group.types.rev131018.groups.Group;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeId;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.NodeRef;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.Nodes;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.inventory.rev130819.nodes.Node;
@@ -65,15 +66,16 @@ import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
 import org.opendaylight.yangtools.yang.common.RpcError;
 import org.opendaylight.yangtools.yang.common.RpcResult;
 import org.opendaylight.yangtools.yang.common.RpcResultBuilder;
+import org.opendaylight.yangtools.yang.common.Uint32;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
  * FlowForwarder It implements
- * {@link org.opendaylight.controller.md.sal.binding.api.DataTreeChangeListener}
+ * {@link org.opendaylight.mdsal.binding.api.DataTreeChangeListener}
  * for WildCardedPath to {@link Flow} and ForwardingRulesCommiter interface for
  * methods: add, update and remove {@link Flow} processing for
- * {@link org.opendaylight.controller.md.sal.binding.api.DataTreeModification}.
+ * {@link org.opendaylight.mdsal.binding.api.DataTreeModification}.
  */
 public class FlowForwarder extends AbstractListeningCommiter<Flow> {
 
@@ -82,17 +84,15 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     private static final String GROUP_EXISTS_IN_DEVICE_ERROR = "GROUPEXISTS";
 
     private ListenerRegistration<FlowForwarder> listenerRegistration;
-    private final BundleFlowForwarder bundleFlowForwarder;
 
     public FlowForwarder(final ForwardingRulesManager manager, final DataBroker db) {
         super(manager, db);
-        bundleFlowForwarder = new BundleFlowForwarder(manager);
     }
 
-    @SuppressWarnings("IllegalCatch")
     @Override
+    @SuppressWarnings("IllegalCatch")
     public void registerListener() {
-        final DataTreeIdentifier<Flow> treeId = new DataTreeIdentifier<>(LogicalDatastoreType.CONFIGURATION,
+        final DataTreeIdentifier<Flow> treeId = DataTreeIdentifier.create(LogicalDatastoreType.CONFIGURATION,
                 getWildCardPath());
         try {
             listenerRegistration = dataBroker.registerDataTreeChangeListener(treeId, FlowForwarder.this);
@@ -121,25 +121,29 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     public void remove(final InstanceIdentifier<Flow> identifier, final Flow removeDataObj,
             final InstanceIdentifier<FlowCapableNode> nodeIdent) {
 
-        final TableKey tableKey = identifier.firstKeyOf(Table.class, TableKey.class);
+        final TableKey tableKey = identifier.firstKeyOf(Table.class);
         if (tableIdValidationPrecondition(tableKey, removeDataObj)) {
             BundleId bundleId = getActiveBundle(nodeIdent, provider);
             if (bundleId != null) {
-                bundleFlowForwarder.remove(identifier, removeDataObj, nodeIdent, bundleId);
+                provider.getBundleFlowListener().remove(identifier, removeDataObj, nodeIdent, bundleId);
             } else {
-                final RemoveFlowInputBuilder builder = new RemoveFlowInputBuilder(removeDataObj);
-                builder.setFlowRef(new FlowRef(identifier));
-                builder.setNode(new NodeRef(nodeIdent.firstIdentifierOf(Node.class)));
-                builder.setFlowTable(new FlowTableRef(nodeIdent.child(Table.class, tableKey)));
-
-                // This method is called only when a given flow object has been
-                // removed from datastore. So FRM always needs to set strict flag
-                // into remove-flow input so that only a flow entry associated with
-                // a given flow object is removed.
-                builder.setTransactionUri(new Uri(provider.getNewTransactionId())).setStrict(Boolean.TRUE);
-                final Future<RpcResult<RemoveFlowOutput>> resultFuture =
-                        provider.getSalFlowService().removeFlow(builder.build());
-                JdkFutures.addErrorLogging(resultFuture, LOG, "removeFlow");
+                final String nodeId = getNodeIdValueFromNodeIdentifier(nodeIdent);
+                nodeConfigurator.enqueueJob(nodeId, () -> {
+                    final RemoveFlowInputBuilder builder = new RemoveFlowInputBuilder(removeDataObj);
+                    builder.setFlowRef(new FlowRef(identifier));
+                    builder.setNode(new NodeRef(nodeIdent.firstIdentifierOf(Node.class)));
+                    builder.setFlowTable(new FlowTableRef(nodeIdent.child(Table.class, tableKey)));
+
+                    // This method is called only when a given flow object has been
+                    // removed from datastore. So FRM always needs to set strict flag
+                    // into remove-flow input so that only a flow entry associated with
+                    // a given flow object is removed.
+                    builder.setTransactionUri(new Uri(provider.getNewTransactionId())).setStrict(Boolean.TRUE);
+                    final ListenableFuture<RpcResult<RemoveFlowOutput>> resultFuture =
+                            provider.getSalFlowService().removeFlow(builder.build());
+                    LoggingFutures.addErrorLogging(resultFuture, LOG, "removeFlow");
+                    return resultFuture;
+                });
             }
         }
     }
@@ -147,11 +151,11 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     // TODO: Pull this into ForwardingRulesCommiter and override it here
 
     @Override
-    public Future<RpcResult<RemoveFlowOutput>> removeWithResult(final InstanceIdentifier<Flow> identifier,
+    public ListenableFuture<RpcResult<RemoveFlowOutput>> removeWithResult(final InstanceIdentifier<Flow> identifier,
             final Flow removeDataObj, final InstanceIdentifier<FlowCapableNode> nodeIdent) {
 
-        Future<RpcResult<RemoveFlowOutput>> resultFuture = SettableFuture.create();
-        final TableKey tableKey = identifier.firstKeyOf(Table.class, TableKey.class);
+        ListenableFuture<RpcResult<RemoveFlowOutput>> resultFuture = SettableFuture.create();
+        final TableKey tableKey = identifier.firstKeyOf(Table.class);
         if (tableIdValidationPrecondition(tableKey, removeDataObj)) {
             final RemoveFlowInputBuilder builder = new RemoveFlowInputBuilder(removeDataObj);
             builder.setFlowRef(new FlowRef(identifier));
@@ -173,14 +177,14 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     public void update(final InstanceIdentifier<Flow> identifier, final Flow original, final Flow update,
             final InstanceIdentifier<FlowCapableNode> nodeIdent) {
 
-        final TableKey tableKey = identifier.firstKeyOf(Table.class, TableKey.class);
+        final TableKey tableKey = identifier.firstKeyOf(Table.class);
         if (tableIdValidationPrecondition(tableKey, update)) {
             BundleId bundleId = getActiveBundle(nodeIdent, provider);
             if (bundleId != null) {
-                bundleFlowForwarder.update(identifier, original, update, nodeIdent, bundleId);
+                provider.getBundleFlowListener().update(identifier, original, update, nodeIdent, bundleId);
             } else {
-                final NodeId nodeId = getNodeIdFromNodeIdentifier(nodeIdent);
-                nodeConfigurator.enqueueJob(nodeId.getValue(), () -> {
+                final String nodeId = getNodeIdValueFromNodeIdentifier(nodeIdent);
+                nodeConfigurator.enqueueJob(nodeId, () -> {
                     final UpdateFlowInputBuilder builder = new UpdateFlowInputBuilder();
                     builder.setNode(new NodeRef(nodeIdent.firstIdentifierOf(Node.class)));
                     builder.setFlowRef(new FlowRef(identifier));
@@ -193,31 +197,29 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
                     builder.setUpdatedFlow(new UpdatedFlowBuilder(update).setStrict(Boolean.TRUE).build());
                     builder.setOriginalFlow(new OriginalFlowBuilder(original).setStrict(Boolean.TRUE).build());
 
-                    Long groupId = isFlowDependentOnGroup(update);
-                    ListenableFuture<RpcResult<UpdateFlowOutput>> future = Futures.immediateFuture(null);
+                    Uint32 groupId = isFlowDependentOnGroup(update);
                     if (groupId != null) {
                         LOG.trace("The flow {} is dependent on group {}. Checking if the group is already present",
-                                getFlowId(new FlowRef(identifier)), groupId);
+                                getFlowId(identifier), groupId);
                         if (isGroupExistsOnDevice(nodeIdent, groupId, provider)) {
                             LOG.trace("The dependent group {} is already programmed. Updating the flow {}", groupId,
-                                    getFlowId(new FlowRef(identifier)));
-                            future = provider.getSalFlowService().updateFlow(builder.build());
-                            JdkFutures.addErrorLogging(future, LOG, "updateFlow");
+                                    getFlowId(identifier));
+                            return provider.getSalFlowService().updateFlow(builder.build());
                         } else {
                             LOG.trace("The dependent group {} isn't programmed yet. Pushing the group", groupId);
                             ListenableFuture<RpcResult<AddGroupOutput>> groupFuture = pushDependentGroup(nodeIdent,
                                     groupId);
+                            SettableFuture<RpcResult<UpdateFlowOutput>> resultFuture = SettableFuture.create();
                             Futures.addCallback(groupFuture,
-                                    new UpdateFlowCallBack(builder.build(), nodeId, future, groupId),
+                                    new UpdateFlowCallBack(builder.build(), nodeId, resultFuture, groupId),
                                     MoreExecutors.directExecutor());
+                            return resultFuture;
                         }
-                    } else {
-                        LOG.trace("The flow {} is not dependent on any group. Updating the flow",
-                                getFlowId(new FlowRef(identifier)));
-                        future = provider.getSalFlowService().updateFlow(builder.build());
-                        JdkFutures.addErrorLogging(future, LOG, "updateFlow");
                     }
-                    return future;
+
+                    LOG.trace("The flow {} is not dependent on any group. Updating the flow",
+                            getFlowId(identifier));
+                    return provider.getSalFlowService().updateFlow(builder.build());
                 });
             }
         }
@@ -227,43 +229,42 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     public Future<? extends RpcResult<?>> add(final InstanceIdentifier<Flow> identifier, final Flow addDataObj,
             final InstanceIdentifier<FlowCapableNode> nodeIdent) {
 
-        final TableKey tableKey = identifier.firstKeyOf(Table.class, TableKey.class);
+        final TableKey tableKey = identifier.firstKeyOf(Table.class);
         if (tableIdValidationPrecondition(tableKey, addDataObj)) {
             BundleId bundleId = getActiveBundle(nodeIdent, provider);
             if (bundleId != null) {
-                return bundleFlowForwarder.add(identifier, addDataObj, nodeIdent, bundleId);
+                return provider.getBundleFlowListener().add(identifier, addDataObj, nodeIdent, bundleId);
             } else {
-                final NodeId nodeId = getNodeIdFromNodeIdentifier(nodeIdent);
-                nodeConfigurator.enqueueJob(nodeId.getValue(), () -> {
+                final String nodeId = getNodeIdValueFromNodeIdentifier(nodeIdent);
+                nodeConfigurator.enqueueJob(nodeId, () -> {
                     final AddFlowInputBuilder builder = new AddFlowInputBuilder(addDataObj);
 
                     builder.setNode(new NodeRef(nodeIdent.firstIdentifierOf(Node.class)));
                     builder.setFlowRef(new FlowRef(identifier));
                     builder.setFlowTable(new FlowTableRef(nodeIdent.child(Table.class, tableKey)));
                     builder.setTransactionUri(new Uri(provider.getNewTransactionId()));
-                    Long groupId = isFlowDependentOnGroup(addDataObj);
-                    ListenableFuture<RpcResult<AddFlowOutput>> future = SettableFuture.create();
+                    Uint32 groupId = isFlowDependentOnGroup(addDataObj);
                     if (groupId != null) {
                         LOG.trace("The flow {} is dependent on group {}. Checking if the group is already present",
                                 getFlowId(new FlowRef(identifier)), groupId);
                         if (isGroupExistsOnDevice(nodeIdent, groupId, provider)) {
                             LOG.trace("The dependent group {} is already programmed. Adding the flow {}", groupId,
                                     getFlowId(new FlowRef(identifier)));
-                            future = provider.getSalFlowService().addFlow(builder.build());
+                            return provider.getSalFlowService().addFlow(builder.build());
                         } else {
                             LOG.trace("The dependent group {} isn't programmed yet. Pushing the group", groupId);
                             ListenableFuture<RpcResult<AddGroupOutput>> groupFuture = pushDependentGroup(nodeIdent,
                                     groupId);
-                            Futures.addCallback(groupFuture, new AddFlowCallBack(builder.build(), nodeId, future,
-                                            groupId),
-                                    MoreExecutors.directExecutor());
+                            SettableFuture<RpcResult<AddFlowOutput>> resultFuture = SettableFuture.create();
+                            Futures.addCallback(groupFuture, new AddFlowCallBack(builder.build(), nodeId, groupId,
+                                    resultFuture), MoreExecutors.directExecutor());
+                            return resultFuture;
                         }
-                    } else {
-                        LOG.trace("The flow {} is not dependent on any group. Adding the flow",
-                                getFlowId(new FlowRef(identifier)));
-                        future = provider.getSalFlowService().addFlow(builder.build());
                     }
-                    return future;
+
+                    LOG.trace("The flow {} is not dependent on any group. Adding the flow",
+                            getFlowId(new FlowRef(identifier)));
+                    return provider.getSalFlowService().addFlow(builder.build());
                 });
             }
         }
@@ -273,7 +274,7 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     @Override
     public void createStaleMarkEntity(InstanceIdentifier<Flow> identifier, Flow del,
             InstanceIdentifier<FlowCapableNode> nodeIdent) {
-        LOG.debug("Creating Stale-Mark entry for the switch {} for flow {} ", nodeIdent.toString(), del.toString());
+        LOG.debug("Creating Stale-Mark entry for the switch {} for flow {} ", nodeIdent, del);
         StaleFlow staleFlow = makeStaleFlow(identifier, del, nodeIdent);
         persistStaleFlow(staleFlow, nodeIdent);
     }
@@ -295,7 +296,7 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
         return true;
     }
 
-    private StaleFlow makeStaleFlow(InstanceIdentifier<Flow> identifier, Flow del,
+    private static StaleFlow makeStaleFlow(InstanceIdentifier<Flow> identifier, Flow del,
             InstanceIdentifier<FlowCapableNode> nodeIdent) {
         StaleFlowBuilder staleFlowBuilder = new StaleFlowBuilder(del);
         return staleFlowBuilder.setId(del.getId()).build();
@@ -304,28 +305,28 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     private void persistStaleFlow(StaleFlow staleFlow, InstanceIdentifier<FlowCapableNode> nodeIdent) {
         WriteTransaction writeTransaction = dataBroker.newWriteOnlyTransaction();
         writeTransaction.put(LogicalDatastoreType.CONFIGURATION, getStaleFlowInstanceIdentifier(staleFlow, nodeIdent),
-                staleFlow, false);
+                staleFlow);
 
-        ListenableFuture<Void> submitFuture = writeTransaction.submit();
+        FluentFuture<?> submitFuture = writeTransaction.commit();
         handleStaleFlowResultFuture(submitFuture);
     }
 
-    private void handleStaleFlowResultFuture(ListenableFuture<Void> submitFuture) {
-        Futures.addCallback(submitFuture, new FutureCallback<Void>() {
+    private static void handleStaleFlowResultFuture(FluentFuture<?> submitFuture) {
+        submitFuture.addCallback(new FutureCallback<Object>() {
             @Override
-            public void onSuccess(Void result) {
+            public void onSuccess(Object result) {
                 LOG.debug("Stale Flow creation success");
             }
 
             @Override
             public void onFailure(Throwable throwable) {
-                LOG.error("Stale Flow creation failed {}", throwable);
+                LOG.error("Stale Flow creation failed", throwable);
             }
         }, MoreExecutors.directExecutor());
 
     }
 
-    private InstanceIdentifier<org.opendaylight.yang.gen.v1.urn.opendaylight
+    private static InstanceIdentifier<org.opendaylight.yang.gen.v1.urn.opendaylight
         .flow.inventory.rev130819.tables.table.StaleFlow> getStaleFlowInstanceIdentifier(
             StaleFlow staleFlow, InstanceIdentifier<FlowCapableNode> nodeIdent) {
         return nodeIdent.child(Table.class, new TableKey(staleFlow.getTableId())).child(
@@ -334,7 +335,7 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
     }
 
     private ListenableFuture<RpcResult<AddGroupOutput>> pushDependentGroup(
-            final InstanceIdentifier<FlowCapableNode> nodeIdent, final Long groupId) {
+            final InstanceIdentifier<FlowCapableNode> nodeIdent, final Uint32 groupId) {
 
         //TODO This read to the DS might have a performance impact.
         //if the dependent group is not installed than we should just cache the parent group,
@@ -343,9 +344,8 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
         InstanceIdentifier<Group> groupIdent = buildGroupInstanceIdentifier(nodeIdent, groupId);
         ListenableFuture<RpcResult<AddGroupOutput>> resultFuture;
         LOG.info("Reading the group from config inventory: {}", groupId);
-        try {
-            Optional<Group> group;
-            group = provider.getReadTranaction().read(LogicalDatastoreType.CONFIGURATION, groupIdent).get();
+        try (ReadTransaction readTransaction = provider.getReadTransaction()) {
+            Optional<Group> group = readTransaction.read(LogicalDatastoreType.CONFIGURATION, groupIdent).get();
             if (group.isPresent()) {
                 final AddGroupInputBuilder builder = new AddGroupInputBuilder(group.get());
                 builder.setNode(new NodeRef(nodeIdent.firstIdentifierOf(Node.class)));
@@ -369,91 +369,101 @@ public class FlowForwarder extends AbstractListeningCommiter<Flow> {
 
     private final class AddFlowCallBack implements FutureCallback<RpcResult<AddGroupOutput>> {
         private final AddFlowInput addFlowInput;
-        private final NodeId nodeId;
-        private ListenableFuture<RpcResult<AddFlowOutput>> future;
-        private final Long groupId;
+        private final String nodeId;
+        private final Uint32 groupId;
+        private final SettableFuture<RpcResult<AddFlowOutput>> resultFuture;
 
-        private AddFlowCallBack(final AddFlowInput addFlowInput, final NodeId nodeId,
-                ListenableFuture<RpcResult<AddFlowOutput>> future, Long groupId) {
+        private AddFlowCallBack(final AddFlowInput addFlowInput, final String nodeId, Uint32 groupId,
+                SettableFuture<RpcResult<AddFlowOutput>> resultFuture) {
             this.addFlowInput = addFlowInput;
             this.nodeId = nodeId;
-            this.future = future;
             this.groupId = groupId;
+            this.resultFuture = resultFuture;
         }
 
         @Override
         public void onSuccess(RpcResult<AddGroupOutput> rpcResult) {
-            if (rpcResult.isSuccessful()) {
+            if (rpcResult.isSuccessful() || rpcResult.getErrors().size() == 1
+                    && rpcResult.getErrors().iterator().next().getMessage().contains(GROUP_EXISTS_IN_DEVICE_ERROR)) {
                 provider.getDevicesGroupRegistry().storeGroup(nodeId, groupId);
-                future = provider.getSalFlowService().addFlow(addFlowInput);
+                Futures.addCallback(provider.getSalFlowService().addFlow(addFlowInput),
+                    new FutureCallback<RpcResult<AddFlowOutput>>() {
+                        @Override
+                        public void onSuccess(RpcResult<AddFlowOutput> result) {
+                            resultFuture.set(result);
+                        }
+
+                        @Override
+                        public void onFailure(Throwable failure) {
+                            resultFuture.setException(failure);
+                        }
+                    },  MoreExecutors.directExecutor());
+
                 LOG.debug("Flow add with id {} finished without error for node {}",
                         getFlowId(addFlowInput.getFlowRef()), nodeId);
             } else {
-                if (rpcResult.getErrors().size() == 1
-                        && rpcResult.getErrors().iterator().next().getMessage()
-                        .contains(GROUP_EXISTS_IN_DEVICE_ERROR)) {
-                    provider.getDevicesGroupRegistry().storeGroup(nodeId, groupId);
-                    future = provider.getSalFlowService().addFlow(addFlowInput);
-                    LOG.debug("Group {} already programmed in the device. Adding the flow {}", groupId,
-                            getFlowId(addFlowInput.getFlowRef()));
-                } else {
-                    LOG.error("Flow add with id {} failed for node {} with error {}",
-                            getFlowId(addFlowInput.getFlowRef()), nodeId, rpcResult.getErrors().toString());
-                    future = Futures.immediateFuture(null);
-                }
+                LOG.error("Flow add with id {} failed for node {} with error {}", getFlowId(addFlowInput.getFlowRef()),
+                        nodeId, rpcResult.getErrors());
+                resultFuture.set(RpcResultBuilder.<AddFlowOutput>failed()
+                        .withRpcErrors(rpcResult.getErrors()).build());
             }
         }
 
         @Override
         public void onFailure(Throwable throwable) {
-            LOG.error("Service call for adding flow with id {} failed for node {} with error {}",
-                    getFlowId(addFlowInput.getFlowRef()), nodeId, throwable.getCause());
-            Futures.immediateFailedFuture(null);
+            LOG.error("Service call for adding flow with id {} failed for node {}",
+                    getFlowId(addFlowInput.getFlowRef()), nodeId, throwable);
+            resultFuture.setException(throwable);
         }
     }
 
     private final class UpdateFlowCallBack implements FutureCallback<RpcResult<AddGroupOutput>> {
         private final UpdateFlowInput updateFlowInput;
-        private final NodeId nodeId;
-        private ListenableFuture<RpcResult<UpdateFlowOutput>> future;
-        private final Long groupId;
+        private final String nodeId;
+        private final Uint32 groupId;
+        private final SettableFuture<RpcResult<UpdateFlowOutput>> resultFuture;
 
-        private UpdateFlowCallBack(final UpdateFlowInput updateFlowInput, final NodeId nodeId,
-                ListenableFuture<RpcResult<UpdateFlowOutput>> future, Long groupId) {
+        private UpdateFlowCallBack(final UpdateFlowInput updateFlowInput, final String nodeId,
+                SettableFuture<RpcResult<UpdateFlowOutput>> resultFuture, Uint32 groupId) {
             this.updateFlowInput = updateFlowInput;
             this.nodeId = nodeId;
-            this.future = future;
             this.groupId = groupId;
+            this.resultFuture = resultFuture;
         }
 
         @Override
         public void onSuccess(RpcResult<AddGroupOutput> rpcResult) {
-            if (rpcResult.isSuccessful()) {
+            if (rpcResult.isSuccessful() || rpcResult.getErrors().size() == 1
+                    && rpcResult.getErrors().iterator().next().getMessage().contains(GROUP_EXISTS_IN_DEVICE_ERROR)) {
                 provider.getDevicesGroupRegistry().storeGroup(nodeId, groupId);
-                future = provider.getSalFlowService().updateFlow(updateFlowInput);
+                Futures.addCallback(provider.getSalFlowService().updateFlow(updateFlowInput),
+                    new FutureCallback<RpcResult<UpdateFlowOutput>>() {
+                        @Override
+                        public void onSuccess(RpcResult<UpdateFlowOutput> result) {
+                            resultFuture.set(result);
+                        }
+
+                        @Override
+                        public void onFailure(Throwable failure) {
+                            resultFuture.setException(failure);
+                        }
+                    },  MoreExecutors.directExecutor());
+
                 LOG.debug("Flow update with id {} finished without error for node {}",
                         getFlowId(updateFlowInput.getFlowRef()), nodeId);
             } else {
-                if (rpcResult.getErrors().size() == 1
-                        && rpcResult.getErrors().iterator().next().getMessage()
-                        .contains(GROUP_EXISTS_IN_DEVICE_ERROR)) {
-                    provider.getDevicesGroupRegistry().storeGroup(nodeId, groupId);
-                    future = provider.getSalFlowService().updateFlow(updateFlowInput);
-                    LOG.debug("Group {} already programmed in the device. Updating the flow {}", groupId,
-                            getFlowId(updateFlowInput.getFlowRef()));
-                } else {
-                    LOG.error("Flow update with id {} failed for node {} with error {}",
-                            getFlowId(updateFlowInput.getFlowRef()), nodeId, rpcResult.getErrors().toString());
-                    future = Futures.immediateFuture(null);
-                }
+                LOG.error("Flow update with id {} failed for node {} with error {}",
+                        getFlowId(updateFlowInput.getFlowRef()), nodeId, rpcResult.getErrors());
+                resultFuture.set(RpcResultBuilder.<UpdateFlowOutput>failed()
+                        .withRpcErrors(rpcResult.getErrors()).build());
             }
         }
 
         @Override
         public void onFailure(Throwable throwable) {
-            LOG.error("Service call for updating flow with id {} failed for node {} with error {}",
+            LOG.error("Service call for updating flow with id {} failed for node {}",
                     getFlowId(updateFlowInput.getFlowRef()), nodeId, throwable);
-            future = Futures.immediateFailedFuture(null);
+            resultFuture.setException(throwable);
         }
     }
 }