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/10/31 01:35:54 UTC

[1/2] git commit: add volume service skeleton

Updated Branches:
  refs/heads/javelin f36b2f997 -> 3423c5d74


add volume service skeleton


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

Branch: refs/heads/javelin
Commit: 3423c5d74f062820f2e6f99b22fabe2526d3dd00
Parents: f36b2f9
Author: Edison Su <su...@gmail.com>
Authored: Tue Oct 30 17:34:46 2012 -0700
Committer: Edison Su <su...@gmail.com>
Committed: Tue Oct 30 17:34:46 2012 -0700

----------------------------------------------------------------------
 .../org/apache/cloudstack/storage/BaseType.java    |   40 +
 .../org/apache/cloudstack/storage/EndPoint.java    |    5 +-
 .../cloudstack/storage/HypervisorHostEndPoint.java |   55 +
 .../storage/command/CreateVolumeAnswer.java        |   36 +
 .../storage/command/CreateVolumeCommand.java       |   42 +
 .../datastore/DefaultPrimaryDataStoreImpl.java     |   67 +-
 .../storage/datastore/PrimaryDataStore.java        |    3 +
 .../storage/datastore/db/DataStoreVO.java          |    6 +-
 .../datastore/db/PrimaryDataStoreProviderVO.java   |   17 +-
 .../driver/DefaultPrimaryDataStoreDriverImpl.java  |   36 +-
 .../DefaultPrimaryDataStoreManagerImpl.java        |   15 +-
 .../provider/PrimaryDataStoreProviderManager.java  |    2 +-
 .../PrimaryDataStoreProviderManagerImpl.java       |   32 +
 .../storage/datastore/type/DataStoreType.java      |   23 +
 .../cloudstack/storage/datastore/type/ISCSI.java   |   31 +
 .../storage/datastore/type/NetworkFileSystem.java  |   31 +
 .../storage/datastore/type/SharedMount.java        |   29 +
 .../DefaultNfsSecondaryEndPointSelector.java       |   38 -
 .../epselector/DefaultPrimaryEndpointSelector.java |   40 -
 .../storage/filesystem/DefaultFileSystem.java      |   59 -
 .../cloudstack/storage/image/db/ImageDataDao.java  |   71 ++
 .../storage/image/db/ImageDataDaoImpl.java         |  925 +++++++++++++++
 .../cloudstack/storage/image/db/ImageDataVO.java   |  381 ++++++
 .../cloudstack/storage/image/format/BAREMETAL.java |   31 +
 .../cloudstack/storage/image/format/ISO.java       |   31 +
 .../storage/image/format/ImageFormat.java          |   23 +
 .../storage/image/format/ImageFormatHelper.java    |   44 +
 .../cloudstack/storage/image/format/OVA.java       |   31 +
 .../cloudstack/storage/image/format/QCOW2.java     |   31 +
 .../cloudstack/storage/image/format/Unknown.java   |   32 +
 .../cloudstack/storage/image/format/VHD.java       |   29 +
 .../image/provider/ImageDataStoreProvider.java     |   25 +
 .../storage/image/store/ImageDataStore.java        |   23 +
 .../manager/PrimaryDataStoreManagerImpl.java       |   13 +
 .../apache/cloudstack/storage/volume/Volume.java   |   49 +-
 .../cloudstack/storage/volume/VolumeInfo.java      |   76 ++
 .../cloudstack/storage/volume/VolumeService.java   |    3 +-
 .../storage/volume/VolumeServiceImpl.java          |   11 +-
 .../cloudstack/storage/volume/VolumeState.java     |    6 +-
 .../cloudstack/storage/volume/db/VolumeVO.java     |    3 +-
 .../volume/disktype/VolumeDiskTypeHelper.java      |   13 +-
 .../cloudstack/storage/volume/type/VolumeType.java |    1 -
 .../storage/volume/type/VolumeTypeBase.java        |   15 +-
 .../storage/volume/type/VolumeTypeHelper.java      |   12 +-
 .../cloudstack/storage/test/volumeServiceTest.java |   32 +-
 server/src/com/cloud/host/dao/HostDao.java         |    1 +
 server/src/com/cloud/host/dao/HostDaoImpl.java     |   21 +-
 47 files changed, 2356 insertions(+), 184 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/BaseType.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/BaseType.java b/platform/storage/src/org/apache/cloudstack/storage/BaseType.java
