You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by ed...@apache.org on 2012/07/31 19:39:17 UTC

git commit: Patch fixes file names and imports wherever used, in files introduced in 73be77a4c1877ae7e3613c7562d562ad96cde7ee I've renamed discover to discoverer to fix the issue. My ant debug fails with: [java] ERROR [utils.component.ComponentLocat

Updated Branches:
  refs/heads/master 721d3ef3d -> 9a9c96df6


Patch fixes file names and imports wherever used, in files introduced in
73be77a4c1877ae7e3613c7562d562ad96cde7ee
I've renamed discover to discoverer to fix the issue. My ant debug fails
with:
     [java] ERROR [utils.component.ComponentLocator] (main:) Unable to
load configuration for management-server from components.xml
     [java] com.cloud.utils.exception.CloudRuntimeException: Unable to
find class: com.cloud.hypervisor.kvm.discoverer.KvmServerDiscoverer

RB: https://reviews.apache.org/r/6239/
Send-by: rohit.yadav@citrix.com


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

Branch: refs/heads/master
Commit: 9a9c96df6472546e2e78b799601ed51e14978b43
Parents: 721d3ef
Author: Edison Su <su...@gmail.com>
Authored: Tue Jul 31 10:38:11 2012 -0700
Committer: Edison Su <su...@gmail.com>
Committed: Tue Jul 31 10:38:11 2012 -0700

----------------------------------------------------------------------
 .../com/cloud/agent/manager/AgentManagerImpl.java  |    2 +-
 .../kvm/discover/KvmDummyResourceBase.java         |   88 ----
 .../kvm/discover/KvmServerDiscoverer.java          |  395 ---------------
 .../kvm/discoverer/KvmDummyResourceBase.java       |   88 ++++
 .../kvm/discoverer/KvmServerDiscoverer.java        |  395 +++++++++++++++
 .../com/cloud/resource/ResourceManagerImpl.java    |    2 +-
 6 files changed, 485 insertions(+), 485 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/9a9c96df/server/src/com/cloud/agent/manager/AgentManagerImpl.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/agent/manager/AgentManagerImpl.java b/server/src/com/cloud/agent/manager/AgentManagerImpl.java
index 9fb9027..62e8acb 100755
--- a/server/src/com/cloud/agent/manager/AgentManagerImpl.java
+++ b/server/src/com/cloud/agent/manager/AgentManagerImpl.java
@@ -88,7 +88,7 @@ import com.cloud.host.dao.HostDao;
 import com.cloud.host.dao.HostTagsDao;
 import com.cloud.hypervisor.Hypervisor.HypervisorType;
 import com.cloud.hypervisor.HypervisorGuruManager;
