You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by ah...@apache.org on 2013/01/19 01:00:12 UTC

[40/51] [abbrv] All merge conflicts resolved

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/10d9c019/plugins/hypervisors/vmware/src/com/cloud/hypervisor/vmware/manager/VmwareManagerImpl.java
----------------------------------------------------------------------
diff --cc plugins/hypervisors/vmware/src/com/cloud/hypervisor/vmware/manager/VmwareManagerImpl.java
index 618d996,c450312..1e941b7
--- a/plugins/hypervisors/vmware/src/com/cloud/hypervisor/vmware/manager/VmwareManagerImpl.java
+++ b/plugins/hypervisors/vmware/src/com/cloud/hypervisor/vmware/manager/VmwareManagerImpl.java
@@@ -46,7 -44,7 +46,6 @@@ import com.cloud.agent.api.Answer
  import com.cloud.agent.api.Command;
  import com.cloud.agent.api.StartupCommand;
  import com.cloud.agent.api.StartupRoutingCommand;
--import com.cloud.cluster.CheckPointManager;
  import com.cloud.cluster.ClusterManager;
  import com.cloud.configuration.Config;
  import com.cloud.configuration.dao.ConfigurationDao;
@@@ -61,10 -59,10 +60,6 @@@ import com.cloud.host.Status
  import com.cloud.host.dao.HostDao;
  import com.cloud.hypervisor.Hypervisor.HypervisorType;
  import com.cloud.hypervisor.vmware.VmwareCleanupMaid;
--import com.cloud.hypervisor.vmware.manager.VmwareManager;
--import com.cloud.hypervisor.vmware.manager.VmwareStorageManager;
--import com.cloud.hypervisor.vmware.manager.VmwareStorageManagerImpl;
--import com.cloud.hypervisor.vmware.manager.VmwareStorageMount;
  import com.cloud.hypervisor.vmware.mo.DiskControllerType;
  import com.cloud.hypervisor.vmware.mo.HostFirewallSystemMO;
  import com.cloud.hypervisor.vmware.mo.HostMO;
@@@ -72,27 -70,28 +67,27 @@@ import com.cloud.hypervisor.vmware.mo.H
  import com.cloud.hypervisor.vmware.mo.TaskMO;
  import com.cloud.hypervisor.vmware.mo.VirtualEthernetCardType;
  import com.cloud.hypervisor.vmware.mo.VmwareHostType;
--import com.cloud.utils.ssh.SshHelper;
  import com.cloud.hypervisor.vmware.util.VmwareContext;
  import com.cloud.network.CiscoNexusVSMDeviceVO;
- import com.cloud.network.NetworkManager;
+ import com.cloud.network.NetworkModel;
  import com.cloud.network.dao.CiscoNexusVSMDeviceDao;
  import com.cloud.org.Cluster.ClusterType;
  import com.cloud.secstorage.CommandExecLogDao;
  import com.cloud.serializer.GsonHelper;
  import com.cloud.server.ConfigurationServer;
++import com.cloud.storage.JavaStorageLayer;
  import com.cloud.storage.StorageLayer;
  import com.cloud.storage.secondary.SecondaryStorageVmManager;
  import com.cloud.utils.FileUtil;
  import com.cloud.utils.NumbersUtil;
  import com.cloud.utils.Pair;
- 
 -import com.cloud.utils.component.ComponentLocator;
 -import com.cloud.utils.component.Inject;
  import com.cloud.utils.component.Manager;
  import com.cloud.utils.concurrency.NamedThreadFactory;
  import com.cloud.utils.db.DB;
  import com.cloud.utils.db.GlobalLock;
  import com.cloud.utils.exception.CloudRuntimeException;
  import com.cloud.utils.script.Script;
++import com.cloud.utils.ssh.SshHelper;
  import com.cloud.vm.DomainRouterVO;
  import com.google.gson.Gson;
  import com.vmware.apputils.vim25.ServiceUtil;