new file mode 100644
index 0000000..12acc7d
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/BaseType.java
@@ -0,0 +1,40 @@
+/*
+ * 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 org.apache.cloudstack.storage;
+
+public abstract class BaseType {
+	public boolean equals(Object that) {
+		if (this == that) {
+			return true;
+		}
+		if (that instanceof String) {
+			if (this.toString().equalsIgnoreCase((String)that)) {
+				return true;
+			}
+		} else if (that instanceof BaseType) {
+			BaseType th = (BaseType)that;
+			if (this.toString().equalsIgnoreCase(th.toString())) {
+				return true;
+			}
+		} else {
+			return false;
+		}
+		return false;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/EndPoint.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/EndPoint.java b/platform/storage/src/org/apache/cloudstack/storage/EndPoint.java
index 8cb01a1..0a3dfa2 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/EndPoint.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/EndPoint.java
@@ -1,5 +1,8 @@
 package org.apache.cloudstack.storage;
 
+import com.cloud.agent.api.Answer;
+import com.cloud.agent.api.Command;
+
 public interface EndPoint {
-	public String getEndPoint();
+	public Answer sendMessage(Command cmd);
 }

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/HypervisorHostEndPoint.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/HypervisorHostEndPoint.java b/platform/storage/src/org/apache/cloudstack/storage/HypervisorHostEndPoint.java
new file mode 100644
index 0000000..8bd51c7
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/HypervisorHostEndPoint.java
@@ -0,0 +1,55 @@
+/*
+ * 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 org.apache.cloudstack.storage;
+
+import javax.inject.Inject;
+
+import org.apache.log4j.Logger;
+
+import com.cloud.agent.AgentManager;
+import com.cloud.agent.api.Answer;
+import com.cloud.agent.api.Command;
+import com.cloud.exception.AgentUnavailableException;
+import com.cloud.exception.OperationTimedoutException;
+
+public class HypervisorHostEndPoint implements EndPoint {
+	private static final Logger s_logger = Logger.getLogger(HypervisorHostEndPoint.class);
+	private long hostId;
+	@Inject
+	AgentManager agentMgr;
+	public HypervisorHostEndPoint(long hostId) {
+		this.hostId = hostId;
+	}
+	
+	@Override
+	public Answer sendMessage(Command cmd) {
+		Answer answer = null;
+		try {
+			answer = agentMgr.send(hostId, cmd);
+		} catch (AgentUnavailableException e) {
+			s_logger.debug("Unable to send command:" + cmd + ", due to: " + e.toString());
+		} catch (OperationTimedoutException e) {
+			s_logger.debug("Unable to send command:" + cmd + ", due to: " + e.toString());
+		} catch (Exception e) {
+			s_logger.debug("Unable to send command:" + cmd + ", due to: " + e.toString());
+		}
+		return answer;
+	}
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeAnswer.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeAnswer.java b/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeAnswer.java
new file mode 100644
index 0000000..e75307c
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeAnswer.java
@@ -0,0 +1,36 @@
+/*
+ * 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 org.apache.cloudstack.storage.command;
+
+import com.cloud.agent.api.Answer;
+
+public class CreateVolumeAnswer extends Answer {
+	private String volumeUuid;
+	protected CreateVolumeAnswer() {
+		super();
+	}
+	
+	public CreateVolumeAnswer(String volumeUuid) {
+		this.volumeUuid = volumeUuid;
+	}
+	
+	public String getVolumeUuid() {
+		return this.volumeUuid;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeCommand.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeCommand.java b/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeCommand.java
new file mode 100644
index 0000000..243e016
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/command/CreateVolumeCommand.java
@@ -0,0 +1,42 @@
+/*
+ * 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 org.apache.cloudstack.storage.command;
+
+import org.apache.cloudstack.storage.volume.VolumeInfo;
+
+import com.cloud.agent.api.Command;
+
+public class CreateVolumeCommand extends Command {
+	protected VolumeInfo volumeInfo;
+	public CreateVolumeCommand(VolumeInfo volumeInfo) {
+		super();
+		this.volumeInfo = volumeInfo;
+	}
+	
+	protected CreateVolumeCommand() {
+		super();
+	}
+	
+	@Override
+	public boolean executeInSequence() {
+		// TODO Auto-generated method stub
+		return false;
+	}
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/DefaultPrimaryDataStoreImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/DefaultPrimaryDataStoreImpl.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/DefaultPrimaryDataStoreImpl.java
index ae2d620..ea22b23 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/datastore/DefaultPrimaryDataStoreImpl.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/DefaultPrimaryDataStoreImpl.java
@@ -1,22 +1,38 @@
 package org.apache.cloudstack.storage.datastore;
 
+import java.util.ArrayList;
+import java.util.Collection;
 import java.util.List;
 
 import javax.inject.Inject;
 
+import org.apache.cloudstack.storage.EndPoint;
+import org.apache.cloudstack.storage.HypervisorHostEndPoint;
 import org.apache.cloudstack.storage.datastore.db.DataStoreVO;
 import org.apache.cloudstack.storage.datastore.driver.PrimaryDataStoreDriver;
 import org.apache.cloudstack.storage.volume.Volume;
+import org.apache.cloudstack.storage.volume.VolumeEvent;
 import org.apache.cloudstack.storage.volume.db.VolumeDao;
 import org.apache.cloudstack.storage.volume.db.VolumeVO;
 import org.apache.cloudstack.storage.volume.disktype.VolumeDiskType;
+import org.apache.log4j.Logger;
+
+import com.cloud.host.HostVO;
+import com.cloud.host.dao.HostDao;
+import com.cloud.utils.component.ComponentInject;
+import com.cloud.utils.exception.CloudRuntimeException;
+
+import edu.emory.mathcs.backport.java.util.Collections;
 
 public class DefaultPrimaryDataStoreImpl implements PrimaryDataStore {
+	private static final Logger s_logger = Logger.getLogger(DefaultPrimaryDataStoreImpl.class);
 	protected PrimaryDataStoreDriver driver;
 	protected DataStoreVO pdsv;
 	protected PrimaryDataStoreInfo pdsInfo;
 	@Inject
-	public VolumeDao volumeDao;
+	private VolumeDao volumeDao;
+	@Inject
+	private HostDao hostDao;
 	public DefaultPrimaryDataStoreImpl(PrimaryDataStoreDriver driver, DataStoreVO pdsv, PrimaryDataStoreInfo pdsInfo) {
 		this.driver = driver;
 		this.pdsv = pdsv;
@@ -53,9 +69,50 @@ public class DefaultPrimaryDataStoreImpl implements PrimaryDataStore {
 			return null;
 		}
 		
-		vol.setVolumeDiskType(diskType);
-		this.driver.createVolume(vol);
-		vol.update();
-		return vol;
+		boolean result = vol.stateTransit(VolumeEvent.CreateRequested);
+		if (!result) {
+			return null;
+		}
+		
+		try {
+			vol.setVolumeDiskType(diskType);
+			result = this.driver.createVolume(vol);
+			vol.update();
+			return vol;
+		} catch (Exception e) {
+			result = false;
+			s_logger.debug("Failed to create volume: " + e.toString());
+			throw new CloudRuntimeException(e.toString());
+		} finally {
+			if (result == true) {
+				vol.stateTransit(VolumeEvent.OperationSucceeded);
+			} else {
+				vol.stateTransit(VolumeEvent.OperationFailed);
+			}
+		}
+		
+	}
+
+	@Override
+	public List<EndPoint> getEndPoints() {
+		Long clusterId = pdsv.getClusterId();
+		if (clusterId == null) {
+			return null;
+		}
+		List<EndPoint> endpoints = new ArrayList<EndPoint>();
+		List<HostVO> hosts = hostDao.findHypervisorHostInCluster(clusterId);
+		for (HostVO host : hosts) {
+			HypervisorHostEndPoint ep = new HypervisorHostEndPoint(host.getId());
+			ComponentInject.inject(ep);
+			endpoints.add(ep);
+		}
+		Collections.shuffle(endpoints);
+		return endpoints;
+	}
+
+	@Override
+	public PrimaryDataStoreInfo getDataStoreInfo() {
+		// TODO Auto-generated method stub
+		return null;
 	}
 }

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/PrimaryDataStore.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/PrimaryDataStore.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/PrimaryDataStore.java
index 3e06156..7efa561 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/datastore/PrimaryDataStore.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/PrimaryDataStore.java
@@ -20,6 +20,7 @@ package org.apache.cloudstack.storage.datastore;
 
 import java.util.List;
 
+import org.apache.cloudstack.storage.EndPoint;
 import org.apache.cloudstack.storage.volume.Volume;
 import org.apache.cloudstack.storage.volume.disktype.VolumeDiskType;
 
@@ -28,4 +29,6 @@ public interface PrimaryDataStore {
 	List<Volume> getVolumes();
 	boolean deleteVolume(long id);
 	Volume createVolume(long id, VolumeDiskType diskType);
+	List<EndPoint> getEndPoints();
+	PrimaryDataStoreInfo getDataStoreInfo();
 }

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/db/DataStoreVO.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/db/DataStoreVO.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/db/DataStoreVO.java
index 960d7c8..52f3bbf 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/datastore/db/DataStoreVO.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/db/DataStoreVO.java
@@ -82,7 +82,7 @@ public class DataStoreVO implements Identity {
     private DataStoreStatus status;
     
     @Column(name="storage_provider", updatable=true, nullable=false)
-    private String storageProvider;
+    private Long storageProvider;
     
     @Column(name="storage_type", nullable=false)
     private String storageType;
@@ -147,11 +147,11 @@ public class DataStoreVO implements Identity {
 		return availableBytes;
 	}
 
-	public String getStorageProvider() {
+	public Long getStorageProviderId() {
 		return storageProvider;
 	}
 	
-	public void setStorageProvider(String provider) {
+	public void setStorageProviderId(Long provider) {
 		storageProvider = provider;
 	}
 	

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/db/PrimaryDataStoreProviderVO.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/db/PrimaryDataStoreProviderVO.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/db/PrimaryDataStoreProviderVO.java
index 0ec6bf0..0d15580 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/datastore/db/PrimaryDataStoreProviderVO.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/db/PrimaryDataStoreProviderVO.java
@@ -18,6 +18,21 @@
  */
 package org.apache.cloudstack.storage.datastore.db;
 
