You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by hu...@apache.org on 2014/01/13 12:16:52 UTC

[1/5] git commit: updated refs/heads/master to 3bea604

Updated Branches:
  refs/heads/master 1760de47e -> 3bea60435


Fix coverity issues 569415, 569416, 569417


Project: http://git-wip-us.apache.org/repos/asf/cloudstack/repo
Commit: http://git-wip-us.apache.org/repos/asf/cloudstack/commit/4683de5a
Tree: http://git-wip-us.apache.org/repos/asf/cloudstack/tree/4683de5a
Diff: http://git-wip-us.apache.org/repos/asf/cloudstack/diff/4683de5a

Branch: refs/heads/master
Commit: 4683de5a923d43ce69a16adacd423050455dc486
Parents: 1760de4
Author: Hugo Trippaers <ht...@schubergphilis.com>
Authored: Mon Jan 13 11:38:48 2014 +0100
Committer: Hugo Trippaers <ht...@schubergphilis.com>
Committed: Mon Jan 13 12:16:36 2014 +0100

----------------------------------------------------------------------
 .../cloud/network/element/NiciraNvpElement.java | 59 +++++++++++---------
 1 file changed, 33 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/4683de5a/plugins/network-elements/nicira-nvp/src/com/cloud/network/element/NiciraNvpElement.java
----------------------------------------------------------------------
diff --git a/plugins/network-elements/nicira-nvp/src/com/cloud/network/element/NiciraNvpElement.java b/plugins/network-elements/nicira-nvp/src/com/cloud/network/element/NiciraNvpElement.java
index b200457..2dbf828 100644
--- a/plugins/network-elements/nicira-nvp/src/com/cloud/network/element/NiciraNvpElement.java
+++ b/plugins/network-elements/nicira-nvp/src/com/cloud/network/element/NiciraNvpElement.java
@@ -127,9 +127,9 @@ import com.cloud.vm.dao.NicDao;
 
 @Component
 @Local(value = {NetworkElement.class, ConnectivityProvider.class, SourceNatServiceProvider.class, StaticNatServiceProvider.class, PortForwardingServiceProvider.class,
-    IpDeployer.class})
+        IpDeployer.class})
 public class NiciraNvpElement extends AdapterBase implements ConnectivityProvider, SourceNatServiceProvider, PortForwardingServiceProvider, StaticNatServiceProvider,