@@@ -120,7 -119,7 +116,6 @@@ public class VmwareManagerImpl implemen
      @Inject ClusterDetailsDao _clusterDetailsDao;
      @Inject CommandExecLogDao _cmdExecLogDao;
      @Inject ClusterManager _clusterMgr;
--    @Inject CheckPointManager _checkPointMgr;
      @Inject SecondaryStorageVmManager _ssvmMgr;
      @Inject CiscoNexusVSMDeviceDao _nexusDao;
      @Inject ClusterVSMMapDao _vsmMapDao;
@@@ -142,15 -141,15 +137,15 @@@
      int _additionalPortRangeSize;
      int _maxHostsPerCluster;
      int _routerExtraPublicNics = 2;
--    
++
      String _cpuOverprovisioningFactor = "1";
      String _reserveCpu = "false";
--    
++
      String _memOverprovisioningFactor = "1";
      String _reserveMem = "false";
--    
++
      String _rootDiskController = DiskControllerType.ide.toString();
--    
++
      Map<String, String> _storageMounts = new HashMap<String, String>();
  
      Random _rand = new Random(System.currentTimeMillis());
@@@ -199,30 -204,30 +194,19 @@@
  
          _storage = (StorageLayer)params.get(StorageLayer.InstanceConfigKey);
          if (_storage == null) {
--            value = (String)params.get(StorageLayer.ClassConfigKey);
--            if (value == null) {
--                value = "com.cloud.storage.JavaStorageLayer";
--            }
--
--            try {
--                Class<?> clazz = Class.forName(value);
--                _storage = (StorageLayer)ComponentLocator.inject(clazz);
--                _storage.configure("StorageLayer", params);
--            } catch (ClassNotFoundException e) {
--                throw new ConfigurationException("Unable to find class " + value);
--            }
++            _storage = new JavaStorageLayer();
++            _storage.configure("StorageLayer", params);
          }