-import com.cloud.hypervisor.kvm.discover.KvmDummyResourceBase;
+import com.cloud.hypervisor.kvm.discoverer.KvmDummyResourceBase;
 import com.cloud.network.dao.IPAddressDao;
 import com.cloud.resource.Discoverer;
 import com.cloud.resource.ResourceManager;

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/9a9c96df/server/src/com/cloud/hypervisor/kvm/discover/KvmDummyResourceBase.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/hypervisor/kvm/discover/KvmDummyResourceBase.java b/server/src/com/cloud/hypervisor/kvm/discover/KvmDummyResourceBase.java
deleted file mode 100644
index 4069f55..0000000
--- a/server/src/com/cloud/hypervisor/kvm/discover/KvmDummyResourceBase.java
+++ /dev/null
@@ -1,88 +0,0 @@
-// Licensed to the Apache Software Foundation (ASF) under one
-// or more contributor license agreements.  See the NOTICE file
-// distributed with this work for additional information
-// regarding copyright ownership.  The ASF licenses this file
-// to you under the Apache License, Version 2.0 (the
-// "License"); you may not use this file except in compliance
-// with the License.  You may obtain a copy of the License at
-//
-//   http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-package com.cloud.hypervisor.kvm.discover;
-
-import java.util.HashMap;
-import java.util.Map;
-
-import javax.naming.ConfigurationException;
-
-import com.cloud.agent.api.Answer;
-import com.cloud.agent.api.Command;
-import com.cloud.agent.api.PingCommand;
-import com.cloud.agent.api.StartupCommand;
-import com.cloud.agent.api.StartupRoutingCommand;
-import com.cloud.agent.api.StartupRoutingCommand.VmState;
-import com.cloud.host.Host.Type;
-import com.cloud.hypervisor.Hypervisor;
-import com.cloud.resource.ServerResource;
-import com.cloud.resource.ServerResourceBase;
-
-public class KvmDummyResourceBase extends ServerResourceBase implements ServerResource {
-	private String _zoneId;
-	private String _podId;
-	private String _clusterId;
-	private String _guid;
-	private String _agentIp;
-	@Override
-	public Type getType() {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	@Override
-	public StartupCommand[] initialize() {
-		StartupRoutingCommand cmd = new StartupRoutingCommand(0, 0, 0, 0, null, Hypervisor.HypervisorType.KVM, new HashMap<String, String>(), new HashMap<String, VmState>());
-		cmd.setDataCenter(_zoneId);
-		cmd.setPod(_podId);
-		cmd.setCluster(_clusterId);
-		cmd.setGuid(_guid);
-		cmd.setName(_agentIp);
-		cmd.setPrivateIpAddress(_agentIp);
-		cmd.setStorageIpAddress(_agentIp);
-		cmd.setVersion(KvmDummyResourceBase.class.getPackage().getImplementationVersion());
-		return new StartupCommand[] { cmd };
-	}
-
-	@Override
-	public PingCommand getCurrentStatus(long id) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	@Override
-	public Answer executeRequest(Command cmd) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	@Override
-	protected String getDefaultScriptsDir() {
-		// TODO Auto-generated method stub
-		return null;
-	}
-	
-	@Override
-	public boolean configure(final String name, final Map<String, Object> params) throws ConfigurationException {
-		_zoneId = (String)params.get("zone");
-		_podId = (String)params.get("pod");
-		_clusterId = (String)params.get("cluster");
-		_guid = (String)params.get("guid");
-		_agentIp = (String)params.get("agentIp");
-		return true;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/9a9c96df/server/src/com/cloud/hypervisor/kvm/discover/KvmServerDiscoverer.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/hypervisor/kvm/discover/KvmServerDiscoverer.java b/server/src/com/cloud/hypervisor/kvm/discover/KvmServerDiscoverer.java
deleted file mode 100755
index 7b2492b..0000000
--- a/server/src/com/cloud/hypervisor/kvm/discover/KvmServerDiscoverer.java
+++ /dev/null
@@ -1,395 +0,0 @@
-// Licensed to the Apache Software Foundation (ASF) under one
-// or more contributor license agreements.  See the NOTICE file
-// distributed with this work for additional information
-// regarding copyright ownership.  The ASF licenses this file
-// to you under the Apache License, Version 2.0 (the
-// "License"); you may not use this file except in compliance
-// with the License.  You may obtain a copy of the License at
-//
-//   http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-package com.cloud.hypervisor.kvm.discover;
-
-import java.net.InetAddress;
-import java.net.URI;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.UUID;
-
-import javax.ejb.Local;
-import javax.naming.ConfigurationException;
-
-import org.apache.log4j.Logger;
-
-import com.cloud.agent.AgentManager;
-import com.cloud.agent.Listener;
-import com.cloud.agent.api.AgentControlAnswer;
-import com.cloud.agent.api.AgentControlCommand;
-import com.cloud.agent.api.Answer;
-import com.cloud.agent.api.Command;
-import com.cloud.agent.api.ShutdownCommand;
-import com.cloud.agent.api.StartupCommand;
-import com.cloud.agent.api.StartupRoutingCommand;
-import com.cloud.configuration.Config;
-import com.cloud.configuration.dao.ConfigurationDao;
-import com.cloud.dc.ClusterVO;
-import com.cloud.dc.dao.ClusterDao;
-import com.cloud.exception.AgentUnavailableException;
-import com.cloud.exception.DiscoveredWithErrorException;
-import com.cloud.exception.DiscoveryException;
-import com.cloud.exception.OperationTimedoutException;
-import com.cloud.host.Host;
-import com.cloud.host.HostVO;
-import com.cloud.host.Status;
-import com.cloud.host.dao.HostDao;
-import com.cloud.hypervisor.Hypervisor;
-import com.cloud.hypervisor.Hypervisor.HypervisorType;
-import com.cloud.hypervisor.kvm.discover.KvmDummyResourceBase;
-import com.cloud.network.NetworkManager;
-import com.cloud.network.PhysicalNetworkSetupInfo;
-import com.cloud.resource.Discoverer;
-import com.cloud.resource.DiscovererBase;
-import com.cloud.resource.ResourceManager;
-import com.cloud.resource.ResourceStateAdapter;
-import com.cloud.resource.ServerResource;
-import com.cloud.resource.UnableDeleteHostException;
-import com.cloud.utils.component.ComponentLocator;
-import com.cloud.utils.component.Inject;
-import com.cloud.utils.script.Script;
-import com.cloud.utils.ssh.SSHCmdHelper;
-
-@Local(value=Discoverer.class)
-public class KvmServerDiscoverer extends DiscovererBase implements Discoverer,
-		Listener, ResourceStateAdapter {
-	 private static final Logger s_logger = Logger.getLogger(KvmServerDiscoverer.class);
-	 private String _setupAgentPath;
-	 private ConfigurationDao _configDao;
-	 private String _hostIp;
-	 private int _waitTime = 5; /*wait for 5 minutes*/
-	 private String _kvmPrivateNic;
-	 private String _kvmPublicNic;
-	 private String _kvmGuestNic;
-	 @Inject HostDao _hostDao = null;
-	 @Inject ClusterDao _clusterDao;
-	 @Inject ResourceManager _resourceMgr;
-	 @Inject AgentManager _agentMgr;
-	 @Inject NetworkManager _networkMgr;
-	 
-	@Override
-	public boolean processAnswers(long agentId, long seq, Answer[] answers) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public boolean processCommands(long agentId, long seq, Command[] commands) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public AgentControlAnswer processControlCommand(long agentId,
-			AgentControlCommand cmd) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	@Override
-	public void processConnect(HostVO host, StartupCommand cmd, boolean forRebalance) {
-	}
-
-	@Override
-	public boolean processDisconnect(long agentId, Status state) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public boolean isRecurring() {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public int getTimeout() {
-		// TODO Auto-generated method stub
-		return 0;
-	}
-
-	@Override
-	public boolean processTimeout(long agentId, long seq) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public Map<? extends ServerResource, Map<String, String>> find(long dcId,
-			Long podId, Long clusterId, URI uri, String username,
-			String password, List<String> hostTags) throws DiscoveryException {
-		
-        ClusterVO cluster = _clusterDao.findById(clusterId);
-        if(cluster == null || cluster.getHypervisorType() != HypervisorType.KVM) {
-        	if(s_logger.isInfoEnabled())
-        		s_logger.info("invalid cluster id or cluster is not for KVM hypervisors"); 
-    		return null;
-        }
-		
-		 Map<KvmDummyResourceBase, Map<String, String>> resources = new HashMap<KvmDummyResourceBase, Map<String, String>>();
-		 Map<String, String> details = new HashMap<String, String>();
-		if (!uri.getScheme().equals("http")) {
-            String msg = "urlString is not http so we're not taking care of the discovery for this: " + uri;
-            s_logger.debug(msg);
-            return null;
-		}
-		com.trilead.ssh2.Connection sshConnection = null;
-		String agentIp = null;
-		try {
-			
-			String hostname = uri.getHost();
-			InetAddress ia = InetAddress.getByName(hostname);
-			agentIp = ia.getHostAddress();
-			String guid = UUID.nameUUIDFromBytes(agentIp.getBytes()).toString();
-			String guidWithTail = guid + "-LibvirtComputingResource";/*tail added by agent.java*/
-			if (_resourceMgr.findHostByGuid(guidWithTail) != null) {
-				s_logger.debug("Skipping " + agentIp + " because " + guidWithTail + " is already in the database.");
-				return null;
-			}       
-			
-			sshConnection = new com.trilead.ssh2.Connection(agentIp, 22);
-
-			sshConnection.connect(null, 60000, 60000);
-			if (!sshConnection.authenticateWithPassword(username, password)) {
-				s_logger.debug("Failed to authenticate");
-				throw new DiscoveredWithErrorException("Authentication error");
-			}
-			
-			if (!SSHCmdHelper.sshExecuteCmd(sshConnection, "lsmod|grep kvm", 3)) {
-				s_logger.debug("It's not a KVM enabled machine");
-				return null;
-			}
-			
-			List <PhysicalNetworkSetupInfo> netInfos = _networkMgr.getPhysicalNetworkInfo(dcId, HypervisorType.KVM);
-			String kvmPrivateNic = _kvmPrivateNic;
-			String kvmPublicNic = _kvmPublicNic;
-			String kvmGuestNic = _kvmGuestNic;
-
-			for (PhysicalNetworkSetupInfo info : netInfos) {
-			    if (info.getPrivateNetworkName() != null) {
-			        kvmPrivateNic = info.getPrivateNetworkName();
-			    }
-			    if (info.getPublicNetworkName() != null) {
-			        kvmPublicNic = info.getPublicNetworkName();
-			    }
-			    if (info.getGuestNetworkName() != null) {
-			        kvmGuestNic = info.getGuestNetworkName();
-			    }
-			}
-
-                        String parameters = " -m " + _hostIp + " -z " + dcId + " -p " + podId + " -c " + clusterId + " -g " + guid + " -a";
-			
-			if (kvmPublicNic != null) {
-				parameters += " --pubNic=" + kvmPublicNic;
-			}
-			
-			if (kvmPrivateNic != null) {
-				parameters += " --prvNic=" + kvmPrivateNic;
-			}
-			
-			if (kvmGuestNic != null) {
-			    parameters += " --guestNic=" + kvmGuestNic;
-			}
-		
-			SSHCmdHelper.sshExecuteCmd(sshConnection, "cloud-setup-agent " + parameters, 3);
-			
-			KvmDummyResourceBase kvmResource = new KvmDummyResourceBase();
-			Map<String, Object> params = new HashMap<String, Object>();
-						
-			params.put("zone", Long.toString(dcId));
-			params.put("pod", Long.toString(podId));
-			params.put("cluster",  Long.toString(clusterId));
-			params.put("guid", guid); 
-			params.put("agentIp", agentIp);
-			kvmResource.configure("kvm agent", params);
-			resources.put(kvmResource, details);
-			
-			HostVO connectedHost = waitForHostConnect(dcId, podId, clusterId, guidWithTail);
-			if (connectedHost == null)
-				return null;
-			
-			details.put("guid", guidWithTail);
-			
-			 // place a place holder guid derived from cluster ID
-			if (cluster.getGuid() == null) {
-			    cluster.setGuid(UUID.nameUUIDFromBytes(String.valueOf(clusterId).getBytes()).toString());
-			    _clusterDao.update(clusterId, cluster);
-			}
-			
-			//save user name and password
-			_hostDao.loadDetails(connectedHost);
-			Map<String, String> hostDetails = connectedHost.getDetails();
-			hostDetails.put("password", password);
-			hostDetails.put("username", username);
-			_hostDao.saveDetails(connectedHost);
-			return resources;
-		} catch (DiscoveredWithErrorException e){ 
-			throw e;
-		}catch (Exception e) {
-			String msg = " can't setup agent, due to " + e.toString() + " - " + e.getMessage();
-			s_logger.warn(msg);
-		} finally {
-			if (sshConnection != null)
-				sshConnection.close();
-		}
-		
-		return null;
-	}
-
-	private HostVO waitForHostConnect(long dcId, long podId, long clusterId, String guid) {
-		for (int i = 0; i < _waitTime *2; i++) {
-			List<HostVO> hosts = _resourceMgr.listAllUpAndEnabledHosts(Host.Type.Routing, clusterId, podId, dcId);
-			for (HostVO host : hosts) {
-				if (host.getGuid().equalsIgnoreCase(guid)) {
-					return host;
-				}
-			}
-			try {
-				Thread.sleep(30000);
-			} catch (InterruptedException e) {
-				s_logger.debug("Failed to sleep: " + e.toString());
-			}
-		}
-		s_logger.debug("Timeout, to wait for the host connecting to mgt svr, assuming it is failed");
-		List<HostVO> hosts = _resourceMgr.findHostByGuid(dcId, guid);
-		if (hosts.size() == 1) {
-			return hosts.get(0);
-		} else {
-			return null;
-		}
-	}
-	
-	@Override
-    public boolean configure(String name, Map<String, Object> params) throws ConfigurationException {
-		ComponentLocator locator = ComponentLocator.getCurrentLocator();
-        _configDao = locator.getDao(ConfigurationDao.class);
-		_setupAgentPath = Script.findScript(getPatchPath(), "setup_agent.sh");
-		_kvmPrivateNic = _configDao.getValue(Config.KvmPrivateNetwork.key());
-		if (_kvmPrivateNic == null) {
-		    _kvmPrivateNic = "cloudbr0";
-		}
-		
-		_kvmPublicNic = _configDao.getValue(Config.KvmPublicNetwork.key());
-		if (_kvmPublicNic == null) {
-		    _kvmPublicNic = _kvmPrivateNic;
-		}
-		
-		_kvmGuestNic = _configDao.getValue(Config.KvmGuestNetwork.key());
-		if (_kvmGuestNic == null) {
-		    _kvmGuestNic = _kvmPrivateNic;
-		}
-		
-		if (_setupAgentPath == null) {
-			throw new ConfigurationException("Can't find setup_agent.sh");
-		}
-		_hostIp = _configDao.getValue("host");
-		if (_hostIp == null) {
-			throw new ConfigurationException("Can't get host IP");
-		}
-    	_resourceMgr.registerResourceStateAdapter(this.getClass().getSimpleName(), this);
-		return true;
-	}
-	
-	protected String getPatchPath() {
-        return "scripts/vm/hypervisor/kvm/";
-    }
-
-	@Override
-	public void postDiscovery(List<HostVO> hosts, long msId)
-			throws DiscoveryException {
-		// TODO Auto-generated method stub
-	}
-	
-	public Hypervisor.HypervisorType getHypervisorType() {
-		return Hypervisor.HypervisorType.KVM;
-	}
-	
-    @Override
-	public boolean matchHypervisor(String hypervisor) {
-    	// for backwards compatibility, if not supplied, always let to try it
-    	if(hypervisor == null)
-    		return true;
-    	
-    	return Hypervisor.HypervisorType.KVM.toString().equalsIgnoreCase(hypervisor);
-    }
-
-	@Override
-    public HostVO createHostVOForConnectedAgent(HostVO host, StartupCommand[] cmd) {
-		StartupCommand firstCmd = cmd[0];
-		if (!(firstCmd instanceof StartupRoutingCommand)) {
-			return null;
-		}
-
-		StartupRoutingCommand ssCmd = ((StartupRoutingCommand) firstCmd);
-		if (ssCmd.getHypervisorType() != HypervisorType.KVM) {
-			return null;
-		}
-
-		/* KVM requires host are the same in cluster */
-		ClusterVO clusterVO = _clusterDao.findById(host.getClusterId());
-		List<HostVO> hostsInCluster = _resourceMgr.listAllHostsInCluster(clusterVO.getId());
-		if (!hostsInCluster.isEmpty()) {
-			HostVO oneHost = hostsInCluster.get(0);
-			_hostDao.loadDetails(oneHost);
-			String hostOsInCluster = oneHost.getDetail("Host.OS");
-			String hostOs = ssCmd.getHostDetails().get("Host.OS");
-			if (!hostOsInCluster.equalsIgnoreCase(hostOs)) {
-				throw new IllegalArgumentException("Can't add host: " + firstCmd.getPrivateIpAddress() + " with hostOS: " + hostOs + " into a cluster,"
-				        + "in which there are " + hostOsInCluster + " hosts added");
-			}
-		}
-		
-		_hostDao.loadDetails(host);
-		
-		return _resourceMgr.fillRoutingHostVO(host, ssCmd, HypervisorType.KVM, host.getDetails(), null);
-    }
-
-	@Override
-    public HostVO createHostVOForDirectConnectAgent(HostVO host, StartupCommand[] startup, ServerResource resource, Map<String, String> details,
-            List<String> hostTags) {
-	    // TODO Auto-generated method stub
-	    return null;
-    }
-
-	@Override
-    public DeleteHostAnswer deleteHost(HostVO host, boolean isForced, boolean isForceDeleteStorage) throws UnableDeleteHostException {
-        if (host.getType() != Host.Type.Routing || host.getHypervisorType() != HypervisorType.KVM) {
-            return null;
-        }
-        
-        _resourceMgr.deleteRoutingHost(host, isForced, isForceDeleteStorage);
-        try {
-            ShutdownCommand cmd = new ShutdownCommand(ShutdownCommand.DeleteHost, null);
-            _agentMgr.send(host.getId(), cmd);
-        } catch (AgentUnavailableException e) {
-            s_logger.warn("Sending ShutdownCommand failed: ", e);
-        } catch (OperationTimedoutException e) {
-            s_logger.warn("Sending ShutdownCommand failed: ", e);
-        }
-        
-        return new DeleteHostAnswer(true);
-    }
-	
-    @Override
-    public boolean stop() {
-    	_resourceMgr.unregisterResourceStateAdapter(this.getClass().getSimpleName());
-        return super.stop();
-    }
-    
-    
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/9a9c96df/server/src/com/cloud/hypervisor/kvm/discoverer/KvmDummyResourceBase.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/hypervisor/kvm/discoverer/KvmDummyResourceBase.java b/server/src/com/cloud/hypervisor/kvm/discoverer/KvmDummyResourceBase.java
new file mode 100644
index 0000000..3386ff7
--- /dev/null
+++ b/server/src/com/cloud/hypervisor/kvm/discoverer/KvmDummyResourceBase.java
@@ -0,0 +1,88 @@
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements.  See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership.  The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License.  You may obtain a copy of the License at
+//
+//   http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied.  See the License for the
+// specific language governing permissions and limitations
+// under the License.
+package com.cloud.hypervisor.kvm.discoverer;
+
+import java.util.HashMap;
+import java.util.Map;
+
+import javax.naming.ConfigurationException;
+
+import com.cloud.agent.api.Answer;
+import com.cloud.agent.api.Command;
+import com.cloud.agent.api.PingCommand;
+import com.cloud.agent.api.StartupCommand;
+import com.cloud.agent.api.StartupRoutingCommand;
+import com.cloud.agent.api.StartupRoutingCommand.VmState;
+import com.cloud.host.Host.Type;
+import com.cloud.hypervisor.Hypervisor;
+import com.cloud.resource.ServerResource;
+import com.cloud.resource.ServerResourceBase;
+
+public class KvmDummyResourceBase extends ServerResourceBase implements ServerResource {
+	private String _zoneId;
+	private String _podId;
+	private String _clusterId;
+	private String _guid;
+	private String _agentIp;
+	@Override
+	public Type getType() {
+		// TODO Auto-generated method stub
+		return null;
+	}
+
+	@Override
+	public StartupCommand[] initialize() {
+		StartupRoutingCommand cmd = new StartupRoutingCommand(0, 0, 0, 0, null, Hypervisor.HypervisorType.KVM, new HashMap<String, String>(), new HashMap<String, VmState>());
+		cmd.setDataCenter(_zoneId);
+		cmd.setPod(_podId);
+		cmd.setCluster(_clusterId);
+		cmd.setGuid(_guid);
+		cmd.setName(_agentIp);
+		cmd.setPrivateIpAddress(_agentIp);
+		cmd.setStorageIpAddress(_agentIp);
+		cmd.setVersion(KvmDummyResourceBase.class.getPackage().getImplementationVersion());
+		return new StartupCommand[] { cmd };
+	}
+
+	@Override
+	public PingCommand getCurrentStatus(long id) {
+		// TODO Auto-generated method stub
+		return null;
+	}
+
+	@Override
+	public Answer executeRequest(Command cmd) {
+		// TODO Auto-generated method stub
+		return null;
+	}
+
+	@Override
+	protected String getDefaultScriptsDir() {
+		// TODO Auto-generated method stub
+		return null;
+	}
+	
+	@Override
+	public boolean configure(final String name, final Map<String, Object> params) throws ConfigurationException {
+		_zoneId = (String)params.get("zone");
+		_podId = (String)params.get("pod");
+		_clusterId = (String)params.get("cluster");
+		_guid = (String)params.get("guid");
+		_agentIp = (String)params.get("agentIp");
+		return true;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/9a9c96df/server/src/com/cloud/hypervisor/kvm/discoverer/KvmServerDiscoverer.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/hypervisor/kvm/discoverer/KvmServerDiscoverer.java b/server/src/com/cloud/hypervisor/kvm/discoverer/KvmServerDiscoverer.java
new file mode 100644
index 0000000..03746e7
--- /dev/null
+++ b/server/src/com/cloud/hypervisor/kvm/discoverer/KvmServerDiscoverer.java
@@ -0,0 +1,395 @@
+// Licensed to the Apache Software Foundation (ASF) under one
+// or more contributor license agreements.  See the NOTICE file
+// distributed with this work for additional information
+// regarding copyright ownership.  The ASF licenses this file
+// to you under the Apache License, Version 2.0 (the
+// "License"); you may not use this file except in compliance
+// with the License.  You may obtain a copy of the License at
+//
+//   http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing,
+// software distributed under the License is distributed on an
+// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+// KIND, either express or implied.  See the License for the
+// specific language governing permissions and limitations
+// under the License.
+package com.cloud.hypervisor.kvm.discoverer;
+
+import java.net.InetAddress;
+import java.net.URI;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.UUID;
+
+import javax.ejb.Local;
+import javax.naming.ConfigurationException;
+
+import org.apache.log4j.Logger;
+
+import com.cloud.agent.AgentManager;
+import com.cloud.agent.Listener;
+import com.cloud.agent.api.AgentControlAnswer;
+import com.cloud.agent.api.AgentControlCommand;
+import com.cloud.agent.api.Answer;
+import com.cloud.agent.api.Command;
+import com.cloud.agent.api.ShutdownCommand;
+import com.cloud.agent.api.StartupCommand;
+import com.cloud.agent.api.StartupRoutingCommand;
+import com.cloud.configuration.Config;
+import com.cloud.configuration.dao.ConfigurationDao;
+import com.cloud.dc.ClusterVO;
+import com.cloud.dc.dao.ClusterDao;
+import com.cloud.exception.AgentUnavailableException;
+import com.cloud.exception.DiscoveredWithErrorException;
+import com.cloud.exception.DiscoveryException;
+import com.cloud.exception.OperationTimedoutException;
+import com.cloud.host.Host;
+import com.cloud.host.HostVO;
+import com.cloud.host.Status;
+import com.cloud.host.dao.HostDao;
+import com.cloud.hypervisor.Hypervisor;
+import com.cloud.hypervisor.Hypervisor.HypervisorType;
+import com.cloud.hypervisor.kvm.discoverer.KvmDummyResourceBase;
+import com.cloud.network.NetworkManager;
+import com.cloud.network.PhysicalNetworkSetupInfo;
+import com.cloud.resource.Discoverer;
+import com.cloud.resource.DiscovererBase;
+import com.cloud.resource.ResourceManager;
+import com.cloud.resource.ResourceStateAdapter;
+import com.cloud.resource.ServerResource;
+import com.cloud.resource.UnableDeleteHostException;
+import com.cloud.utils.component.ComponentLocator;
+import com.cloud.utils.component.Inject;
+import com.cloud.utils.script.Script;
+import com.cloud.utils.ssh.SSHCmdHelper;
+
+@Local(value=Discoverer.class)
+public class KvmServerDiscoverer extends DiscovererBase implements Discoverer,
+		Listener, ResourceStateAdapter {
+	 private static final Logger s_logger = Logger.getLogger(KvmServerDiscoverer.class);
+	 private String _setupAgentPath;
+	 private ConfigurationDao _configDao;
+	 private String _hostIp;
+	 private int _waitTime = 5; /*wait for 5 minutes*/
+	 private String _kvmPrivateNic;
+	 private String _kvmPublicNic;
+	 private String _kvmGuestNic;
+	 @Inject HostDao _hostDao = null;
+	 @Inject ClusterDao _clusterDao;
+	 @Inject ResourceManager _resourceMgr;
+	 @Inject AgentManager _agentMgr;
+	 @Inject NetworkManager _networkMgr;
+	 
+	@Override
+	public boolean processAnswers(long agentId, long seq, Answer[] answers) {
+		// TODO Auto-generated method stub
+		return false;
+	}
+
+	@Override
+	public boolean processCommands(long agentId, long seq, Command[] commands) {
+		// TODO Auto-generated method stub
+		return false;
+	}
+
+	@Override
+	public AgentControlAnswer processControlCommand(long agentId,
+			AgentControlCommand cmd) {
+		// TODO Auto-generated method stub
+		return null;
+	}
+
+	@Override
+	public void processConnect(HostVO host, StartupCommand cmd, boolean forRebalance) {
+	}
+
+	@Override
+	public boolean processDisconnect(long agentId, Status state) {
+		// TODO Auto-generated method stub
+		return false;
+	}
+
+	@Override
+	public boolean isRecurring() {
+		// TODO Auto-generated method stub
+		return false;
+	}
+
+	@Override
+	public int getTimeout() {
+		// TODO Auto-generated method stub
+		return 0;
+	}
+
+	@Override
+	public boolean processTimeout(long agentId, long seq) {
+		// TODO Auto-generated method stub
+		return false;
+	}
+
+	@Override
+	public Map<? extends ServerResource, Map<String, String>> find(long dcId,
+			Long podId, Long clusterId, URI uri, String username,
+			String password, List<String> hostTags) throws DiscoveryException {
+		
+        ClusterVO cluster = _clusterDao.findById(clusterId);
+        if(cluster == null || cluster.getHypervisorType() != HypervisorType.KVM) {
+        	if(s_logger.isInfoEnabled())
+        		s_logger.info("invalid cluster id or cluster is not for KVM hypervisors"); 
+    		return null;
+        }
+		
+		 Map<KvmDummyResourceBase, Map<String, String>> resources = new HashMap<KvmDummyResourceBase, Map<String, String>>();
+		 Map<String, String> details = new HashMap<String, String>();
+		if (!uri.getScheme().equals("http")) {
+            String msg = "urlString is not http so we're not taking care of the discovery for this: " + uri;
+            s_logger.debug(msg);
+            return null;
+		}
+		com.trilead.ssh2.Connection sshConnection = null;
+		String agentIp = null;
+		try {
+			
+			String hostname = uri.getHost();
+			InetAddress ia = InetAddress.getByName(hostname);
+			agentIp = ia.getHostAddress();
+			String guid = UUID.nameUUIDFromBytes(agentIp.getBytes()).toString();
+			String guidWithTail = guid + "-LibvirtComputingResource";/*tail added by agent.java*/
+			if (_resourceMgr.findHostByGuid(guidWithTail) != null) {
+				s_logger.debug("Skipping " + agentIp + " because " + guidWithTail + " is already in the database.");
+				return null;
+			}       
+			
+			sshConnection = new com.trilead.ssh2.Connection(agentIp, 22);
+
+			sshConnection.connect(null, 60000, 60000);
+			if (!sshConnection.authenticateWithPassword(username, password)) {
+				s_logger.debug("Failed to authenticate");
+				throw new DiscoveredWithErrorException("Authentication error");
+			}
+			
+			if (!SSHCmdHelper.sshExecuteCmd(sshConnection, "lsmod|grep kvm", 3)) {
+				s_logger.debug("It's not a KVM enabled machine");
+				return null;
+			}
+			
+			List <PhysicalNetworkSetupInfo> netInfos = _networkMgr.getPhysicalNetworkInfo(dcId, HypervisorType.KVM);
+			String kvmPrivateNic = _kvmPrivateNic;
+			String kvmPublicNic = _kvmPublicNic;
+			String kvmGuestNic = _kvmGuestNic;
+
+			for (PhysicalNetworkSetupInfo info : netInfos) {
+			    if (info.getPrivateNetworkName() != null) {
+			        kvmPrivateNic = info.getPrivateNetworkName();
+			    }
+			    if (info.getPublicNetworkName() != null) {
+			        kvmPublicNic = info.getPublicNetworkName();
+			    }
+			    if (info.getGuestNetworkName() != null) {
+			        kvmGuestNic = info.getGuestNetworkName();
+			    }
+			}
+
+                        String parameters = " -m " + _hostIp + " -z " + dcId + " -p " + podId + " -c " + clusterId + " -g " + guid + " -a";
+			
+			if (kvmPublicNic != null) {
+				parameters += " --pubNic=" + kvmPublicNic;
+			}
+			
+			if (kvmPrivateNic != null) {
+				parameters += " --prvNic=" + kvmPrivateNic;
+			}
+			
+			if (kvmGuestNic != null) {
+			    parameters += " --guestNic=" + kvmGuestNic;
+			}
+		
+			SSHCmdHelper.sshExecuteCmd(sshConnection, "cloud-setup-agent " + parameters, 3);
+			
+			KvmDummyResourceBase kvmResource = new KvmDummyResourceBase();
+			Map<String, Object> params = new HashMap<String, Object>();
+						
+			params.put("zone", Long.toString(dcId));
+			params.put("pod", Long.toString(podId));
+			params.put("cluster",  Long.toString(clusterId));
+			params.put("guid", guid); 
+			params.put("agentIp", agentIp);
+			kvmResource.configure("kvm agent", params);
+			resources.put(kvmResource, details);
+			
+			HostVO connectedHost = waitForHostConnect(dcId, podId, clusterId, guidWithTail);
+			if (connectedHost == null)
+				return null;
+			
+			details.put("guid", guidWithTail);
+			
+			 // place a place holder guid derived from cluster ID
+			if (cluster.getGuid() == null) {
+			    cluster.setGuid(UUID.nameUUIDFromBytes(String.valueOf(clusterId).getBytes()).toString());
+			    _clusterDao.update(clusterId, cluster);
+			}
+			
+			//save user name and password
+			_hostDao.loadDetails(connectedHost);
+			Map<String, String> hostDetails = connectedHost.getDetails();
+			hostDetails.put("password", password);
+			hostDetails.put("username", username);
+			_hostDao.saveDetails(connectedHost);
+			return resources;
+		} catch (DiscoveredWithErrorException e){ 
+			throw e;
+		}catch (Exception e) {
+			String msg = " can't setup agent, due to " + e.toString() + " - " + e.getMessage();
+			s_logger.warn(msg);
+		} finally {
+			if (sshConnection != null)
+				sshConnection.close();
+		}
+		
+		return null;
+	}
+
+	private HostVO waitForHostConnect(long dcId, long podId, long clusterId, String guid) {
+		for (int i = 0; i < _waitTime *2; i++) {
+			List<HostVO> hosts = _resourceMgr.listAllUpAndEnabledHosts(Host.Type.Routing, clusterId, podId, dcId);
+			for (HostVO host : hosts) {
+				if (host.getGuid().equalsIgnoreCase(guid)) {
+					return host;
+				}
+			}
+			try {
+				Thread.sleep(30000);
+			} catch (InterruptedException e) {
+				s_logger.debug("Failed to sleep: " + e.toString());
+			}
+		}
+		s_logger.debug("Timeout, to wait for the host connecting to mgt svr, assuming it is failed");
+		List<HostVO> hosts = _resourceMgr.findHostByGuid(dcId, guid);
+		if (hosts.size() == 1) {
+			return hosts.get(0);
+		} else {
+			return null;
+		}
+	}
+	
+	@Override
+    public boolean configure(String name, Map<String, Object> params) throws ConfigurationException {
+		ComponentLocator locator = ComponentLocator.getCurrentLocator();
+        _configDao = locator.getDao(ConfigurationDao.class);
+		_setupAgentPath = Script.findScript(getPatchPath(), "setup_agent.sh");
+		_kvmPrivateNic = _configDao.getValue(Config.KvmPrivateNetwork.key());
+		if (_kvmPrivateNic == null) {
+		    _kvmPrivateNic = "cloudbr0";
+		}
+		
+		_kvmPublicNic = _configDao.getValue(Config.KvmPublicNetwork.key());
+		if (_kvmPublicNic == null) {
+		    _kvmPublicNic = _kvmPrivateNic;
+		}
+		
+		_kvmGuestNic = _configDao.getValue(Config.KvmGuestNetwork.key());
+		if (_kvmGuestNic == null) {
+		    _kvmGuestNic = _kvmPrivateNic;
+		}
+		
+		if (_setupAgentPath == null) {
+			throw new ConfigurationException("Can't find setup_agent.sh");
+		}
+		_hostIp = _configDao.getValue("host");
+		if (_hostIp == null) {
+			throw new ConfigurationException("Can't get host IP");
+		}
+    	_resourceMgr.registerResourceStateAdapter(this.getClass().getSimpleName(), this);
+		return true;
+	}
+	
+	protected String getPatchPath() {
+        return "scripts/vm/hypervisor/kvm/";
+    }
+
+	@Override
+	public void postDiscovery(List<HostVO> hosts, long msId)
+			throws DiscoveryException {
+		// TODO Auto-generated method stub
+	}
+	
+	public Hypervisor.HypervisorType getHypervisorType() {
+		return Hypervisor.HypervisorType.KVM;
+	}
+	
+    @Override
+	public boolean matchHypervisor(String hypervisor) {
+    	// for backwards compatibility, if not supplied, always let to try it
+    	if(hypervisor == null)
+    		return true;
+    	
+    	return Hypervisor.HypervisorType.KVM.toString().equalsIgnoreCase(hypervisor);
+    }
+
+	@Override
+    public HostVO createHostVOForConnectedAgent(HostVO host, StartupCommand[] cmd) {
+		StartupCommand firstCmd = cmd[0];
+		if (!(firstCmd instanceof StartupRoutingCommand)) {
+			return null;
+		}
+
+		StartupRoutingCommand ssCmd = ((StartupRoutingCommand) firstCmd);
+		if (ssCmd.getHypervisorType() != HypervisorType.KVM) {
+			return null;
+		}
+
+		/* KVM requires host are the same in cluster */
+		ClusterVO clusterVO = _clusterDao.findById(host.getClusterId());
+		List<HostVO> hostsInCluster = _resourceMgr.listAllHostsInCluster(clusterVO.getId());
+		if (!hostsInCluster.isEmpty()) {
+			HostVO oneHost = hostsInCluster.get(0);
+			_hostDao.loadDetails(oneHost);
+			String hostOsInCluster = oneHost.getDetail("Host.OS");
+			String hostOs = ssCmd.getHostDetails().get("Host.OS");
+			if (!hostOsInCluster.equalsIgnoreCase(hostOs)) {
+				throw new IllegalArgumentException("Can't add host: " + firstCmd.getPrivateIpAddress() + " with hostOS: " + hostOs + " into a cluster,"
+				        + "in which there are " + hostOsInCluster + " hosts added");
+			}
+		}
+		
+		_hostDao.loadDetails(host);
+		
+		return _resourceMgr.fillRoutingHostVO(host, ssCmd, HypervisorType.KVM, host.getDetails(), null);
+    }
+
+	@Override
+    public HostVO createHostVOForDirectConnectAgent(HostVO host, StartupCommand[] startup, ServerResource resource, Map<String, String> details,
+            List<String> hostTags) {
+	    // TODO Auto-generated method stub
+	    return null;
+    }
+
+	@Override
+    public DeleteHostAnswer deleteHost(HostVO host, boolean isForced, boolean isForceDeleteStorage) throws UnableDeleteHostException {
+        if (host.getType() != Host.Type.Routing || host.getHypervisorType() != HypervisorType.KVM) {
+            return null;
+        }
+        
+        _resourceMgr.deleteRoutingHost(host, isForced, isForceDeleteStorage);
+        try {
+            ShutdownCommand cmd = new ShutdownCommand(ShutdownCommand.DeleteHost, null);
+            _agentMgr.send(host.getId(), cmd);
+        } catch (AgentUnavailableException e) {
+            s_logger.warn("Sending ShutdownCommand failed: ", e);
+        } catch (OperationTimedoutException e) {
+            s_logger.warn("Sending ShutdownCommand failed: ", e);
+        }
+        
+        return new DeleteHostAnswer(true);
+    }
+	
+    @Override
+    public boolean stop() {
+    	_resourceMgr.unregisterResourceStateAdapter(this.getClass().getSimpleName());
+        return super.stop();
+    }
+    
+    
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/9a9c96df/server/src/com/cloud/resource/ResourceManagerImpl.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/resource/ResourceManagerImpl.java b/server/src/com/cloud/resource/ResourceManagerImpl.java
index 7f00da9..14b5df5 100755
--- a/server/src/com/cloud/resource/ResourceManagerImpl.java
+++ b/server/src/com/cloud/resource/ResourceManagerImpl.java
@@ -98,7 +98,7 @@ import com.cloud.host.dao.HostDetailsDao;
 import com.cloud.host.dao.HostTagsDao;
 import com.cloud.hypervisor.Hypervisor;
 import com.cloud.hypervisor.Hypervisor.HypervisorType;
-import com.cloud.hypervisor.kvm.discover.KvmDummyResourceBase;
+import com.cloud.hypervisor.kvm.discoverer.KvmDummyResourceBase;
 import com.cloud.network.IPAddressVO;
 import com.cloud.network.dao.IPAddressDao;
 import com.cloud.org.Cluster;