-        NiciraNvpElementService, ResourceStateAdapter, IpDeployer {
+NiciraNvpElementService, ResourceStateAdapter, IpDeployer {
 
     private static final int MAX_PORT = 65535;
     private static final int MIN_PORT = 0;
@@ -211,7 +211,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
 
     @Override
     public boolean implement(Network network, NetworkOffering offering, DeployDestination dest, ReservationContext context) throws ConcurrentOperationException,
-        ResourceUnavailableException, InsufficientCapacityException {
+    ResourceUnavailableException, InsufficientCapacityException {
         s_logger.debug("entering NiciraNvpElement implement function for network " + network.getDisplayText() + " (state " + network.getState() + ")");
 
         if (!canHandle(network, Service.Connectivity)) {
@@ -262,9 +262,9 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
             long vlanid = (Vlan.UNTAGGED.equals(vtag)) ? 0 : Long.parseLong(vtag);
 
             CreateLogicalRouterCommand cmd =
-                new CreateLogicalRouterCommand(niciraNvpHost.getDetail("l3gatewayserviceuuid"), vlanid, BroadcastDomainType.getValue(network.getBroadcastUri()),
-                    "router-" + network.getDisplayText(), publicCidr, sourceNatIp.getGateway(), internalCidr, context.getDomain().getName() + "-" +
-                        context.getAccount().getAccountName());
+                    new CreateLogicalRouterCommand(niciraNvpHost.getDetail("l3gatewayserviceuuid"), vlanid, BroadcastDomainType.getValue(network.getBroadcastUri()),
+                            "router-" + network.getDisplayText(), publicCidr, sourceNatIp.getGateway(), internalCidr, context.getDomain().getName() + "-" +
+                                    context.getAccount().getAccountName());
             CreateLogicalRouterAnswer answer = (CreateLogicalRouterAnswer)agentMgr.easySend(niciraNvpHost.getId(), cmd);
             if (answer.getResult() == false) {
                 s_logger.error("Failed to create Logical Router for network " + network.getDisplayText());
@@ -281,7 +281,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
 
     @Override
     public boolean prepare(Network network, NicProfile nic, VirtualMachineProfile vm, DeployDestination dest, ReservationContext context)
-        throws ConcurrentOperationException, ResourceUnavailableException, InsufficientCapacityException {
+            throws ConcurrentOperationException, ResourceUnavailableException, InsufficientCapacityException {
 
         if (!canHandle(network, Service.Connectivity)) {
             return false;
@@ -310,8 +310,8 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
             if (answer.getResult()) {
                 s_logger.warn("Existing Logical Switchport found for nic " + nic.getName() + " with uuid " + existingNicMap.getLogicalSwitchPortUuid());
                 UpdateLogicalSwitchPortCommand cmd =
-                    new UpdateLogicalSwitchPortCommand(existingNicMap.getLogicalSwitchPortUuid(), BroadcastDomainType.getValue(network.getBroadcastUri()),
-                        nicVO.getUuid(), context.getDomain().getName() + "-" + context.getAccount().getAccountName(), nic.getName());
+                        new UpdateLogicalSwitchPortCommand(existingNicMap.getLogicalSwitchPortUuid(), BroadcastDomainType.getValue(network.getBroadcastUri()),
+                                nicVO.getUuid(), context.getDomain().getName() + "-" + context.getAccount().getAccountName(), nic.getName());
                 agentMgr.easySend(niciraNvpHost.getId(), cmd);
                 return true;
             } else {
@@ -321,8 +321,8 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
         }
 
         CreateLogicalSwitchPortCommand cmd =
-            new CreateLogicalSwitchPortCommand(BroadcastDomainType.getValue(network.getBroadcastUri()), nicVO.getUuid(), context.getDomain().getName() + "-" +
-                context.getAccount().getAccountName(), nic.getName());
+                new CreateLogicalSwitchPortCommand(BroadcastDomainType.getValue(network.getBroadcastUri()), nicVO.getUuid(), context.getDomain().getName() + "-" +
+                        context.getAccount().getAccountName(), nic.getName());
         CreateLogicalSwitchPortAnswer answer = (CreateLogicalSwitchPortAnswer)agentMgr.easySend(niciraNvpHost.getId(), cmd);
 
         if (answer == null || !answer.getResult()) {
@@ -331,7 +331,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
         }
 
         NiciraNvpNicMappingVO nicMap =
-            new NiciraNvpNicMappingVO(BroadcastDomainType.getValue(network.getBroadcastUri()), answer.getLogicalSwitchPortUuid(), nicVO.getUuid());
+                new NiciraNvpNicMappingVO(BroadcastDomainType.getValue(network.getBroadcastUri()), answer.getLogicalSwitchPortUuid(), nicVO.getUuid());
         niciraNvpNicMappingDao.persist(nicMap);
 
         return true;
@@ -339,7 +339,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
 
     @Override
     public boolean release(Network network, NicProfile nic, VirtualMachineProfile vm, ReservationContext context) throws ConcurrentOperationException,
-        ResourceUnavailableException {
+    ResourceUnavailableException {
 
         if (!canHandle(network, Service.Connectivity)) {
             return false;
@@ -434,7 +434,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
 
     @Override
     public boolean shutdownProviderInstances(PhysicalNetworkServiceProvider provider, ReservationContext context) throws ConcurrentOperationException,
-        ResourceUnavailableException {
+    ResourceUnavailableException {
         // Nothing to do here.
         return true;
     }
@@ -499,6 +499,9 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
         ServerResource resource = new NiciraNvpResource();
         final String deviceName = Network.Provider.NiciraNvp.getName();
         NetworkDevice networkDevice = NetworkDevice.getNetworkDevice(deviceName);
+        if (networkDevice == null) {
+            throw new CloudRuntimeException("No network device found for " + deviceName);
+        }
         final Long physicalNetworkId = cmd.getPhysicalNetworkId();
         PhysicalNetworkVO physicalNetwork = physicalNetworkDao.findById(physicalNetworkId);
         if (physicalNetwork == null) {
@@ -507,13 +510,13 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
         long zoneId = physicalNetwork.getDataCenterId();
 
         final PhysicalNetworkServiceProviderVO ntwkSvcProvider =
-            physicalNetworkServiceProviderDao.findByServiceProvider(physicalNetwork.getId(), networkDevice.getNetworkServiceProvder());
+                physicalNetworkServiceProviderDao.findByServiceProvider(physicalNetwork.getId(), networkDevice.getNetworkServiceProvder());
         if (ntwkSvcProvider == null) {
             throw new CloudRuntimeException("Network Service Provider: " + networkDevice.getNetworkServiceProvder() + " is not enabled in the physical network: " +
-                physicalNetworkId + "to add this device");
+                    physicalNetworkId + "to add this device");
         } else if (ntwkSvcProvider.getState() == PhysicalNetworkServiceProvider.State.Shutdown) {
             throw new CloudRuntimeException("Network Service Provider: " + ntwkSvcProvider.getProviderName() + " is in shutdown state in the physical network: " +
-                physicalNetworkId + "to add this device");
+                    physicalNetworkId + "to add this device");
         }
 
         if (niciraNvpDao.listByPhysicalNetwork(physicalNetworkId).size() != 0) {
@@ -598,12 +601,13 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
             // Lets see if there are networks that use us
             // Find the nicira networks on this physical network
             List<NetworkVO> networkList = networkDao.listByPhysicalNetwork(physicalNetworkId);
-
-            // Networks with broadcast type lswitch are ours
-            for (NetworkVO network : networkList) {
-                if (network.getBroadcastDomainType() == Networks.BroadcastDomainType.Lswitch) {
-                    if ((network.getState() != Network.State.Shutdown) && (network.getState() != Network.State.Destroy)) {
-                        throw new CloudRuntimeException("This Nicira Nvp device can not be deleted as there are one or more logical networks provisioned by cloudstack.");
+            if (networkList != null) {
+                // Networks with broadcast type lswitch are ours
+                for (NetworkVO network : networkList) {
+                    if (network.getBroadcastDomainType() == Networks.BroadcastDomainType.Lswitch) {
+                        if ((network.getState() != Network.State.Shutdown) && (network.getState() != Network.State.Destroy)) {
+                            throw new CloudRuntimeException("This Nicira Nvp device can not be deleted as there are one or more logical networks provisioned by cloudstack.");
+                        }
                     }
                 }
             }
@@ -665,6 +669,9 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
 
         // Find the nicira networks on this physical network
         List<NetworkVO> networkList = networkDao.listByPhysicalNetwork(physicalNetworkId);
+        if (networkList == null) {
+            return Collections.emptyList();
+        }
 
         // Networks with broadcast type lswitch are ours
         List<NetworkVO> responseList = new ArrayList<NetworkVO>();
@@ -747,7 +754,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
                 cidrs.add(ip.getAddress().addr() + "/" + NetUtils.getCidrSize(ip.getNetmask()));
             }
             ConfigurePublicIpsOnLogicalRouterCommand cmd =
-                new ConfigurePublicIpsOnLogicalRouterCommand(routermapping.getLogicalRouterUuid(), niciraNvpHost.getDetail("l3gatewayserviceuuid"), cidrs);
+                    new ConfigurePublicIpsOnLogicalRouterCommand(routermapping.getLogicalRouterUuid(), niciraNvpHost.getDetail("l3gatewayserviceuuid"), cidrs);
             ConfigurePublicIpsOnLogicalRouterAnswer answer = (ConfigurePublicIpsOnLogicalRouterAnswer)agentMgr.easySend(niciraNvpHost.getId(), cmd);
             //FIXME answer can be null if the host is down
             return answer.getResult();
@@ -788,7 +795,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
             // we only need the source and destination ip. Unfortunately no mention if a rule
             // is new.
             StaticNatRuleTO ruleTO =
-                new StaticNatRuleTO(1, sourceIp.getAddress().addr(), MIN_PORT, MAX_PORT, rule.getDestIpAddress(), MIN_PORT, MAX_PORT, "any", rule.isForRevoke(), false);
+                    new StaticNatRuleTO(1, sourceIp.getAddress().addr(), MIN_PORT, MAX_PORT, rule.getDestIpAddress(), MIN_PORT, MAX_PORT, "any", rule.isForRevoke(), false);
             staticNatRules.add(ruleTO);
         }
 
@@ -830,7 +837,7 @@ public class NiciraNvpElement extends AdapterBase implements ConnectivityProvide
         }
 
         ConfigurePortForwardingRulesOnLogicalRouterCommand cmd =
-            new ConfigurePortForwardingRulesOnLogicalRouterCommand(routermapping.getLogicalRouterUuid(), portForwardingRules);
+                new ConfigurePortForwardingRulesOnLogicalRouterCommand(routermapping.getLogicalRouterUuid(), portForwardingRules);
         ConfigurePortForwardingRulesOnLogicalRouterAnswer answer = (ConfigurePortForwardingRulesOnLogicalRouterAnswer)agentMgr.easySend(niciraNvpHost.getId(), cmd);
 
         return answer.getResult();


[3/5] git commit: updated refs/heads/master to 3bea604

Posted by hu...@apache.org.
Fix coverity issue 606007, 606008


Project: http://git-wip-us.apache.org/repos/asf/cloudstack/repo
Commit: http://git-wip-us.apache.org/repos/asf/cloudstack/commit/16d333f0
Tree: http://git-wip-us.apache.org/repos/asf/cloudstack/tree/16d333f0
Diff: http://git-wip-us.apache.org/repos/asf/cloudstack/diff/16d333f0

Branch: refs/heads/master
Commit: 16d333f06dfaa1eac1d0ab74ab33d98fe8ed2ccb
Parents: 044a207
Author: Hugo Trippaers <ht...@schubergphilis.com>
Authored: Mon Jan 13 11:58:51 2014 +0100
Committer: Hugo Trippaers <ht...@schubergphilis.com>
Committed: Mon Jan 13 12:16:37 2014 +0100

----------------------------------------------------------------------
 .../OpenDaylightControllerResourceManagerImpl.java   | 15 ++++++++++-----
 1 file changed, 10 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/16d333f0/plugins/network-elements/opendaylight/src/main/java/org/apache/cloudstack/network/opendaylight/agent/OpenDaylightControllerResourceManagerImpl.java
----------------------------------------------------------------------
diff --git a/plugins/network-elements/opendaylight/src/main/java/org/apache/cloudstack/network/opendaylight/agent/OpenDaylightControllerResourceManagerImpl.java b/plugins/network-elements/opendaylight/src/main/java/org/apache/cloudstack/network/opendaylight/agent/OpenDaylightControllerResourceManagerImpl.java
index f4da02b..abc48bb 100644
--- a/plugins/network-elements/opendaylight/src/main/java/org/apache/cloudstack/network/opendaylight/agent/OpenDaylightControllerResourceManagerImpl.java
+++ b/plugins/network-elements/opendaylight/src/main/java/org/apache/cloudstack/network/opendaylight/agent/OpenDaylightControllerResourceManagerImpl.java
@@ -92,6 +92,9 @@ public class OpenDaylightControllerResourceManagerImpl implements OpenDaylightCo
 
         final String deviceName = NetworkDevice.OpenDaylightController.getName();
         NetworkDevice networkDevice = NetworkDevice.getNetworkDevice(deviceName);
+        if (networkDevice == null) {
+            throw new CloudRuntimeException("No network device found for name " + deviceName);
+        }
         final Long physicalNetworkId = cmd.getPhysicalNetworkId();
         PhysicalNetworkVO physicalNetwork = physicalNetworkDao.findById(physicalNetworkId);
         if (physicalNetwork == null) {
@@ -156,11 +159,13 @@ public class OpenDaylightControllerResourceManagerImpl implements OpenDaylightCo
             // Lets see if there are networks that use us
             List<NetworkVO> networkList = networkDao.listByPhysicalNetwork(physicalNetworkId);
 
-            // Networks with broadcast type lswitch are ours
-            for (NetworkVO network : networkList) {
-                if (network.getBroadcastDomainType() == Networks.BroadcastDomainType.OpenDaylight) {
-                    if ((network.getState() != Network.State.Shutdown) && (network.getState() != Network.State.Destroy)) {
-                        throw new CloudRuntimeException("This Controller can not be deleted as there are one or more logical networks provisioned by cloudstack.");
+            if (networkList != null) {
+                // Networks with broadcast type lswitch are ours
+                for (NetworkVO network : networkList) {
+                    if (network.getBroadcastDomainType() == Networks.BroadcastDomainType.OpenDaylight) {
+                        if ((network.getState() != Network.State.Shutdown) && (network.getState() != Network.State.Destroy)) {
+                            throw new CloudRuntimeException("This Controller can not be deleted as there are one or more logical networks provisioned by cloudstack.");
+                        }
                     }
                 }
             }


[4/5] git commit: updated refs/heads/master to 3bea604

Posted by hu...@apache.org.
Remove commented elements


Project: http://git-wip-us.apache.org/repos/asf/cloudstack/repo
Commit: http://git-wip-us.apache.org/repos/asf/cloudstack/commit/3bea6043
Tree: http://git-wip-us.apache.org/repos/asf/cloudstack/tree/3bea6043
Diff: http://git-wip-us.apache.org/repos/asf/cloudstack/diff/3bea6043

Branch: refs/heads/master
Commit: 3bea60435e324a17fac122c7117c49793675edd2
Parents: 16d333f
Author: Hugo Trippaers <ht...@schubergphilis.com>
Authored: Mon Jan 13 12:02:51 2014 +0100
Committer: Hugo Trippaers <ht...@schubergphilis.com>
Committed: Mon Jan 13 12:16:37 2014 +0100

----------------------------------------------------------------------
 plugins/network-elements/nicira-nvp/pom.xml | 34 ------------------------
 1 file changed, 34 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/3bea6043/plugins/network-elements/nicira-nvp/pom.xml
----------------------------------------------------------------------
diff --git a/plugins/network-elements/nicira-nvp/pom.xml b/plugins/network-elements/nicira-nvp/pom.xml
index 477b295..a4b4c49 100644
--- a/plugins/network-elements/nicira-nvp/pom.xml
+++ b/plugins/network-elements/nicira-nvp/pom.xml
@@ -34,40 +34,6 @@
         <filtering>true</filtering>
       </testResource>
     </testResources>
-
-<!--
-    <plugins>
-      <plugin>
-        <groupId>org.apache.maven.plugins</groupId>
-        <artifactId>maven-checkstyle-plugin</artifactId>
-        <version>${cs.checkstyle.version}</version>
-        <dependencies>
-          <dependency>
-            <groupId>org.apache.cloudstack</groupId>
-            <artifactId>checkstyle</artifactId>
-            <version>${project.version}</version>
-          </dependency>
-        </dependencies>
-        <executions>
-          <execution>
-            <phase>process-classes</phase>
-            <goals>
-              <goal>check</goal>
-            </goals>
-          </execution>
-        </executions>
-        <configuration>
-          <failsOnError>true</failsOnError>
-          <configLocation>tooling/checkstyle.xml</configLocation>
-          <consoleOutput>true</consoleOutput>
-          <includeTestSourceDirectory>true</includeTestSourceDirectory>
-          <sourceDirectory>${project.basedir}</sourceDirectory>
-          <includes>**\/*.java,**\/*.xml,**\/*.ini,**\/*.sh,**\/*.bat</includes>
-          <excludes>**\/target\/,**\/bin\/</excludes>
-        </configuration>
-      </plugin>
-    </plugins>
--->
   </build>
 
   <profiles>


[5/5] git commit: updated refs/heads/master to 3bea604

Posted by hu...@apache.org.
Fix coverity issue 600070


Project: http://git-wip-us.apache.org/repos/asf/cloudstack/repo
Commit: http://git-wip-us.apache.org/repos/asf/cloudstack/commit/15a08107
Tree: http://git-wip-us.apache.org/repos/asf/cloudstack/tree/15a08107
Diff: http://git-wip-us.apache.org/repos/asf/cloudstack/diff/15a08107

Branch: refs/heads/master
Commit: 15a08107d8554b32edd9b566fe70c6b65a2d6597
Parents: 4683de5
Author: Hugo Trippaers <ht...@schubergphilis.com>
Authored: Mon Jan 13 11:53:50 2014 +0100
Committer: Hugo Trippaers <ht...@schubergphilis.com>
Committed: Mon Jan 13 12:16:37 2014 +0100

----------------------------------------------------------------------
 .../com/cloud/network/nicira/NiciraNvpApi.java  | 35 +++++++++-----------
 1 file changed, 16 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/15a08107/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/NiciraNvpApi.java
----------------------------------------------------------------------
diff --git a/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/NiciraNvpApi.java b/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/NiciraNvpApi.java
index e58dcb9..92c23eb 100644
--- a/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/NiciraNvpApi.java
+++ b/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/NiciraNvpApi.java
@@ -71,6 +71,7 @@ import com.google.gson.JsonObject;
 import com.google.gson.JsonParseException;
 import com.google.gson.reflect.TypeToken;
 
+@SuppressWarnings("rawtypes")
 public class NiciraNvpApi {
     protected static final String GET_METHOD_TYPE = "get";
     protected static final String DELETE_METHOD_TYPE = "delete";
@@ -98,14 +99,27 @@ public class NiciraNvpApi {
 
     private final Gson gson;
 
-    @SuppressWarnings("rawtypes")
     protected static Map<Class, String> prefixMap;
 
-    @SuppressWarnings("rawtypes")
     protected static Map<Class, Type> listTypeMap;
 
     protected static Map<String, String> defaultListParams;
 
+    static {
+        prefixMap = new HashMap<Class, String>();
+        prefixMap.put(SecurityProfile.class, SEC_PROFILE_URI_PREFIX);
+        prefixMap.put(Acl.class, ACL_URI_PREFIX);
+
+        listTypeMap = new HashMap<Class, Type>();
+        listTypeMap.put(SecurityProfile.class, new TypeToken<NiciraNvpList<SecurityProfile>>() {
+        }.getType());
+        listTypeMap.put(Acl.class, new TypeToken<NiciraNvpList<Acl>>() {
+        }.getType());
+
+        defaultListParams = new HashMap<String, String>();
+        defaultListParams.put("fields", "*");
+    }
+
     /* This factory method is protected so we can extend this
      * in the unittests.
      */
@@ -147,23 +161,6 @@ public class NiciraNvpApi {
         }
 
         gson = new GsonBuilder().registerTypeAdapter(NatRule.class, new NatRuleAdapter()).setFieldNamingPolicy(FieldNamingPolicy.LOWER_CASE_WITH_UNDERSCORES).create();
-        buildTypeSpecificStructures();
-    }
-
-    @SuppressWarnings("rawtypes")
-    protected void buildTypeSpecificStructures() {
-        if (prefixMap == null || listTypeMap == null || defaultListParams == null) {
-            prefixMap = new HashMap<Class, String>();
-            prefixMap.put(SecurityProfile.class, SEC_PROFILE_URI_PREFIX);
-            prefixMap.put(Acl.class, ACL_URI_PREFIX);
-
-            listTypeMap = new HashMap<Class, Type>();
-            listTypeMap.put(SecurityProfile.class, new TypeToken<NiciraNvpList<SecurityProfile>>() {}.getType());
-            listTypeMap.put(Acl.class, new TypeToken<NiciraNvpList<Acl>>() {}.getType());
-
-            defaultListParams = new HashMap<String, String>();
-            defaultListParams.put("fields", "*");
-        }
     }
 
     public void setControllerAddress(final String address) {


[2/5] git commit: updated refs/heads/master to 3bea604

Posted by hu...@apache.org.
Fix coverity issue 573580


Project: http://git-wip-us.apache.org/repos/asf/cloudstack/repo
Commit: http://git-wip-us.apache.org/repos/asf/cloudstack/commit/044a2078
Tree: http://git-wip-us.apache.org/repos/asf/cloudstack/tree/044a2078
Diff: http://git-wip-us.apache.org/repos/asf/cloudstack/diff/044a2078

Branch: refs/heads/master
Commit: 044a2078a153ae9811d955f8a753ea4235a42928
Parents: 15a0810
Author: Hugo Trippaers <ht...@schubergphilis.com>
Authored: Mon Jan 13 11:54:24 2014 +0100
Committer: Hugo Trippaers <ht...@schubergphilis.com>
Committed: Mon Jan 13 12:16:37 2014 +0100

----------------------------------------------------------------------
 .../network/nicira/SingleDefaultRouteImplictRoutingConfig.java     | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/044a2078/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/SingleDefaultRouteImplictRoutingConfig.java
----------------------------------------------------------------------
diff --git a/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/SingleDefaultRouteImplictRoutingConfig.java b/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/SingleDefaultRouteImplictRoutingConfig.java
index bbe1cb5..d386e70 100644
--- a/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/SingleDefaultRouteImplictRoutingConfig.java
+++ b/plugins/network-elements/nicira-nvp/src/com/cloud/network/nicira/SingleDefaultRouteImplictRoutingConfig.java
@@ -21,7 +21,7 @@ package com.cloud.network.nicira;
  */
 public class SingleDefaultRouteImplictRoutingConfig extends RoutingConfig {
     public RouterNextHop defaultRouteNextHop;
-    public String type = "SingleDefaultRouteImplicitRoutingConfig";
+    public final String type = "SingleDefaultRouteImplicitRoutingConfig";
 
     public SingleDefaultRouteImplictRoutingConfig(RouterNextHop routerNextHop) {
         defaultRouteNextHop = routerNextHop;