--        
 -        value = configDao.getValue(Config.VmwareUseNexusVSwitch.key());
 +        value = _configDao.getValue(Config.VmwareUseNexusVSwitch.key());
          if(value == null) {
--        	_nexusVSwitchActive = false;
++            _nexusVSwitchActive = false;
          }
          else
          {
--        	_nexusVSwitchActive = Boolean.parseBoolean(value);
++            _nexusVSwitchActive = Boolean.parseBoolean(value);
          }
  
 -        _privateNetworkVSwitchName = configDao.getValue(Config.VmwarePrivateNetworkVSwitch.key());
 +        _privateNetworkVSwitchName = _configDao.getValue(Config.VmwarePrivateNetworkVSwitch.key());
  
          if (_privateNetworkVSwitchName == null) {
              if (_nexusVSwitchActive) {
@@@ -256,57 -261,57 +240,57 @@@
          if(_serviceConsoleName == null) {
              _serviceConsoleName = "Service Console";
          }
--        
 -        _managemetPortGroupName = configDao.getValue(Config.VmwareManagementPortGroup.key());
++
 +        _managemetPortGroupName = _configDao.getValue(Config.VmwareManagementPortGroup.key());
          if(_managemetPortGroupName == null) {
--        	_managemetPortGroupName = "Management Network";
++            _managemetPortGroupName = "Management Network";
          }
--        
 -        _defaultSystemVmNicAdapterType = configDao.getValue(Config.VmwareSystemVmNicDeviceType.key());
++
 +        _defaultSystemVmNicAdapterType = _configDao.getValue(Config.VmwareSystemVmNicDeviceType.key());
          if(_defaultSystemVmNicAdapterType == null)
              _defaultSystemVmNicAdapterType = VirtualEthernetCardType.E1000.toString();
--        
 -        _additionalPortRangeStart = NumbersUtil.parseInt(configDao.getValue(Config.VmwareAdditionalVncPortRangeStart.key()), 59000);
++
 +        _additionalPortRangeStart = NumbersUtil.parseInt(_configDao.getValue(Config.VmwareAdditionalVncPortRangeStart.key()), 59000);
          if(_additionalPortRangeStart > 65535) {
--        	s_logger.warn("Invalid port range start port (" + _additionalPortRangeStart + ") for additional VNC port allocation, reset it to default start port 59000");
--        	_additionalPortRangeStart = 59000;
++            s_logger.warn("Invalid port range start port (" + _additionalPortRangeStart + ") for additional VNC port allocation, reset it to default start port 59000");
++            _additionalPortRangeStart = 59000;
          }
--        
 -        _additionalPortRangeSize = NumbersUtil.parseInt(configDao.getValue(Config.VmwareAdditionalVncPortRangeSize.key()), 1000);
++
 +        _additionalPortRangeSize = NumbersUtil.parseInt(_configDao.getValue(Config.VmwareAdditionalVncPortRangeSize.key()), 1000);
          if(_additionalPortRangeSize < 0 || _additionalPortRangeStart + _additionalPortRangeSize > 65535) {
--        	s_logger.warn("Invalid port range size (" + _additionalPortRangeSize + " for range starts at " + _additionalPortRangeStart);
--        	_additionalPortRangeSize = Math.min(1000, 65535 - _additionalPortRangeStart);
 -        }
 -        
 -        _routerExtraPublicNics = NumbersUtil.parseInt(configDao.getValue(Config.RouterExtraPublicNics.key()), 2);
 -        
 -        _maxHostsPerCluster = NumbersUtil.parseInt(configDao.getValue(Config.VmwarePerClusterHostMax.key()), VmwareManager.MAX_HOSTS_PER_CLUSTER);
 -        _cpuOverprovisioningFactor = configDao.getValue(Config.CPUOverprovisioningFactor.key());
++            s_logger.warn("Invalid port range size (" + _additionalPortRangeSize + " for range starts at " + _additionalPortRangeStart);
++            _additionalPortRangeSize = Math.min(1000, 65535 - _additionalPortRangeStart);
 +        }
-         
++
 +        _routerExtraPublicNics = NumbersUtil.parseInt(_configDao.getValue(Config.RouterExtraPublicNics.key()), 2);
-         
++
 +        _maxHostsPerCluster = NumbersUtil.parseInt(_configDao.getValue(Config.VmwarePerClusterHostMax.key()), VmwareManager.MAX_HOSTS_PER_CLUSTER);
 +        _cpuOverprovisioningFactor = _configDao.getValue(Config.CPUOverprovisioningFactor.key());
          if(_cpuOverprovisioningFactor == null || _cpuOverprovisioningFactor.isEmpty())
--        	_cpuOverprovisioningFactor = "1";
++            _cpuOverprovisioningFactor = "1";
  
 -        _memOverprovisioningFactor = configDao.getValue(Config.MemOverprovisioningFactor.key());
 +        _memOverprovisioningFactor = _configDao.getValue(Config.MemOverprovisioningFactor.key());
          if(_memOverprovisioningFactor == null || _memOverprovisioningFactor.isEmpty())
--        	_memOverprovisioningFactor = "1";
--        
 -        _reserveCpu = configDao.getValue(Config.VmwareReserveCpu.key());
++            _memOverprovisioningFactor = "1";
++
 +        _reserveCpu = _configDao.getValue(Config.VmwareReserveCpu.key());
          if(_reserveCpu == null || _reserveCpu.isEmpty())
--        	_reserveCpu = "false";
 -        _reserveMem = configDao.getValue(Config.VmwareReserveMem.key());
++            _reserveCpu = "false";
 +        _reserveMem = _configDao.getValue(Config.VmwareReserveMem.key());
          if(_reserveMem == null || _reserveMem.isEmpty())
--        	_reserveMem = "false";
--        
 -        _recycleHungWorker = configDao.getValue(Config.VmwareRecycleHungWorker.key());
++            _reserveMem = "false";
++
 +        _recycleHungWorker = _configDao.getValue(Config.VmwareRecycleHungWorker.key());
          if(_recycleHungWorker == null || _recycleHungWorker.isEmpty())
              _recycleHungWorker = "false";
--        
 -        _rootDiskController = configDao.getValue(Config.VmwareRootDiskControllerType.key());
++
 +        _rootDiskController = _configDao.getValue(Config.VmwareRootDiskControllerType.key());
          if(_rootDiskController == null || _rootDiskController.isEmpty())
--        	_rootDiskController = DiskControllerType.ide.toString();
--        
--    	s_logger.info("Additional VNC port allocation range is settled at " + _additionalPortRangeStart + " to " + (_additionalPortRangeStart + _additionalPortRangeSize));
++            _rootDiskController = DiskControllerType.ide.toString();
++
++        s_logger.info("Additional VNC port allocation range is settled at " + _additionalPortRangeStart + " to " + (_additionalPortRangeStart + _additionalPortRangeSize));
  
 -        value = configDao.getValue("vmware.host.scan.interval");
 +        value = _configDao.getValue("vmware.host.scan.interval");
          _hostScanInterval = NumbersUtil.parseLong(value, DEFAULT_HOST_SCAN_INTERVAL);
          s_logger.info("VmwareManagerImpl config - vmware.host.scan.interval: " + _hostScanInterval);
  
@@@ -344,6 -352,6 +328,7 @@@
          return _name;
      }
  