-public class PrimaryDataStoreProviderVO {
+import javax.persistence.Column;
+import javax.persistence.Entity;
+import javax.persistence.Id;
+import javax.persistence.Table;
+import javax.persistence.TableGenerator;
 
+@Entity
+@Table(name="data_store_provider")
+public class PrimaryDataStoreProviderVO {
+    @Id
+    @TableGenerator(name="data_store_provider_sq", table="sequence", pkColumnName="name", valueColumnName="value", pkColumnValue="data_store_provider_seq", allocationSize=1)
+    @Column(name="id", updatable=false, nullable = false)
+	private long id;
+    
+    public long getId() {
+    	return id;
+    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/driver/DefaultPrimaryDataStoreDriverImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/driver/DefaultPrimaryDataStoreDriverImpl.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/driver/DefaultPrimaryDataStoreDriverImpl.java
index d1e6976..935f214 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/datastore/driver/DefaultPrimaryDataStoreDriverImpl.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/driver/DefaultPrimaryDataStoreDriverImpl.java
@@ -1,17 +1,47 @@
 package org.apache.cloudstack.storage.datastore.driver;
 
+import java.util.List;
+
 import org.apache.cloudstack.storage.EndPoint;
+import org.apache.cloudstack.storage.command.CreateVolumeAnswer;
+import org.apache.cloudstack.storage.command.CreateVolumeCommand;
 import org.apache.cloudstack.storage.volume.Volume;
+import org.apache.cloudstack.storage.volume.VolumeInfo;
+import org.apache.log4j.Logger;
 import org.springframework.stereotype.Component;
 
+import com.cloud.agent.api.Answer;
+
 @Component
 public class DefaultPrimaryDataStoreDriverImpl implements
 		PrimaryDataStoreDriver {
-
+	private static final Logger s_logger = Logger.getLogger(DefaultPrimaryDataStoreDriverImpl.class);
 	@Override
 	public boolean createVolume(Volume vol) {
-		// TODO Auto-generated method stub
-		return false;
+		//The default driver will send createvolume command to one of hosts which can access its datastore
+		List<EndPoint> endPoints = vol.getDataStore().getEndPoints();
+		int retries = 3;
+		VolumeInfo volInfo = new VolumeInfo(vol);
+		CreateVolumeCommand createCmd = new CreateVolumeCommand(volInfo);
+		Answer answer = null;
+		int i = 0;
+		boolean result = false;
+		
+		for (EndPoint ep : endPoints) {
+			answer = ep.sendMessage(createCmd);
+			if (answer == null) {
+				if (i < retries) {
+					s_logger.debug("create volume failed, retrying: " + i);
+				}
+				i++;
+			} else {
+				CreateVolumeAnswer volAnswer = (CreateVolumeAnswer)answer;
+				vol.setUuid(volAnswer.getVolumeUuid());
+				result = true;
+			}
+		}
+		
+		return result;
 	}
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/manager/DefaultPrimaryDataStoreManagerImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/manager/DefaultPrimaryDataStoreManagerImpl.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/manager/DefaultPrimaryDataStoreManagerImpl.java
index dfa4663..4949b2f 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/datastore/manager/DefaultPrimaryDataStoreManagerImpl.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/manager/DefaultPrimaryDataStoreManagerImpl.java
@@ -21,18 +21,29 @@ package org.apache.cloudstack.storage.datastore.manager;
 import javax.inject.Inject;
 
 import org.apache.cloudstack.storage.datastore.PrimaryDataStore;
+import org.apache.cloudstack.storage.datastore.db.DataStoreVO;
+import org.apache.cloudstack.storage.datastore.db.PrimaryDataStoreDao;
 import org.apache.cloudstack.storage.datastore.db.PrimaryDataStoreProviderDao;
 import org.apache.cloudstack.storage.datastore.lifecycle.PrimaryDataStoreLifeCycle;
+import org.apache.cloudstack.storage.datastore.provider.PrimaryDataStoreProvider;
+import org.apache.cloudstack.storage.datastore.provider.PrimaryDataStoreProviderManager;
 import org.springframework.stereotype.Component;
 
 @Component
 public class DefaultPrimaryDataStoreManagerImpl implements PrimaryDataStoreManager {
 	@Inject
 	PrimaryDataStoreProviderDao dataStoreProviderDao;
+	@Inject
+	PrimaryDataStoreProviderManager providerManager;
+	@Inject
+	PrimaryDataStoreDao dataStoreDao;
 	@Override
 	public PrimaryDataStore getPrimaryDataStore(long dataStoreId) {
-		// TODO Auto-generated method stub
-		return null;
+		DataStoreVO dataStoreVO = dataStoreDao.findById(dataStoreId);
+		Long providerId = dataStoreVO.getStorageProviderId();
+		PrimaryDataStoreProvider provider = providerManager.getDataStoreProvider(providerId);
+		PrimaryDataStore dataStore = provider.getDataStore(dataStoreId);
+		return dataStore;
 	}
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManager.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManager.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManager.java
index a01c96c..4ef9a5c 100644
--- a/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManager.java
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManager.java
@@ -1,5 +1,5 @@
 package org.apache.cloudstack.storage.datastore.provider;
 
 public interface PrimaryDataStoreProviderManager {
-	public PrimaryDataStoreProvider getDataStoreProvider(String providerUuid);
+	public PrimaryDataStoreProvider getDataStoreProvider(Long providerId);
 }

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManagerImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManagerImpl.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManagerImpl.java
new file mode 100644
index 0000000..0875553
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/provider/PrimaryDataStoreProviderManagerImpl.java
@@ -0,0 +1,32 @@
+/*
+ * 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 org.apache.cloudstack.storage.datastore.provider;
+
+import org.springframework.stereotype.Component;
+
+@Component
+public class PrimaryDataStoreProviderManagerImpl implements PrimaryDataStoreProviderManager {
+
+	@Override
+	public PrimaryDataStoreProvider getDataStoreProvider(Long providerId) {
+		// TODO Auto-generated method stub
+		return null;
+	}
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/type/DataStoreType.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/type/DataStoreType.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/DataStoreType.java
new file mode 100644
index 0000000..8f3fe8c
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/DataStoreType.java
@@ -0,0 +1,23 @@
+/*
+ * 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 org.apache.cloudstack.storage.datastore.type;
+
+public interface DataStoreType {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/type/ISCSI.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/type/ISCSI.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/ISCSI.java
new file mode 100644
index 0000000..26d36de
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/ISCSI.java
@@ -0,0 +1,31 @@
+/*
+ * 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 org.apache.cloudstack.storage.datastore.type;
+
+import org.apache.cloudstack.storage.BaseType;
+import org.springframework.stereotype.Component;
+
+@Component
+public class ISCSI extends BaseType implements DataStoreType {
+	private final String type = "iscsi";
+	@Override
+	public String toString() {
+		return type;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/type/NetworkFileSystem.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/type/NetworkFileSystem.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/NetworkFileSystem.java
new file mode 100644
index 0000000..9340975
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/NetworkFileSystem.java
@@ -0,0 +1,31 @@
+/*
+ * 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 org.apache.cloudstack.storage.datastore.type;
+
+import org.apache.cloudstack.storage.BaseType;
+import org.springframework.stereotype.Component;
+
+@Component
+public class NetworkFileSystem extends BaseType implements DataStoreType {
+	private final String type = "nfs";
+	@Override
+	public String toString() {
+		return type;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/datastore/type/SharedMount.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/datastore/type/SharedMount.java b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/SharedMount.java
new file mode 100644
index 0000000..c97a893
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/datastore/type/SharedMount.java
@@ -0,0 +1,29 @@
+/*
+ * 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 org.apache.cloudstack.storage.datastore.type;
+
+import org.apache.cloudstack.storage.BaseType;
+
+public class SharedMount extends BaseType implements DataStoreType {
+	private final String type = "SharedMountPoint";
+	@Override
+	public String toString() {
+		return type;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultNfsSecondaryEndPointSelector.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultNfsSecondaryEndPointSelector.java b/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultNfsSecondaryEndPointSelector.java
deleted file mode 100644
index b9de406..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultNfsSecondaryEndPointSelector.java
+++ /dev/null
@@ -1,38 +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 org.apache.cloudstack.storage.epselector;
-
-import java.util.List;
-
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStore;
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStoreEndPoint;
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStoreEndPointSelector;
-import org.apache.cloudstack.platform.subsystem.api.storage.StorageEvent;
-
-public class DefaultNfsSecondaryEndPointSelector implements DataStoreEndPointSelector {
-	protected DataStore _ds;
-    public DefaultNfsSecondaryEndPointSelector(DataStore ds) {
-    	_ds = ds;
-    }
-	public List<DataStoreEndPoint> getEndPoints(StorageEvent event) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultPrimaryEndpointSelector.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultPrimaryEndpointSelector.java b/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultPrimaryEndpointSelector.java
deleted file mode 100644
index 33ccb42..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/epselector/DefaultPrimaryEndpointSelector.java
+++ /dev/null
@@ -1,40 +0,0 @@
-package org.apache.cloudstack.storage.epselector;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStore;
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStoreEndPoint;
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStoreEndPointSelector;
-import org.apache.cloudstack.platform.subsystem.api.storage.StorageEvent;
-
-import com.cloud.host.Host;
-import com.cloud.host.HostVO;
-import com.cloud.resource.ResourceManager;
-import com.cloud.utils.component.Inject;
-
-public class DefaultPrimaryEndpointSelector implements
-		DataStoreEndPointSelector {
-	protected DataStore _ds;
-	
-    @Inject
-    protected ResourceManager _resourceMgr;
-	
-    public DefaultPrimaryEndpointSelector(DataStore ds) {
-    	_ds = ds;
-    }
-    
-	public List<DataStoreEndPoint> getEndPoints() {
-		List<HostVO> allHosts = _resourceMgr.listAllUpAndEnabledHosts(Host.Type.Routing, _ds.getCluterId(), _ds.getPodId(), _ds.getZoneId());
-		List<DataStoreEndPoint> dseps = new ArrayList<DataStoreEndPoint>();
-		for (HostVO host : allHosts) {
-			dseps.add(new DataStoreEndPoint(host.getId(), host.getPrivateIpAddress()));
-		}
-		return dseps;
-	}
-
-	public List<DataStoreEndPoint> getEndPoints(StorageEvent event) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/filesystem/DefaultFileSystem.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/filesystem/DefaultFileSystem.java b/platform/storage/src/org/apache/cloudstack/storage/filesystem/DefaultFileSystem.java
deleted file mode 100644
index 7176cea..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/filesystem/DefaultFileSystem.java
+++ /dev/null
@@ -1,59 +0,0 @@
-package org.apache.cloudstack.storage.filesystem;
-
-import org.apache.cloudstack.platform.subsystem.api.storage.DataObject;
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStore;
-import org.apache.cloudstack.platform.subsystem.api.storage.FileSystem;
-
-public class DefaultFileSystem implements FileSystem {
-
-	public DataObject create(DataObject obj) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	public DataObject copy(DataObject Obj, DataStore destStore) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	public DataObject copy(DataObject obj, DataObject destObj) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	public DataObject move(DataObject srcObj, DataObject destObj) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	public boolean delete(DataObject obj) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	public long getStats(DataObject obj) {
-		// TODO Auto-generated method stub
-		return 0;
-	}
-
-	public String getFileType() {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	public boolean isWritable(DataObject obj) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	public boolean contains(DataObject obj) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	public DataObject ioctl(DataObject obj, Object... objects) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDao.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDao.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDao.java
new file mode 100644
index 0000000..b336ffa
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDao.java
@@ -0,0 +1,71 @@
+/*
+ * 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 org.apache.cloudstack.storage.image.db;
+
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
+import com.cloud.domain.DomainVO;
+import com.cloud.hypervisor.Hypervisor.HypervisorType;
+import com.cloud.projects.Project.ListProjectResourcesCriteria;
+import com.cloud.template.VirtualMachineTemplate.TemplateFilter;
+import com.cloud.user.Account;
+import com.cloud.utils.Pair;
+import com.cloud.utils.db.GenericDao;
+
+public interface ImageDataDao extends GenericDao<ImageDataVO, Long> {
+	public List<ImageDataVO> listByPublic();
+	public ImageDataVO findByName(String templateName);
+	public ImageDataVO findByTemplateName(String templateName);	
+
+	//public void update(ImageDataVO template);
+
+
+	public List<ImageDataVO> listAllSystemVMTemplates();
+
+	public List<ImageDataVO> listDefaultBuiltinTemplates();
+	public String getRoutingTemplateUniqueName();
+	public List<ImageDataVO> findIsosByIdAndPath(Long domainId, Long accountId, String path);
+	public List<ImageDataVO> listReadyTemplates();
+	public List<ImageDataVO> listByAccountId(long accountId);
+	public Set<Pair<Long, Long>> searchTemplates(String name, String keyword, TemplateFilter templateFilter, boolean isIso,
+	        List<HypervisorType> hypers, Boolean bootable, DomainVO domain, Long pageSize, Long startIndex, Long zoneId,
+	        HypervisorType hyperType, boolean onlyReady, boolean showDomr, List<Account> permittedAccounts, Account caller,
+	        ListProjectResourcesCriteria listProjectResourcesCriteria, Map<String, String> tags);
+	
+    public Set<Pair<Long, Long>> searchSwiftTemplates(String name, String keyword, TemplateFilter templateFilter,
+            boolean isIso, List<HypervisorType> hypers, Boolean bootable, DomainVO domain, Long pageSize, Long startIndex,
+            Long zoneId, HypervisorType hyperType, boolean onlyReady, boolean showDomr, List<Account> permittedAccounts, Account caller, Map<String, String> tags);
+
+	public long addTemplateToZone(ImageDataVO tmplt, long zoneId);
+	public List<ImageDataVO> listAllInZone(long dataCenterId);	
+	
+    public List<ImageDataVO> listByHypervisorType(List<HypervisorType> hyperTypes);
+	public List<ImageDataVO> publicIsoSearch(Boolean bootable, boolean listRemoved, Map<String, String> tags);
+	public List<ImageDataVO> userIsoSearch(boolean listRemoved);
+    ImageDataVO findSystemVMTemplate(long zoneId);
+    ImageDataVO findSystemVMTemplate(long zoneId, HypervisorType hType);
+
+    ImageDataVO findRoutingTemplate(HypervisorType type);
+    List<Long> listPrivateTemplatesByHost(Long hostId);
+    public Long countTemplatesForAccount(long accountId);
+	
+}
+

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3423c5d7/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDaoImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDaoImpl.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDaoImpl.java
new file mode 100644
index 0000000..8ba5575
--- /dev/null
+++ b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDaoImpl.java
@@ -0,0 +1,925 @@
+/*
+ * 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 org.apache.cloudstack.storage.image.db;
+
+import java.sql.PreparedStatement;
+import java.sql.ResultSet;
+import java.sql.SQLException;
+import java.util.ArrayList;
+import java.util.Date;
+import java.util.HashSet;
+import java.util.LinkedHashSet;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
+import javax.naming.ConfigurationException;
+
+import org.apache.cloudstack.storage.image.format.ISO;
+import org.apache.log4j.Logger;
+import org.springframework.stereotype.Component;
+
+import com.cloud.api.BaseCmd;
+import com.cloud.configuration.dao.ConfigurationDao;
+import com.cloud.dc.dao.DataCenterDao;
+import com.cloud.domain.DomainVO;
+import com.cloud.domain.dao.DomainDao;
+import com.cloud.host.Host;
+import com.cloud.host.HostVO;
+import com.cloud.host.dao.HostDao;
+import com.cloud.hypervisor.Hypervisor.HypervisorType;
+import com.cloud.projects.Project.ListProjectResourcesCriteria;
+import com.cloud.server.ResourceTag.TaggedResourceType;
+import com.cloud.storage.Storage;
+import com.cloud.storage.VMTemplateZoneVO;
+import com.cloud.storage.Storage.TemplateType;
+import com.cloud.storage.VMTemplateStorageResourceAssoc.Status;
+import com.cloud.storage.dao.VMTemplateDaoImpl;
+import com.cloud.storage.dao.VMTemplateDetailsDao;
+import com.cloud.storage.dao.VMTemplateZoneDao;
+import com.cloud.tags.ResourceTagVO;
+import com.cloud.tags.dao.ResourceTagsDaoImpl;
+import com.cloud.template.VirtualMachineTemplate.TemplateFilter;
+import com.cloud.user.Account;
+import com.cloud.utils.Pair;
+import com.cloud.utils.component.ComponentLocator;
+import com.cloud.utils.component.Inject;
+import com.cloud.utils.db.DB;
+import com.cloud.utils.db.Filter;
+import com.cloud.utils.db.GenericDaoBase;
+import com.cloud.utils.db.GenericSearchBuilder;
+import com.cloud.utils.db.JoinBuilder;
+import com.cloud.utils.db.SearchBuilder;
+import com.cloud.utils.db.SearchCriteria;
+import com.cloud.utils.db.Transaction;
+import com.cloud.utils.db.SearchCriteria.Func;
+import com.cloud.utils.exception.CloudRuntimeException;
+
+@Component
+public class ImageDataDaoImpl extends GenericDaoBase<ImageDataVO, Long> implements ImageDataDao {
+    private static final Logger s_logger = Logger.getLogger(VMTemplateDaoImpl.class);
+    
+    @Inject
+    VMTemplateZoneDao _templateZoneDao;
+    @Inject
+    VMTemplateDetailsDao _templateDetailsDao;
+    
+    @Inject
+    ConfigurationDao  _configDao;
+    @Inject
+    HostDao   _hostDao;
+    @Inject
+    DomainDao _domainDao;
+    @Inject
+    DataCenterDao _dcDao;
+    private final String SELECT_TEMPLATE_HOST_REF = "SELECT t.id, h.data_center_id, t.unique_name, t.name, t.public, t.featured, t.type, t.hvm, t.bits, t.url, t.format, t.created, t.account_id, " +
+    								"t.checksum, t.display_text, t.enable_password, t.guest_os_id, t.bootable, t.prepopulate, t.cross_zones, t.hypervisor_type FROM vm_template t";
+    
+    private final String SELECT_TEMPLATE_ZONE_REF = "SELECT t.id, tzr.zone_id, t.unique_name, t.name, t.public, t.featured, t.type, t.hvm, t.bits, t.url, t.format, t.created, t.account_id, " +
+									"t.checksum, t.display_text, t.enable_password, t.guest_os_id, t.bootable, t.prepopulate, t.cross_zones, t.hypervisor_type FROM vm_template t INNER JOIN template_zone_ref tzr on (t.id = tzr.template_id) ";
+    
+    private final String SELECT_TEMPLATE_SWIFT_REF = "SELECT t.id, t.unique_name, t.name, t.public, t.featured, t.type, t.hvm, t.bits, t.url, t.format, t.created, t.account_id, "
+            + "t.checksum, t.display_text, t.enable_password, t.guest_os_id, t.bootable, t.prepopulate, t.cross_zones, t.hypervisor_type FROM vm_template t";
+    protected SearchBuilder<ImageDataVO> TemplateNameSearch;
+    protected SearchBuilder<ImageDataVO> UniqueNameSearch;
+    protected SearchBuilder<ImageDataVO> tmpltTypeSearch;
+    protected SearchBuilder<ImageDataVO> tmpltTypeHyperSearch;
+    protected SearchBuilder<ImageDataVO> tmpltTypeHyperSearch2;
+
+    protected SearchBuilder<ImageDataVO> AccountIdSearch;
+    protected SearchBuilder<ImageDataVO> NameSearch;
+    protected SearchBuilder<ImageDataVO> TmpltsInZoneSearch;
+    private SearchBuilder<ImageDataVO> PublicSearch;
+    private SearchBuilder<ImageDataVO> NameAccountIdSearch;
+    private SearchBuilder<ImageDataVO> PublicIsoSearch;
+    private SearchBuilder<ImageDataVO> UserIsoSearch;
+    private GenericSearchBuilder<ImageDataVO, Long> CountTemplatesByAccount;
+
+    ResourceTagsDaoImpl _tagsDao = ComponentLocator.inject(ResourceTagsDaoImpl.class);
+
+
+    private String routerTmpltName;
+    private String consoleProxyTmpltName;
+    
+    protected ImageDataDaoImpl() {
+    }
+    
+    @Override
+    public List<ImageDataVO> listByPublic() {
+    	SearchCriteria<ImageDataVO> sc = PublicSearch.create();
+    	sc.setParameters("public", 1);
+	    return listBy(sc);
+	}
+    
+	@Override
+	public ImageDataVO findByName(String templateName) {
+		SearchCriteria<ImageDataVO> sc = UniqueNameSearch.create();
+		sc.setParameters("uniqueName", templateName);
+		return findOneIncludingRemovedBy(sc);
+	}
+
+	@Override
+	public ImageDataVO findByTemplateName(String templateName) {
+		SearchCriteria<ImageDataVO> sc = NameSearch.create();
+		sc.setParameters("name", templateName);
+		return findOneIncludingRemovedBy(sc);
+	}
+
+    @Override
+    public List<ImageDataVO> publicIsoSearch(Boolean bootable, boolean listRemoved, Map<String, String> tags){
+        
+        SearchBuilder<ImageDataVO> sb = null;
+        if (tags == null || tags.isEmpty()) {
+            sb = PublicIsoSearch;
+        } else {
+            sb = createSearchBuilder();
+            sb.and("public", sb.entity().isPublicTemplate(), SearchCriteria.Op.EQ);
+            sb.and("format", sb.entity().getFormat(), SearchCriteria.Op.EQ);
+            sb.and("type", sb.entity().getTemplateType(), SearchCriteria.Op.EQ);
+            sb.and("bootable", sb.entity().isBootable(), SearchCriteria.Op.EQ);
+            sb.and("removed", sb.entity().getRemoved(), SearchCriteria.Op.EQ);
+            
+            SearchBuilder<ResourceTagVO> tagSearch = _tagsDao.createSearchBuilder();
+            for (int count=0; count < tags.size(); count++) {
+                tagSearch.or().op("key" + String.valueOf(count), tagSearch.entity().getKey(), SearchCriteria.Op.EQ);
+                tagSearch.and("value" + String.valueOf(count), tagSearch.entity().getValue(), SearchCriteria.Op.EQ);
+                tagSearch.cp();
+            }
+            tagSearch.and("resourceType", tagSearch.entity().getResourceType(), SearchCriteria.Op.EQ);
+            sb.groupBy(sb.entity().getId());
+            sb.join("tagSearch", tagSearch, sb.entity().getId(), tagSearch.entity().getResourceId(), JoinBuilder.JoinType.INNER);
+        }
+        
+        SearchCriteria<ImageDataVO> sc = sb.create();
+        
+    	sc.setParameters("public", 1);
+    	sc.setParameters("format", "ISO");
+    	sc.setParameters("type", TemplateType.PERHOST.toString());
+    	if (bootable != null) {
+    	    sc.setParameters("bootable", bootable);
+    	}
+    	
+    	if (!listRemoved) {
+    		sc.setParameters("removed", (Object)null);
+    	}
+    	
+    	if (tags != null && !tags.isEmpty()) {
+            int count = 0;
+            sc.setJoinParameters("tagSearch", "resourceType", TaggedResourceType.ISO.toString());
+            for (String key : tags.keySet()) {
+                sc.setJoinParameters("tagSearch", "key" + String.valueOf(count), key);
+                sc.setJoinParameters("tagSearch", "value" + String.valueOf(count), tags.get(key));
+                count++;
+            }
+        }
+    	
+        return listBy(sc);
+    }
+    
+    @Override
+    public List<ImageDataVO> userIsoSearch(boolean listRemoved){
+
+        SearchBuilder<ImageDataVO> sb = null;
+        sb = UserIsoSearch;
+        SearchCriteria<ImageDataVO> sc = sb.create();
+
+        sc.setParameters("format", Storage.ImageFormat.ISO);
+        sc.setParameters("type", TemplateType.USER.toString());
+
+        if (!listRemoved) {
+            sc.setParameters("removed", (Object)null);
+        }
+
+        return listBy(sc);
+    }
+	@Override
+	public List<ImageDataVO> listAllSystemVMTemplates() {
+		SearchCriteria<ImageDataVO> sc = tmpltTypeSearch.create();
+		sc.setParameters("templateType", Storage.TemplateType.SYSTEM);
+		
+		Filter filter = new Filter(ImageDataVO.class, "id", false, null, null);
+		return listBy(sc, filter);
+	}
+
+    @Override
+    public List<Long> listPrivateTemplatesByHost(Long hostId) {
+
+        String sql = "select * from template_host_ref as thr INNER JOIN vm_template as t ON t.id=thr.template_id " 
+            + "where thr.host_id=? and t.public=0 and t.featured=0 and t.type='USER' and t.removed is NULL";
+
+        List<Long> l = new ArrayList<Long>();
+
+        Transaction txn = Transaction.currentTxn();
+
+        PreparedStatement pstmt = null;
+        try {
+            pstmt = txn.prepareAutoCloseStatement(sql);
+            pstmt.setLong(1, hostId);
+            ResultSet rs = pstmt.executeQuery();
+            while (rs.next()) {
+                l.add(rs.getLong(1));
+            }
+        } catch (SQLException e) {
+        } catch (Throwable e) {
+        }
+        return l;
+    }
+	
+	@Override
+	public List<ImageDataVO> listReadyTemplates() {
+		SearchCriteria<ImageDataVO> sc = createSearchCriteria();
+		sc.addAnd("ready", SearchCriteria.Op.EQ, true);
+		sc.addAnd("format", SearchCriteria.Op.NEQ, Storage.ImageFormat.ISO);
+		return listIncludingRemovedBy(sc);
+	}
+	
+	@Override
+	public List<ImageDataVO> findIsosByIdAndPath(Long domainId, Long accountId, String path) {
+		SearchCriteria<ImageDataVO> sc = createSearchCriteria();
+		sc.addAnd("iso", SearchCriteria.Op.EQ, true);
+		if (domainId != null) {
+            sc.addAnd("domainId", SearchCriteria.Op.EQ, domainId);
+        }
+		if (accountId != null) {
+            sc.addAnd("accountId", SearchCriteria.Op.EQ, accountId);
+        }
+		if (path != null) {
+            sc.addAnd("path", SearchCriteria.Op.EQ, path);
+        }
+		return listIncludingRemovedBy(sc);
+	}
+
+	@Override
+	public List<ImageDataVO> listByAccountId(long accountId) {
+        SearchCriteria<ImageDataVO> sc = AccountIdSearch.create();
+        sc.setParameters("accountId", accountId);
+        return listBy(sc);
+	}
+	
+	@Override
+    public List<ImageDataVO> listByHypervisorType(List<HypervisorType> hyperTypes) {
+		SearchCriteria<ImageDataVO> sc = createSearchCriteria();
+        hyperTypes.add(HypervisorType.None);
+        sc.addAnd("hypervisorType", SearchCriteria.Op.IN, hyperTypes.toArray());
+		return listBy(sc);
+	}
+
+	@Override
+	public boolean configure(String name, Map<String, Object> params) throws ConfigurationException {
+		boolean result = super.configure(name, params);
+		
+	    PublicSearch = createSearchBuilder();
+	    PublicSearch.and("public", PublicSearch.entity().isPublicTemplate(), SearchCriteria.Op.EQ);
+
+		routerTmpltName = (String)params.get("routing.uniquename");
+		
+		s_logger.debug("Found parameter routing unique name " + routerTmpltName);
+		if (routerTmpltName==null) {
+			routerTmpltName="routing";
+		}
+		
+		consoleProxyTmpltName = (String)params.get("consoleproxy.uniquename");
+		if(consoleProxyTmpltName == null) {
+            consoleProxyTmpltName = "routing";
+        }
+		if(s_logger.isDebugEnabled()) {
+            s_logger.debug("Use console proxy template : " + consoleProxyTmpltName);
+        }
+
+		UniqueNameSearch = createSearchBuilder();
+		UniqueNameSearch.and("uniqueName", UniqueNameSearch.entity().getUniqueName(), SearchCriteria.Op.EQ);
+		NameSearch = createSearchBuilder();
+		NameSearch.and("name", NameSearch.entity().getName(), SearchCriteria.Op.EQ);
+
+		NameAccountIdSearch = createSearchBuilder();
+		NameAccountIdSearch.and("name", NameAccountIdSearch.entity().getName(), SearchCriteria.Op.EQ);
+		NameAccountIdSearch.and("accountId", NameAccountIdSearch.entity().getAccountId(), SearchCriteria.Op.EQ);
+
+		PublicIsoSearch = createSearchBuilder();
+		PublicIsoSearch.and("public", PublicIsoSearch.entity().isPublicTemplate(), SearchCriteria.Op.EQ);
+		PublicIsoSearch.and("format", PublicIsoSearch.entity().getFormat(), SearchCriteria.Op.EQ);
+		PublicIsoSearch.and("type", PublicIsoSearch.entity().getTemplateType(), SearchCriteria.Op.EQ);
+		PublicIsoSearch.and("bootable", PublicIsoSearch.entity().isBootable(), SearchCriteria.Op.EQ);
+		PublicIsoSearch.and("removed", PublicIsoSearch.entity().getRemoved(), SearchCriteria.Op.EQ);
+
+		UserIsoSearch = createSearchBuilder();
+		UserIsoSearch.and("format", UserIsoSearch.entity().getFormat(), SearchCriteria.Op.EQ);
+		UserIsoSearch.and("type", UserIsoSearch.entity().getTemplateType(), SearchCriteria.Op.EQ);
+		UserIsoSearch.and("removed", UserIsoSearch.entity().getRemoved(), SearchCriteria.Op.EQ);
+
+		tmpltTypeHyperSearch = createSearchBuilder();
+		tmpltTypeHyperSearch.and("templateType", tmpltTypeHyperSearch.entity().getTemplateType(), SearchCriteria.Op.EQ);
+		SearchBuilder<HostVO> hostHyperSearch = _hostDao.createSearchBuilder();
+		hostHyperSearch.and("type", hostHyperSearch.entity().getType(), SearchCriteria.Op.EQ);
+		hostHyperSearch.and("zoneId", hostHyperSearch.entity().getDataCenterId(), SearchCriteria.Op.EQ);
+		hostHyperSearch.groupBy(hostHyperSearch.entity().getHypervisorType());
+		
+		tmpltTypeHyperSearch.join("tmplHyper", hostHyperSearch, hostHyperSearch.entity().getHypervisorType(), tmpltTypeHyperSearch.entity().getHypervisorType(), JoinBuilder.JoinType.INNER);
+		hostHyperSearch.done();
+		tmpltTypeHyperSearch.done();
+		
+		tmpltTypeHyperSearch2 = createSearchBuilder();
+		tmpltTypeHyperSearch2.and("templateType", tmpltTypeHyperSearch2.entity().getTemplateType(), SearchCriteria.Op.EQ);
+		tmpltTypeHyperSearch2.and("hypervisorType", tmpltTypeHyperSearch2.entity().getHypervisorType(), SearchCriteria.Op.EQ);
+
+		
+		tmpltTypeSearch = createSearchBuilder();
+        tmpltTypeSearch.and("removed", tmpltTypeSearch.entity().getRemoved(), SearchCriteria.Op.NULL);
+		tmpltTypeSearch.and("templateType", tmpltTypeSearch.entity().getTemplateType(), SearchCriteria.Op.EQ);
+
+		AccountIdSearch = createSearchBuilder();
+		AccountIdSearch.and("accountId", AccountIdSearch.entity().getAccountId(), SearchCriteria.Op.EQ);
+        AccountIdSearch.and("publicTemplate", AccountIdSearch.entity().isPublicTemplate(), SearchCriteria.Op.EQ);
+		AccountIdSearch.done();
+		
+		SearchBuilder<VMTemplateZoneVO> tmpltZoneSearch = _templateZoneDao.createSearchBuilder();
+		tmpltZoneSearch.and("removed", tmpltZoneSearch.entity().getRemoved(), SearchCriteria.Op.NULL);
+		tmpltZoneSearch.and("zoneId", tmpltZoneSearch.entity().getZoneId(), SearchCriteria.Op.EQ);
+		
+		TmpltsInZoneSearch = createSearchBuilder();
+		TmpltsInZoneSearch.and("removed", TmpltsInZoneSearch.entity().getRemoved(), SearchCriteria.Op.NULL);
+		TmpltsInZoneSearch.and().op("avoidtype", TmpltsInZoneSearch.entity().getTemplateType(), SearchCriteria.Op.NEQ);
+		TmpltsInZoneSearch.or("templateType", TmpltsInZoneSearch.entity().getTemplateType(), SearchCriteria.Op.NULL);
+		TmpltsInZoneSearch.cp();
+		TmpltsInZoneSearch.join("tmpltzone", tmpltZoneSearch, tmpltZoneSearch.entity().getTemplateId(), TmpltsInZoneSearch.entity().getId(), JoinBuilder.JoinType.INNER);
+		tmpltZoneSearch.done();
+		TmpltsInZoneSearch.done();
+
+		CountTemplatesByAccount = createSearchBuilder(Long.class);
+		CountTemplatesByAccount.select(null, Func.COUNT, null);        
+		CountTemplatesByAccount.and("account", CountTemplatesByAccount.entity().getAccountId(), SearchCriteria.Op.EQ);
+		CountTemplatesByAccount.and("removed", CountTemplatesByAccount.entity().getRemoved(), SearchCriteria.Op.NULL);
+		CountTemplatesByAccount.done();
+
+		return result;
+	}
+
+	@Override
+	public String getRoutingTemplateUniqueName() {
+		return routerTmpltName;
+	}
+
+    @Override
+    public Set<Pair<Long, Long>> searchSwiftTemplates(String name, String keyword, TemplateFilter templateFilter, boolean isIso, List<HypervisorType> hypers, Boolean bootable, DomainVO domain,
+            Long pageSize, Long startIndex, Long zoneId, HypervisorType hyperType, boolean onlyReady, boolean showDomr, List<Account> permittedAccounts, Account caller, Map<String, String> tags) {
+
+        StringBuilder builder = new StringBuilder();
+        if (!permittedAccounts.isEmpty()) {
+            for (Account permittedAccount : permittedAccounts) {
+                builder.append(permittedAccount.getAccountId() + ",");
+            }
+        }
+
+        String permittedAccountsStr = builder.toString();
+
+        if (permittedAccountsStr.length() > 0) {
+            // chop the "," off
+            permittedAccountsStr = permittedAccountsStr.substring(0, permittedAccountsStr.length() - 1);
+        }
+
+        Transaction txn = Transaction.currentTxn();
+        txn.start();
+
+        Set<Pair<Long, Long>> templateZonePairList = new HashSet<Pair<Long, Long>>();
+        PreparedStatement pstmt = null;
+        ResultSet rs = null;
+        String sql = SELECT_TEMPLATE_SWIFT_REF;
+        try {
+            String joinClause = "";
+            String whereClause = " WHERE t.removed IS NULL";
+
+            if (isIso) {
+                whereClause += " AND t.format = 'ISO'";
+                if (!hyperType.equals(HypervisorType.None)) {
+                    joinClause = " INNER JOIN guest_os guestOS on (guestOS.id = t.guest_os_id) INNER JOIN guest_os_hypervisor goh on ( goh.guest_os_id = guestOS.id) ";
+                    whereClause += " AND goh.hypervisor_type = '" + hyperType.toString() + "'";
+                }
+            } else {
+                whereClause += " AND t.format <> 'ISO'";
+                if (hypers.isEmpty()) {
+                    return templateZonePairList;
+                } else {
+                    StringBuilder relatedHypers = new StringBuilder();
+                    for (HypervisorType hyper : hypers) {
+                        relatedHypers.append("'");
+                        relatedHypers.append(hyper.toString());
+                        relatedHypers.append("'");
+                        relatedHypers.append(",");
+                    }
+                    relatedHypers.setLength(relatedHypers.length() - 1);
+                    whereClause += " AND t.hypervisor_type IN (" + relatedHypers + ")";
+                }
+            }
+            joinClause += " INNER JOIN  template_swift_ref tsr on (t.id = tsr.template_id)";
+            if (keyword != null) {
+                whereClause += " AND t.name LIKE \"%" + keyword + "%\"";
+            } else if (name != null) {
+                whereClause += " AND t.name LIKE \"%" + name + "%\"";
+            }
+
+            if (bootable != null) {
+                whereClause += " AND t.bootable = " + bootable;
+            }
+
+            if (!showDomr) {
+                whereClause += " AND t.type != '" + Storage.TemplateType.SYSTEM.toString() + "'";
+            }
+
+            if (templateFilter == TemplateFilter.featured) {
+                whereClause += " AND t.public = 1 AND t.featured = 1";
+            } else if ((templateFilter == TemplateFilter.self || templateFilter == TemplateFilter.selfexecutable) && caller.getType() != Account.ACCOUNT_TYPE_ADMIN) {
+                if (caller.getType() == Account.ACCOUNT_TYPE_DOMAIN_ADMIN || caller.getType() == Account.ACCOUNT_TYPE_RESOURCE_DOMAIN_ADMIN) {
+                    joinClause += " INNER JOIN account a on (t.account_id = a.id) INNER JOIN domain d on (a.domain_id = d.id)";
+                    whereClause += "  AND d.path LIKE '" + domain.getPath() + "%'";
+                } else {
+                    whereClause += " AND t.account_id IN (" + permittedAccountsStr + ")";
+                }
+            } else if (templateFilter == TemplateFilter.sharedexecutable && caller.getType() != Account.ACCOUNT_TYPE_ADMIN) {
+                if (caller.getType() == Account.ACCOUNT_TYPE_NORMAL) {
+                    joinClause += " LEFT JOIN launch_permission lp ON t.id = lp.template_id WHERE" + " (t.account_id IN (" + permittedAccountsStr + ") OR" + " lp.account_id IN ("
+                            + permittedAccountsStr + "))";
+                } else {
+                    joinClause += " INNER JOIN account a on (t.account_id = a.id) ";
+                }
+            } else if (templateFilter == TemplateFilter.executable && !permittedAccounts.isEmpty()) {
+                whereClause += " AND (t.public = 1 OR t.account_id IN (" + permittedAccountsStr + "))";
+            } else if (templateFilter == TemplateFilter.community) {
+                whereClause += " AND t.public = 1 AND t.featured = 0";
+            } else if (templateFilter == TemplateFilter.all && caller.getType() == Account.ACCOUNT_TYPE_ADMIN) {
+            } else if (caller.getType() != Account.ACCOUNT_TYPE_ADMIN) {
+                return templateZonePairList;
+            }
+
+            sql += joinClause + whereClause + getOrderByLimit(pageSize, startIndex);
+            pstmt = txn.prepareStatement(sql);
+            rs = pstmt.executeQuery();
+            while (rs.next()) {
+                Pair<Long, Long> templateZonePair = new Pair<Long, Long>(rs.getLong(1), -1L);
+                templateZonePairList.add(templateZonePair);
+            }
+
+        } catch (Exception e) {
+            s_logger.warn("Error listing templates", e);
+        } finally {
+            try {
+                if (rs != null) {
+                    rs.close();
+                }
+                if (pstmt != null) {
+                    pstmt.close();
+                }
+                txn.commit();
+            } catch (SQLException sqle) {
+                s_logger.warn("Error in cleaning up", sqle);
+            }
+        }
+
+        return templateZonePairList;
+    }
+
+
+	@Override
+	public Set<Pair<Long, Long>> searchTemplates(String name, String keyword, TemplateFilter templateFilter, 
+	        boolean isIso, List<HypervisorType> hypers, Boolean bootable, DomainVO domain, Long pageSize, Long startIndex,
+	        Long zoneId, HypervisorType hyperType, boolean onlyReady, boolean showDomr,List<Account> permittedAccounts,
+	        Account caller, ListProjectResourcesCriteria listProjectResourcesCriteria, Map<String, String> tags) {
+        StringBuilder builder = new StringBuilder();
+        if (!permittedAccounts.isEmpty()) {
+            for (Account permittedAccount : permittedAccounts) {
+                builder.append(permittedAccount.getAccountId() + ",");
+            }
+        }
+        
+        String permittedAccountsStr = builder.toString();
+        
+        if (permittedAccountsStr.length() > 0) {
+            //chop the "," off
+            permittedAccountsStr = permittedAccountsStr.substring(0, permittedAccountsStr.length()-1);
+        }
+	    
+	    Transaction txn = Transaction.currentTxn();
+        txn.start();
+        
+        /* Use LinkedHashSet here to guarantee iteration order */
+        Set<Pair<Long, Long>> templateZonePairList = new LinkedHashSet<Pair<Long, Long>>();
+        PreparedStatement pstmt = null;
+        ResultSet rs = null;
+        StringBuilder relatedDomainIds = new StringBuilder();
+        String sql = SELECT_TEMPLATE_ZONE_REF;
+        String groupByClause = "";
+        try {        	
+        	//short accountType;
+        	//String accountId = null;
+        	String guestOSJoin = "";  
+        	StringBuilder templateHostRefJoin = new StringBuilder();
+        	String dataCenterJoin = "", lpjoin = "";
+        	String tagsJoin = "";
+
+        	if (isIso && !hyperType.equals(HypervisorType.None)) { 
+        		guestOSJoin = " INNER JOIN guest_os guestOS on (guestOS.id = t.guest_os_id) INNER JOIN guest_os_hypervisor goh on ( goh.guest_os_id = guestOS.id) ";
+        	}
+        	if (onlyReady){
+        		templateHostRefJoin.append(" INNER JOIN  template_host_ref thr on (t.id = thr.template_id) INNER JOIN host h on (thr.host_id = h.id)");
+        		sql = SELECT_TEMPLATE_HOST_REF;
+                groupByClause = " GROUP BY t.id, h.data_center_id ";
+        	}
+        	if ((templateFilter == TemplateFilter.featured) || (templateFilter == TemplateFilter.community)) {
+        	    dataCenterJoin = " INNER JOIN data_center dc on (h.data_center_id = dc.id)";
+        	}
+        	
+        	if (templateFilter == TemplateFilter.sharedexecutable){
+        	    lpjoin = " INNER JOIN launch_permission lp ON t.id = lp.template_id ";
+        	}
+        	
+        	if (tags != null && !tags.isEmpty()) {
+        	    tagsJoin = " INNER JOIN resource_tags r ON t.id = r.resource_id ";
+        	}
+        	       	
+        	sql +=  guestOSJoin + templateHostRefJoin + dataCenterJoin + lpjoin + tagsJoin;
+        	String whereClause = "";
+        	
+        	//All joins have to be made before we start setting the condition settings
+        	if ((listProjectResourcesCriteria == ListProjectResourcesCriteria.SkipProjectResources 
+        			|| (!permittedAccounts.isEmpty() && !(templateFilter == TemplateFilter.community || templateFilter == TemplateFilter.featured))) && 
+        			!(caller.getType() != Account.ACCOUNT_TYPE_NORMAL && templateFilter == TemplateFilter.all)) {
+        		whereClause += " INNER JOIN account a on (t.account_id = a.id)";
+        		if ((templateFilter == TemplateFilter.self || templateFilter == TemplateFilter.selfexecutable) && (caller.getType() == Account.ACCOUNT_TYPE_DOMAIN_ADMIN || caller.getType() == Account.ACCOUNT_TYPE_RESOURCE_DOMAIN_ADMIN)) {                	            		
+            		 whereClause += " INNER JOIN domain d on (a.domain_id = d.id) WHERE d.path LIKE '" + domain.getPath() + "%'";     
+             		if (listProjectResourcesCriteria == ListProjectResourcesCriteria.SkipProjectResources) {
+            			whereClause += " AND a.type != " + Account.ACCOUNT_TYPE_PROJECT;
+            		}
+        		} else 
+        			if (listProjectResourcesCriteria == ListProjectResourcesCriteria.SkipProjectResources) {
+        				whereClause += " WHERE a.type != " + Account.ACCOUNT_TYPE_PROJECT;
+        		}
+        	}
+        	
+            if (!permittedAccounts.isEmpty()) {
+                for (Account account : permittedAccounts) {
+                    //accountType = account.getType();
+                    //accountId = Long.toString(account.getId());
+                    DomainVO accountDomain = _domainDao.findById(account.getDomainId());
+
+                    // get all parent domain ID's all the way till root domain
+                    DomainVO domainTreeNode = accountDomain;
+                    while (true) {
+                        relatedDomainIds.append(domainTreeNode.getId());
+                        relatedDomainIds.append(",");
+                        if (domainTreeNode.getParent() != null) {
+                            domainTreeNode = _domainDao.findById(domainTreeNode.getParent());
+                        } else {
+                            break;
+                        }
+                    }
+
+                    // get all child domain ID's
+                    if (isAdmin(account.getType()) ) {
+                        List<DomainVO> allChildDomains = _domainDao.findAllChildren(accountDomain.getPath(), accountDomain.getId());
+                        for (DomainVO childDomain : allChildDomains) {
+                            relatedDomainIds.append(childDomain.getId());
+                            relatedDomainIds.append(",");
+                        }
+                    }
+                    relatedDomainIds.setLength(relatedDomainIds.length()-1);
+                }
+            }
+            
+            String attr = " AND ";
+            if (whereClause.endsWith(" WHERE ")) {
+            	attr += " WHERE ";
+            }
+            
+            if (!isIso) {
+        	    if ( hypers.isEmpty() ) {
+        	        return templateZonePairList;
+        	    } else {
+        	        StringBuilder relatedHypers = new StringBuilder();
+        	        for (HypervisorType hyper : hypers ) {
+        	            relatedHypers.append("'");
+        	            relatedHypers.append(hyper.toString());
+                        relatedHypers.append("'");
+        	            relatedHypers.append(",");
+        	        }
+        	        relatedHypers.setLength(relatedHypers.length()-1);
+                    whereClause += attr + " t.hypervisor_type IN (" + relatedHypers + ")";
+        	    }
+        	}
+            
+            if (!permittedAccounts.isEmpty() && !(templateFilter == TemplateFilter.featured || 
+                    templateFilter == TemplateFilter.community || templateFilter == TemplateFilter.executable)  && !isAdmin(caller.getType()) ) {
+            	whereClause += attr + "t.account_id IN (" + permittedAccountsStr + ")";
+            }
+
+        	if (templateFilter == TemplateFilter.featured) {
+            	whereClause += attr + "t.public = 1 AND t.featured = 1";
+            	if (!permittedAccounts.isEmpty()) {
+            	    whereClause += attr + "(dc.domain_id IN (" + relatedDomainIds + ") OR dc.domain_id is NULL)";
+            	}            	            
+            } else if (templateFilter == TemplateFilter.self || templateFilter == TemplateFilter.selfexecutable) {
+                whereClause += " AND t.account_id IN (" + permittedAccountsStr + ")";
+            } else if (templateFilter == TemplateFilter.sharedexecutable) {
+            		whereClause += " AND " +
+                	" (t.account_id IN (" + permittedAccountsStr + ") OR" +
+                	" lp.account_id IN (" + permittedAccountsStr + "))";	
+            } else if (templateFilter == TemplateFilter.executable && !permittedAccounts.isEmpty()) {
+            	whereClause += attr + "(t.public = 1 OR t.account_id IN (" + permittedAccountsStr + "))";
+            } else if (templateFilter == TemplateFilter.community) {
+            	whereClause += attr + "t.public = 1 AND t.featured = 0";
+            	if (!permittedAccounts.isEmpty()) {
+            	    whereClause += attr + "(dc.domain_id IN (" + relatedDomainIds + ") OR dc.domain_id is NULL)";
+            	}
+            } else if (caller.getType() != Account.ACCOUNT_TYPE_ADMIN && !isIso) {
+            	return templateZonePairList;
+            }
+        	
+        	if (tags != null && !tags.isEmpty()) {
+        	    whereClause += " AND (";
+        	    boolean first = true;
+        	    for (String key : tags.keySet()) {
+        	        if (!first) {
+        	            whereClause += " OR ";
+        	        }
+        	        whereClause += "(r.key=\"" + key + "\" and r.value=\"" + tags.get(key) + "\")";
+        	        first = false;
+        	    }
+        	    whereClause += ")";
+        	}
+            
+            if (whereClause.equals("")) {
+            	whereClause += " WHERE ";
+            } else if (!whereClause.equals(" WHERE ")) {
+            	whereClause += " AND ";
+            }
+            
+            sql += whereClause + getExtrasWhere(templateFilter, name, keyword, isIso, bootable, hyperType, zoneId,
+                    onlyReady, showDomr) + groupByClause + getOrderByLimit(pageSize, startIndex);
+
+            pstmt = txn.prepareStatement(sql);
+            rs = pstmt.executeQuery();
+
+            while (rs.next()) {
+               Pair<Long, Long> templateZonePair = new Pair<Long, Long>(rs.getLong(1), rs.getLong(2));
+                               templateZonePairList.add(templateZonePair);
+            }
+           //for now, defaulting pageSize to a large val if null; may need to revisit post 2.2RC2 
+           if(isIso && templateZonePairList.size() < (pageSize != null ? pageSize : 500) 
+                   && templateFilter != TemplateFilter.community
+                   && !(templateFilter == TemplateFilter.self && !BaseCmd.isRootAdmin(caller.getType())) ){ //evaluates to true If root admin and filter=self
+
+               List<ImageDataVO> publicIsos = publicIsoSearch(bootable, false, tags);
+               List<ImageDataVO> userIsos = userIsoSearch(false);
+
+               //Listing the ISOs according to the page size.Restricting the total no. of ISOs on a page
+               //to be less than or equal to the pageSize parameter
+
+               int i=0;
+
+               if (startIndex > userIsos.size()) {
+                   i=(int) (startIndex - userIsos.size());
+               }
+
+               for (; i < publicIsos.size(); i++) {
+                   if(templateZonePairList.size() >= pageSize){
+                        break;
+                        } else {
+                        if (keyword != null && publicIsos.get(i).getName().contains(keyword)) {
+                            templateZonePairList.add(new Pair<Long,Long>(publicIsos.get(i).getId(), null));
+                            continue;
+                        } else if (name != null && publicIsos.get(i).getName().contains(name)) {
+                            templateZonePairList.add(new Pair<Long,Long>(publicIsos.get(i).getId(), null));
+                            continue;
+                        } else if (keyword == null && name == null){
+                            templateZonePairList.add(new Pair<Long,Long>(publicIsos.get(i).getId(), null));
+                        }
+                      }
+                    }
+                }
+        } catch (Exception e) {
+            s_logger.warn("Error listing templates", e);
+        } finally {
+        	try {
+        		if (rs != null) {
+        			rs.close();
+        		}
+        		if (pstmt != null) {
+        			pstmt.close();
+        		}
+        		txn.commit();
+        	} catch( SQLException sqle) {
+        		s_logger.warn("Error in cleaning up", sqle);
+        	}
+        }
+        
+        return templateZonePairList;
+	}
+
+	private String getExtrasWhere(TemplateFilter templateFilter, String name, String keyword, boolean isIso, Boolean bootable, HypervisorType hyperType, Long zoneId, boolean onlyReady, boolean showDomr) {
+	    String sql = "";
+        if (keyword != null) {
+            sql += " t.name LIKE \"%" + keyword + "%\" AND";
+        } else if (name != null) {
+            sql += " t.name LIKE \"%" + name + "%\" AND";
+        }
+
+        if (isIso) {
+            sql += " t.format = 'ISO'";
+            if (!hyperType.equals(HypervisorType.None)) {
+            	sql += " AND goh.hypervisor_type = '" + hyperType.toString() + "'";
+            }
+        } else {
+            sql += " t.format <> 'ISO'";
+            if (!hyperType.equals(HypervisorType.None)) {
+            	sql += " AND t.hypervisor_type = '" + hyperType.toString() + "'";
+            }
+        }
+        
+        if (bootable != null) {
+        	sql += " AND t.bootable = " + bootable;
+        }
+
+        if (onlyReady){
+        	sql += " AND thr.download_state = '" +Status.DOWNLOADED.toString() + "'" + " AND thr.destroyed=0 ";
+        	if (zoneId != null){
+        		sql += " AND h.data_center_id = " +zoneId;
+            }
+        }else if (zoneId != null){
+        	sql += " AND tzr.zone_id = " +zoneId+ " AND tzr.removed is null" ;
+        }else{
+        	sql += " AND tzr.removed is null ";
+        }
+        if (!showDomr){
+        	sql += " AND t.type != '" +Storage.TemplateType.SYSTEM.toString() + "'";
+        }        
+
+        sql += " AND t.removed IS NULL";
+
+        return sql;
+	}
+
+	private String getOrderByLimit(Long pageSize, Long startIndex) {
+    	Boolean isAscending = Boolean.parseBoolean(_configDao.getValue("sortkey.algorithm"));
+    	isAscending = (isAscending == null ? true : isAscending);
+    	
+		String sql;
+		if (isAscending) {
+			sql = " ORDER BY t.sort_key ASC";
+		} else {
+			sql = " ORDER BY t.sort_key DESC";
+		}
+    	
+        if ((pageSize != null) && (startIndex != null)) {
+            sql += " LIMIT " + startIndex.toString() + "," + pageSize.toString();
+        }
+        return sql;
+	}
+
+	@Override
+	@DB
+	public long addTemplateToZone(ImageDataVO tmplt, long zoneId) {
+		Transaction txn = Transaction.currentTxn();
+		txn.start();
+		ImageDataVO tmplt2 = findById(tmplt.getId());
+		if (tmplt2 == null){
+			if (persist(tmplt) == null) {
+				throw new CloudRuntimeException("Failed to persist the template " + tmplt);
+			}
+			if(tmplt.getDetails() != null) {
+				_templateDetailsDao.persist(tmplt.getId(), tmplt.getDetails());
+			}
+		}
+		VMTemplateZoneVO tmpltZoneVO = _templateZoneDao.findByZoneTemplate(zoneId, tmplt.getId());
+		if (tmpltZoneVO == null ) {
+		    tmpltZoneVO = new VMTemplateZoneVO(zoneId, tmplt.getId(), new Date());
+		    _templateZoneDao.persist(tmpltZoneVO);
+		} else {
+		    tmpltZoneVO.setRemoved(null);
+		    tmpltZoneVO.setLastUpdated(new Date());
+		    _templateZoneDao.update(tmpltZoneVO.getId(), tmpltZoneVO);
+		}
+		txn.commit();
+		
+		return tmplt.getId();
+	}
+
+	@Override
+	@DB
+	public List<ImageDataVO> listAllInZone(long dataCenterId) {
+		SearchCriteria<ImageDataVO> sc = TmpltsInZoneSearch.create();
+		sc.setParameters("avoidtype", TemplateType.PERHOST.toString());
+		sc.setJoinParameters("tmpltzone", "zoneId", dataCenterId);
+		return listBy(sc);
+	}
+
+	@Override
+	public List<ImageDataVO> listDefaultBuiltinTemplates() {
+		SearchCriteria<ImageDataVO> sc = tmpltTypeSearch.create();
+		sc.setParameters("templateType", Storage.TemplateType.BUILTIN);
+		return listBy(sc);
+	}
+	
+	@Override
+	public ImageDataVO findSystemVMTemplate(long zoneId) {
+		SearchCriteria<ImageDataVO> sc = tmpltTypeHyperSearch.create();
+		sc.setParameters("templateType", Storage.TemplateType.SYSTEM);
+		sc.setJoinParameters("tmplHyper",  "type", Host.Type.Routing);
+		sc.setJoinParameters("tmplHyper", "zoneId", zoneId);
+
+		//order by descending order of id and select the first (this is going to be the latest)
+		List<ImageDataVO> tmplts = listBy(sc, new Filter(ImageDataVO.class, "id", false, null, 1l));
+		
+		if (tmplts.size() > 0) {
+			return tmplts.get(0);
+		} else {
+			return null;
+		}
+	}
+	
+	public ImageDataVO findSystemVMTemplate(long zoneId, HypervisorType hType) {
+	    SearchCriteria<ImageDataVO> sc = tmpltTypeHyperSearch.create();
+	    sc.setParameters("templateType", Storage.TemplateType.SYSTEM);
+	    sc.setJoinParameters("tmplHyper",  "type", Host.Type.Routing);
+	    sc.setJoinParameters("tmplHyper", "zoneId", zoneId);
+
+	    //order by descending order of id
+	    List<ImageDataVO> tmplts = listBy(sc, new Filter(ImageDataVO.class, "id", false, null, null));
+
+	    for (ImageDataVO tmplt: tmplts) {
+	        if (tmplt.getHypervisorType() == hType) {
+	            return tmplt;
+	        }
+	    }
+	    if (tmplts.size() > 0 && hType == HypervisorType.Any) {
+	        return tmplts.get(0);
+	    }
+	    return null;
+	}
+
+	@Override
+	public ImageDataVO findRoutingTemplate(HypervisorType hType) {
+	    SearchCriteria<ImageDataVO> sc = tmpltTypeHyperSearch2.create();
+        sc.setParameters("templateType", Storage.TemplateType.SYSTEM);
+        sc.setParameters("hypervisorType", hType);
+
+        //order by descending order of id and select the first (this is going to be the latest)
+        List<ImageDataVO> tmplts = listBy(sc, new Filter(ImageDataVO.class, "id", false, null, 1l));
+        
+        if (tmplts.size() > 0) {
+            return tmplts.get(0);
+        } else {
+            return null;
+        }
+	}
+
+    @Override
+    public Long countTemplatesForAccount(long accountId) {
+    	SearchCriteria<Long> sc = CountTemplatesByAccount.create();
+        sc.setParameters("account", accountId);
+        return customSearch(sc, null).get(0);
+    }
+    
+    @Override
+    @DB
+    public boolean remove(Long id) {
+        Transaction txn = Transaction.currentTxn();
+        txn.start();
+        ImageDataVO template = createForUpdate();
+        template.setRemoved(new Date());
+        
+        ImageDataVO vo = findById(id);
+        if (vo != null) {
+            if (vo.getFormat().equalsIgnoreCase(new ISO().toString())) {
+                _tagsDao.removeByIdAndType(id, TaggedResourceType.ISO);
+            } else {
+                _tagsDao.removeByIdAndType(id, TaggedResourceType.Template);
+            }
+        }
+
+        boolean result = update(id, template);
+        txn.commit();
+        return result;
+    }
+    
+    private boolean isAdmin(short accountType) {
+	    return ((accountType == Account.ACCOUNT_TYPE_ADMIN) ||
+	    	    (accountType == Account.ACCOUNT_TYPE_RESOURCE_DOMAIN_ADMIN) ||
+	            (accountType == Account.ACCOUNT_TYPE_DOMAIN_ADMIN) ||
+	            (accountType == Account.ACCOUNT_TYPE_READ_ONLY_ADMIN));
+	}
+    
+}
\ No newline at end of file