++    @Override
      public boolean getNexusVSwitchGlobalParameter() {
          return _nexusVSwitchActive;
      }
@@@ -352,22 -360,22 +337,22 @@@
      public String composeWorkerName() {
          return UUID.randomUUID().toString().replace("-", "");
      }
--    
++
      @Override
      public String getPrivateVSwitchName(long dcId, HypervisorType hypervisorType) {
          return _netMgr.getDefaultManagementTrafficLabel(dcId, hypervisorType);
      }
--    
++
      @Override
      public String getPublicVSwitchName(long dcId, HypervisorType hypervisorType) {
          return _netMgr.getDefaultPublicTrafficLabel(dcId, hypervisorType);
      }
--    
++
      @Override
      public String getGuestVSwitchName(long dcId, HypervisorType hypervisorType) {
          return _netMgr.getDefaultGuestTrafficLabel(dcId, hypervisorType);
      }
--    
++
      @Override
      public List<ManagedObjectReference> addHostToPodCluster(VmwareContext serviceContext, long dcId, Long podId, Long clusterId,
              String hostInventoryPath) throws Exception {
@@@ -391,23 -399,23 +376,23 @@@
                  HostMO hostMo = new HostMO(serviceContext, hosts[0]);
                  HostFirewallSystemMO firewallMo = hostMo.getHostFirewallSystemMO();
                  if(firewallMo != null) {
--            		if(hostMo.getHostType() == VmwareHostType.ESX) {
--            		    
--	                    firewallMo.enableRuleset("vncServer");
--	                    firewallMo.refreshFirewall();
--            		}
++                    if(hostMo.getHostType() == VmwareHostType.ESX) {
++
++                        firewallMo.enableRuleset("vncServer");
++                        firewallMo.refreshFirewall();
++                    }
                  }
  
                  // prepare at least one network on the vswitch to enable OVF importing
                  String vlanId = null;
                  if(privateTrafficLabel != null) {
--                	String[] tokens = privateTrafficLabel.split(",");
--                	if(tokens.length == 2)
--                		vlanId = tokens[1];
++                    String[] tokens = privateTrafficLabel.split(",");
++                    if(tokens.length == 2)
++                        vlanId = tokens[1];
                  }
  
                  if(!_nexusVSwitchActive) {
--                	HypervisorHostHelper.prepareNetwork(_privateNetworkVSwitchName, "cloud.private", hostMo, vlanId, null, null, 180000, false);
++                    HypervisorHostHelper.prepareNetwork(_privateNetworkVSwitchName, "cloud.private", hostMo, vlanId, null, null, 180000, false);
                  }
                  else {
                      s_logger.info("Preparing Network on " + privateTrafficLabel);
@@@ -418,22 -426,22 +403,22 @@@
              } else if(mor.getType().equals("ClusterComputeResource")) {
                  ManagedObjectReference[] hosts = (ManagedObjectReference[])serviceContext.getServiceUtil().getDynamicProperty(mor, "host");
                  assert(hosts != null);
--                
++
                  if(hosts.length > _maxHostsPerCluster) {
--                	String msg = "vCenter cluster size is too big (current configured cluster size: " + _maxHostsPerCluster + ")";
--                	s_logger.error(msg);
--                	throw new DiscoveredWithErrorException(msg);
++                    String msg = "vCenter cluster size is too big (current configured cluster size: " + _maxHostsPerCluster + ")";
++                    s_logger.error(msg);
++                    throw new DiscoveredWithErrorException(msg);
                  }
--                
++
                  for(ManagedObjectReference morHost: hosts) {
                      // For ESX host, we need to enable host firewall to allow VNC access
                      HostMO hostMo = new HostMO(serviceContext, morHost);
                      HostFirewallSystemMO firewallMo = hostMo.getHostFirewallSystemMO();
                      if(firewallMo != null) {
--                		if(hostMo.getHostType() == VmwareHostType.ESX) {
--	                        firewallMo.enableRuleset("vncServer");
--	                        firewallMo.refreshFirewall();
--                		}
++                        if(hostMo.getHostType() == VmwareHostType.ESX) {
++                            firewallMo.enableRuleset("vncServer");
++                            firewallMo.refreshFirewall();
++                        }
                      }
  
                      String vlanId = null;
@@@ -442,12 -450,12 +427,12 @@@
                          if(tokens.length == 2)
                              vlanId = tokens[1];
                      }
--                    
--                    
++
++
                      s_logger.info("Calling prepareNetwork : " + hostMo.getContext().toString());
                      // prepare at least one network on the vswitch to enable OVF importing
                      if(!_nexusVSwitchActive) {
--                    	HypervisorHostHelper.prepareNetwork(_privateNetworkVSwitchName, "cloud.private", hostMo, vlanId, null, null, 180000, false);
++                        HypervisorHostHelper.prepareNetwork(_privateNetworkVSwitchName, "cloud.private", hostMo, vlanId, null, null, 180000, false);
                      }
                      else {
                          s_logger.info("Preparing Network on " + privateTrafficLabel);
@@@ -461,10 -469,10 +446,10 @@@
                  HostMO hostMo = new HostMO(serviceContext, mor);
                  HostFirewallSystemMO firewallMo = hostMo.getHostFirewallSystemMO();
                  if(firewallMo != null) {
--            		if(hostMo.getHostType() == VmwareHostType.ESX) {
--	                    firewallMo.enableRuleset("vncServer");
--	                    firewallMo.refreshFirewall();
--            		}
++                    if(hostMo.getHostType() == VmwareHostType.ESX) {
++                        firewallMo.enableRuleset("vncServer");
++                        firewallMo.refreshFirewall();
++                    }
                  }
  
                  String vlanId = null;
@@@ -476,7 -484,7 +461,7 @@@
  
                  // prepare at least one network on the vswitch to enable OVF importing
                  if(!_nexusVSwitchActive) {
--                	HypervisorHostHelper.prepareNetwork(_privateNetworkVSwitchName, "cloud.private", hostMo, vlanId, null, null, 180000, false);
++                    HypervisorHostHelper.prepareNetwork(_privateNetworkVSwitchName, "cloud.private", hostMo, vlanId, null, null, 180000, false);
                  }
                  else {
                      s_logger.info("Preparing Network on " + privateTrafficLabel);
@@@ -534,28 -542,28 +519,30 @@@
  
      @Override
      public String getSecondaryStorageStoreUrl(long dcId) {
--    	List<HostVO> secStorageHosts = _ssvmMgr.listSecondaryStorageHostsInOneZone(dcId);
--    	if(secStorageHosts.size() > 0)
--    		return secStorageHosts.get(0).getStorageUrl();
--    	
++        List<HostVO> secStorageHosts = _ssvmMgr.listSecondaryStorageHostsInOneZone(dcId);
++        if(secStorageHosts.size() > 0)
++            return secStorageHosts.get(0).getStorageUrl();
++
          return null;
      }
  
--	public String getServiceConsolePortGroupName() {
--		return _serviceConsoleName;
--	}
--	
--	public String getManagementPortGroupName() {
--		return _managemetPortGroupName;
--	}
--    
++    @Override
++    public String getServiceConsolePortGroupName() {
++        return _serviceConsoleName;
++    }
++
++    @Override
++    public String getManagementPortGroupName() {
++        return _managemetPortGroupName;
++    }
++
      @Override
      public String getManagementPortGroupByHost(HostMO hostMo) throws Exception {
--    	if(hostMo.getHostType() == VmwareHostType.ESXi)
--    		return  this._managemetPortGroupName;
++        if(hostMo.getHostType() == VmwareHostType.ESXi)
++            return  this._managemetPortGroupName;
          return this._serviceConsoleName;
      }
--    
++
      @Override
      public void setupResourceStartupParams(Map<String, Object> params) {
          params.put("private.network.vswitch.name", _privateNetworkVSwitchName);
@@@ -577,20 -585,20 +564,10 @@@
          return _storageMgr;
      }
  
--    
--    @Override
--	public long pushCleanupCheckpoint(String hostGuid, String vmName) {
--        return _checkPointMgr.pushCheckPoint(new VmwareCleanupMaid(hostGuid, vmName));
--    }
--    
--    @Override
--	public void popCleanupCheckpoint(long checkpoint) {
--    	_checkPointMgr.popCheckPoint(checkpoint);
--    }
--    
++
      @Override
--	public void gcLeftOverVMs(VmwareContext context) {
--    	VmwareCleanupMaid.gcLeftOverVMs(context);
++    public void gcLeftOverVMs(VmwareContext context) {
++        VmwareCleanupMaid.gcLeftOverVMs(context);
      }
  
      @Override
@@@ -615,19 -623,19 +592,19 @@@
                      if(!destIso.exists()) {
                          s_logger.info("Inject SSH key pairs before copying systemvm.iso into secondary storage");
                          _configServer.updateKeyPairs();
--                        
--	                    try {
--	                        FileUtil.copyfile(srcIso, destIso);
--	                    } catch(IOException e) {
--	                    	s_logger.error("Unexpected exception ", e);
--	                    	
--	                        String msg = "Unable to copy systemvm ISO on secondary storage. src location: " + srcIso.toString() + ", dest location: " + destIso;
--	                        s_logger.error(msg);
--	                        throw new CloudRuntimeException(msg);
--	                    }
++
++                        try {
++                            FileUtil.copyfile(srcIso, destIso);
++                        } catch(IOException e) {
++                            s_logger.error("Unexpected exception ", e);
++
++                            String msg = "Unable to copy systemvm ISO on secondary storage. src location: " + srcIso.toString() + ", dest location: " + destIso;
++                            s_logger.error(msg);
++                            throw new CloudRuntimeException(msg);
++                        }
                      } else {
--                    	if(s_logger.isTraceEnabled())
--                    		s_logger.trace("SystemVM ISO file " + destIso.getPath() + " already exists");
++                        if(s_logger.isTraceEnabled())
++                            s_logger.trace("SystemVM ISO file " + destIso.getPath() + " already exists");
                      }
                  } finally {
                      lock.unlock();
@@@ -637,22 -645,22 +614,22 @@@
              lock.releaseRef();
          }
      }
--   
++
      @Override
      public String getSystemVMIsoFileNameOnDatastore() {
--        String version = ComponentLocator.class.getPackage().getImplementationVersion();
++        String version = this.getClass().getPackage().getImplementationVersion();
          String fileName = "systemvm-" + version + ".iso";
          return fileName.replace(':', '-');
      }
--    
++
      @Override
      public String getSystemVMDefaultNicAdapterType() {
          return this._defaultSystemVmNicAdapterType;
      }
--    
++
      private File getSystemVMPatchIsoFile() {
          // locate systemvm.iso
--        URL url = ComponentLocator.class.getProtectionDomain().getCodeSource().getLocation();
++        URL url = this.getClass().getProtectionDomain().getCodeSource().getLocation();
          File file = new File(url.getFile());
          File isoFile = new File(file.getParent() + "/vms/systemvm.iso");
          if (!isoFile.exists()) {
@@@ -666,7 -674,7 +643,7 @@@
  
      @Override
      public File getSystemVMKeyFile() {
--        URL url = ComponentLocator.class.getProtectionDomain().getCodeSource().getLocation();
++        URL url = this.getClass().getProtectionDomain().getCodeSource().getLocation();
          File file = new File(url.getFile());
  
          File keyFile = new File(file.getParent(), "/scripts/vm/systemvm/id_rsa.cloud");
@@@ -853,16 -861,16 +830,6 @@@
  
                      _cmdExecLogDao.expunge(execId);
                  }
--
--                String checkPointIdStr = answer.getContextParam("checkpoint");
--                if(checkPointIdStr != null) {
--                    _checkPointMgr.popCheckPoint(Long.parseLong(checkPointIdStr));
--                }
--                
--                checkPointIdStr = answer.getContextParam("checkpoint2");
--                if(checkPointIdStr != null) {
--                    _checkPointMgr.popCheckPoint(Long.parseLong(checkPointIdStr));
--                }
              }
          }
  
@@@ -889,9 -897,9 +856,9 @@@
              }
          }
      }
--    
++
      protected final int DEFAULT_DOMR_SSHPORT = 3922;
--    
++
      protected boolean shutdownRouterVM(DomainRouterVO router) {
          if (s_logger.isDebugEnabled()) {
              s_logger.debug("Try to shutdown router VM " + router.getInstanceName() + " directly.");
@@@ -935,31 -943,31 +902,31 @@@
      public boolean processTimeout(long agentId, long seq) {
          return false;
      }
--    
++
      @Override
      public boolean beginExclusiveOperation(int timeOutSeconds) {
          return _exclusiveOpLock.lock(timeOutSeconds);
      }
--    
++
      @Override
      public void endExclusiveOperation() {
          _exclusiveOpLock.unlock();
      }
--    
++
      @Override
--	public Pair<Integer, Integer> getAddiionalVncPortRange() {
--    	return new Pair<Integer, Integer>(_additionalPortRangeStart, _additionalPortRangeSize);
++    public Pair<Integer, Integer> getAddiionalVncPortRange() {
++        return new Pair<Integer, Integer>(_additionalPortRangeStart, _additionalPortRangeSize);
      }
--    
++
      @Override
      public int getMaxHostsPerCluster() {
--    	return this._maxHostsPerCluster;
++        return this._maxHostsPerCluster;
      }
--    
++
      @Override
--	public int getRouterExtraPublicNics() {
--		return this._routerExtraPublicNics;
--	}
++    public int getRouterExtraPublicNics() {
++        return this._routerExtraPublicNics;
++    }
  
      @Override
      public Map<String, String> getNexusVSMCredentialsByClusterId(Long clusterId) {