You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by ah...@apache.org on 2012/11/05 18:23:43 UTC

[15/18] Moved platform to engine

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/ImageOrchestratorImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/ImageOrchestratorImpl.java b/platform/storage/src/org/apache/cloudstack/storage/image/ImageOrchestratorImpl.java
deleted file mode 100644
index 43c262d..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/ImageOrchestratorImpl.java
+++ /dev/null
@@ -1,78 +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.image;
-
-import java.util.List;
-
-import org.apache.cloudstack.platform.subsystem.api.storage.DataStore;
-import org.apache.cloudstack.platform.subsystem.api.storage.SnapshotProfile;
-import org.apache.cloudstack.platform.subsystem.api.storage.TemplateStrategy;
-import org.apache.cloudstack.platform.subsystem.api.storage.VolumeProfile;
-import org.apache.cloudstack.storage.manager.SecondaryStorageManager;
-
-import com.cloud.storage.TemplateProfile;
-import com.cloud.storage.VMTemplateZoneVO;
-import com.cloud.storage.dao.VMTemplateZoneDao;
-import com.cloud.utils.component.Inject;
-
-public class ImageOrchestratorImpl implements ImageOrchestrator {
-	@Inject
-	SecondaryStorageManager _secStorageMgr;
-	@Inject
-	VMTemplateZoneDao _templateZoneDao;
-	public void registerTemplate(long templateId) {
-		List<VMTemplateZoneVO> tpZones = _templateZoneDao.listByTemplateId(templateId);
-		
-		for (VMTemplateZoneVO tpZone : tpZones) {
-			DataStore imageStore = null;
-			List<DataStore> imageStores = _secStorageMgr.getImageStores(tpZone.getZoneId());
-			for (DataStore imgStore : imageStores) {
-				TemplateStrategy ts = imgStore.getTemplateStrategy();
-				if (ts.canRegister(templateId)) {
-					imageStore = imgStore;
-					break;
-				}
-			}
-			
-			if (imageStore == null) {
-				continue;
-			}
-			
-			TemplateStrategy ts = imageStore.getTemplateStrategy();
-			ts.register(ts.get(templateId));
-		}
-	}
-
-	public void registerSnapshot(long snapshotId) {
-		// TODO Auto-generated method stub
-		
-	}
-
-	public void registerVolume(long volumeId) {
-		// TODO Auto-generated method stub
-		
-	}
-
-	public void registerIso(long isoId) {
-		// TODO Auto-generated method stub
-		
-	}
-
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/ImageService.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/ImageService.java b/platform/storage/src/org/apache/cloudstack/storage/image/ImageService.java
deleted file mode 100644
index ebdc594..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/ImageService.java
+++ /dev/null
@@ -1,30 +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.image;
-
-public interface ImageService {
-	boolean registerTemplate(long templateId, long imageStoreId);
-	boolean deleteTemplate(long templateId);
-	long registerIso(String isoUrl, long accountId);
-	boolean deleteIso(long isoId);
-	String grantTemplateAccess(long templateId, long endpointId);
-	boolean revokeTemplateAccess(long templateId, long endpointId);
-	String grantIsoAccess(long isoId, long endpointId);
-	boolean revokeIsoAccess(long isoId, long endpointId);
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/ImageServiceImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/ImageServiceImpl.java b/platform/storage/src/org/apache/cloudstack/storage/image/ImageServiceImpl.java
deleted file mode 100644
index 6849192..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/ImageServiceImpl.java
+++ /dev/null
@@ -1,84 +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.image;
-
-import javax.inject.Inject;
-
-import org.apache.cloudstack.storage.image.downloader.ImageDownloader;
-import org.apache.cloudstack.storage.image.manager.ImageDataStoreManager;
-import org.apache.cloudstack.storage.image.store.ImageDataStore;
-
-public class ImageServiceImpl implements ImageService {
-
-	@Inject
-	ImageDataStoreManager imageStoreMgr;
-	@Override
-	public boolean registerTemplate(long templateId, long imageStoreId) {
-		ImageDataStore ids = imageStoreMgr.getImageDataStore(imageStoreId);
-		Template template = ids.registerTemplate(templateId);
-		if (ids.needDownloadToCacheStorage()) {
-			ImageDownloader imageDl = ids.getImageDownloader();
-			imageDl.downloadImage(template);
-		}
-		return true;
-	}
-
-	@Override
-	public boolean deleteTemplate(long templateId) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public long registerIso(String isoUrl, long accountId) {
-		// TODO Auto-generated method stub
-		return 0;
-	}
-
-	@Override
-	public boolean deleteIso(long isoId) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public String grantTemplateAccess(long templateId, long endpointId) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	@Override
-	public boolean revokeTemplateAccess(long templateId, long endpointId) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public String grantIsoAccess(long isoId, long endpointId) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	@Override
-	public boolean revokeIsoAccess(long isoId, long endpointId) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/Template.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/Template.java b/platform/storage/src/org/apache/cloudstack/storage/image/Template.java
deleted file mode 100644
index 4fc6b53..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/Template.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.image;
-
-import org.apache.cloudstack.storage.image.db.ImageDataVO;
-import org.apache.cloudstack.storage.image.store.ImageDataStore;
-
-public class Template {
-	protected ImageDataVO imageVO;
-	protected ImageDataStore dataStore;
-	public Template(ImageDataStore dataStore, ImageDataVO imageVO) {
-		this.dataStore = dataStore;
-		this.imageVO = imageVO;
-	}
-	
-	public ImageDataStore getImageDataStore() {
-		return this.dataStore;
-	}
-	
-	public String getTemplate
-	
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDao.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDao.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDao.java
deleted file mode 100644
index 3e1a951..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDao.java
+++ /dev/null
@@ -1,25 +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.image.db;
-
-import com.cloud.utils.db.GenericDao;
-
-public interface ImageDaoStoreDao extends GenericDao<ImageDataStoreVO, Long> {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDaoImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDaoImpl.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDaoImpl.java
deleted file mode 100644
index 01dd62e..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDaoStoreDaoImpl.java
+++ /dev/null
@@ -1,25 +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.image.db;
-
-import com.cloud.utils.db.GenericDaoBase;
-
-public class ImageDaoStoreDaoImpl extends GenericDaoBase<ImageDataStoreVO, Long> implements ImageDaoStoreDao {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/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
deleted file mode 100644
index b336ffa..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDao.java
+++ /dev/null
@@ -1,71 +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.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/3dafea6e/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
deleted file mode 100644
index 8ba5575..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataDaoImpl.java
+++ /dev/null
@@ -1,925 +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.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

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDao.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDao.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDao.java
deleted file mode 100644
index 466afa2..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDao.java
+++ /dev/null
@@ -1,25 +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.image.db;
-
-import com.cloud.utils.db.GenericDao;
-
-public interface ImageDataStoreProviderDao extends GenericDao<ImageDataStoreProviderVO, Long> {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDaoImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDaoImpl.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDaoImpl.java
deleted file mode 100644
index cb075be..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderDaoImpl.java
+++ /dev/null
@@ -1,26 +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.image.db;
-
-import com.cloud.utils.db.GenericDaoBase;
-
-
-public class ImageDataStoreProviderDaoImpl extends GenericDaoBase<ImageDataStoreProviderVO, Long> implements ImageDataStoreProviderDao {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderVO.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderVO.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderVO.java
deleted file mode 100644
index b8ecdcc..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreProviderVO.java
+++ /dev/null
@@ -1,23 +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.image.db;
-
-public interface ImageDataStoreProviderVO {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreVO.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreVO.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreVO.java
deleted file mode 100644
index 7177203..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataStoreVO.java
+++ /dev/null
@@ -1,60 +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.image.db;
-
-import javax.persistence.Column;
-import javax.persistence.Entity;
-import javax.persistence.Id;
-import javax.persistence.Table;
-import javax.persistence.TableGenerator;
-
-@Entity
-@Table(name="image_data_store")
-public class ImageDataStoreVO {
-    @Id
-    @TableGenerator(name="image_data_store_sq", table="sequence", pkColumnName="name", valueColumnName="value", pkColumnValue="image_data_store_seq", allocationSize=1)
-    @Column(name="id", nullable = false)
-    private long id;
-    
-    @Column(name="name", nullable = false)
-    private String name;
-    
-    @Column(name="image_provider", nullable = false)
-    private long provider;
-    
-    public long getId() {
-    	return this.id;
-    }
-    
-    public String getName() {
-    	return this.name;
-    }
-    
-    public long getProvider() {
-    	return this.provider;
-    }
-    
-    public void setName(String name) {
-    	this.name = name;
-    }
-    
-    public void setProvider(long provider) {
-    	this.provider = provider;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataVO.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataVO.java b/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataVO.java
deleted file mode 100644
index d50be88..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/db/ImageDataVO.java
+++ /dev/null
@@ -1,381 +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.image.db;
-
-import java.util.Date;
-import java.util.Map;
-import java.util.UUID;
-
-import javax.persistence.Column;
-import javax.persistence.Entity;
-import javax.persistence.EnumType;
-import javax.persistence.Enumerated;
-import javax.persistence.Id;
-import javax.persistence.Table;
-import javax.persistence.TableGenerator;
-import javax.persistence.Temporal;
-import javax.persistence.TemporalType;
-import javax.persistence.Transient;
-
-import com.cloud.api.Identity;
-import com.cloud.hypervisor.Hypervisor.HypervisorType;
-import com.cloud.storage.Storage;
-import com.cloud.storage.VMTemplateVO;
-import com.cloud.storage.Storage.TemplateType;
-import com.cloud.utils.db.GenericDao;
-
-@Entity
-@Table(name="vm_template")
-public class ImageDataVO implements Identity {
-    @Id
-    @TableGenerator(name="vm_template_sq", table="sequence", pkColumnName="name", valueColumnName="value", pkColumnValue="vm_template_seq", allocationSize=1)
-    @Column(name="id", nullable = false)
-    private long id;
-
-    @Column(name="format")
-    private String format;
-
-    @Column(name="unique_name")
-    private String uniqueName;
-
-    @Column(name="name")
-    private String name = null;
-
-    @Column(name="public")
-    private boolean publicTemplate = true;
-
-    @Column(name="featured")
-    private boolean featured;
-
-    @Column(name="type")
-    private Storage.TemplateType templateType;
-
-    @Column(name="url")
-    private String url = null;
-
-    @Column(name="hvm")
-    private boolean requiresHvm;
-
-    @Column(name="bits")
-    private int bits;
-
-    @Temporal(value=TemporalType.TIMESTAMP)
-    @Column(name=GenericDao.CREATED_COLUMN)
-    private Date created = null;
-
-    @Column(name=GenericDao.REMOVED)
-    @Temporal(TemporalType.TIMESTAMP)
-    private Date removed;
-
-    @Column(name="account_id")
-    private long accountId;
-
-    @Column(name="checksum")
-    private String checksum;    
-
-    @Column(name="display_text", length=4096)
-    private String displayText;
-
-    @Column(name="enable_password")
-    private boolean enablePassword;
-
-    @Column(name="guest_os_id")
-    private long guestOSId;
-
-    @Column(name="bootable")
-    private boolean bootable = true;
-
-    @Column(name="prepopulate")
-    private boolean prepopulate = false;
-
-    @Column(name="cross_zones")
-    private boolean crossZones = false;
-
-    @Column(name="hypervisor_type")
-    @Enumerated(value=EnumType.STRING)
-    private HypervisorType hypervisorType;
-
-    @Column(name="extractable")
-    private boolean extractable = true;
-
-    @Column(name="source_template_id")
-    private Long sourceTemplateId;
-
-    @Column(name="template_tag")
-    private String templateTag;
-    
-    @Column(name="uuid")
-    private String uuid;
-    
-    @Column(name="sort_key")
-    private int sortKey;
-    
-    @Column(name="enable_sshkey")
-    private boolean enableSshKey;
-    
-    @Transient
-    Map details;
-
-
-    public String getUniqueName() {
-        return uniqueName;
-    }
-
-    public void setUniqueName(String uniqueName) {
-        this.uniqueName = uniqueName;
-    }
-
-    protected ImageDataVO() {
-    	this.uuid = UUID.randomUUID().toString();
-    }
-
-    public boolean getEnablePassword() {
-        return enablePassword;
-    }
-
-    public String getFormat() {
-        return format;
-    }
-
-    public void setEnablePassword(boolean enablePassword) {
-        this.enablePassword = enablePassword;
-    }
-
-    public void setFormat(String format) {
-        this.format = format;
-    }
-
-    public long getId() {
-        return id;
-    }
-
-    public TemplateType getTemplateType() {
-        return templateType;
-    }
-
-    public void setTemplateType(TemplateType type) {
-        this.templateType = type;
-    }
-
-    public boolean requiresHvm() {
-        return requiresHvm;
-    }
-
-    public int getBits() {
-        return bits;
-    }
-
-    public void setBits(int bits) {
-        this.bits = bits;
-    }
-
-    public String getName() {
-        return name;
-    }
-
-    public void setName(String name) {
-        this.name = name;
-    }
-
-    public Date getRemoved() {
-        return removed;
-    }
-
-    public boolean isPublicTemplate() {
-        return publicTemplate;
-    }
-
-    public void setPublicTemplate(boolean publicTemplate) {
-        this.publicTemplate = publicTemplate;
-    }
-
-    public boolean isFeatured() {
-        return featured;
-    }
-
-    public void setFeatured(boolean featured) {
-        this.featured = featured;
-    }
-
-    public Date getCreated() {
-        return created;
-    }
-
-    public String getUrl() {
-        return url;
-    }
-
-    public void setUrl(String url) {
-        this.url = url;
-    }
-
-    public long getAccountId() {
-        return accountId;
-    }
-
-    public String getChecksum() {
-        return checksum;
-    }
-
-    public void setChecksum(String checksum) {
-        this.checksum = checksum;
-    }
-
-    public String getDisplayText() {
-        return displayText;
-    }
-
-    public void setDisplayText(String displayText) {
-        this.displayText = displayText;
-    }
-
-    public long getGuestOSId() {
-        return guestOSId;
-    }
-
-    public void setGuestOSId(long guestOSId) {
-        this.guestOSId = guestOSId;
-    }
-
-    public boolean isBootable() {
-        return bootable;
-    }
-
-    public void setBootable(boolean bootable) {
-        this.bootable = bootable;
-    }
-
-    public void setPrepopulate(boolean prepopulate) {
-        this.prepopulate = prepopulate;
-    }
-
-    public boolean isPrepopulate() {
-        return prepopulate;
-    }
-
-    public void setCrossZones(boolean crossZones) {
-        this.crossZones = crossZones;
-    }
-
-    public boolean isCrossZones() {
-        return crossZones;
-    }
-
-    public HypervisorType getHypervisorType() {
-        return hypervisorType;
-    }
-
-    public void setHypervisorType(HypervisorType hyperType) {
-        hypervisorType = hyperType;
-    }
-
-    public boolean isExtractable() {
-        return extractable;
-    }
-
-    public void setExtractable(boolean extractable) {
-        this.extractable = extractable;
-    }
-
-    public Long getSourceTemplateId() {
-        return sourceTemplateId;
-    }
-
-    public void setSourceTemplateId(Long sourceTemplateId) {
-        this.sourceTemplateId = sourceTemplateId;
-    }
-
-    public String getTemplateTag() {
-        return templateTag;
-    }    
-
-    public void setTemplateTag(String templateTag) {
-        this.templateTag = templateTag;
-    }   
-
-    public long getDomainId() {
-        return -1;
-    }
-    
-    @Override
-    public String getUuid() {
-    	return this.uuid;
-    }
-    
-    public void setUuid(String uuid) {
-    	this.uuid = uuid;
-    }
-    
-    public Map getDetails() {
-    	return this.details;
-    }
-    
-    public void setDetails(Map details) {
-    	this.details = details;
-    }
-
-    @Override
-    public boolean equals(Object that) {
-        if (this == that ) {
-            return true;
-        }
-        if (!(that instanceof VMTemplateVO)){
-            return false;
-        }
-        VMTemplateVO other = (VMTemplateVO)that;
-
-        return ((this.getUniqueName().equals(other.getUniqueName())));		
-    }
-
-    @Override
-    public int hashCode() {
-        return uniqueName.hashCode();
-    }
-
-    @Transient
-    String toString;
-    @Override
-    public String toString() {
-        if (toString == null) {
-            toString = new StringBuilder("Tmpl[").append(id).append("-").append(format).append("-").append(uniqueName).toString();
-        }
-        return toString;
-    }
-
-    public void setRemoved(Date removed) {
-        this.removed = removed;
-    }
-    
-    public void setSortKey(int key) {
-    	sortKey = key;
-    }
-    
-    public int getSortKey() {
-    	return sortKey;
-    }
-
-	public boolean getEnableSshKey() {
-		return enableSshKey;
-	}
-	
-	public void setEnableSshKey(boolean enable) {
-		enableSshKey = enable;
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/downloader/ImageDownloader.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/downloader/ImageDownloader.java b/platform/storage/src/org/apache/cloudstack/storage/image/downloader/ImageDownloader.java
deleted file mode 100644
index 123df61..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/downloader/ImageDownloader.java
+++ /dev/null
@@ -1,25 +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.image.downloader;
-
-import org.apache.cloudstack.storage.image.Template;
-
-public interface ImageDownloader {
-	public void downloadImage(Template template);
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriver.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriver.java b/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriver.java
deleted file mode 100644
index 1a45bd9..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriver.java
+++ /dev/null
@@ -1,28 +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.image.driver;
-
-import org.apache.cloudstack.storage.image.Template;
-
-public interface ImageDataStoreDriver {
-	boolean registerTemplate(Template template);
-	String grantAccess(long templateId, long endPointId);
-	boolean revokeAccess(long templateId, long endPointId);
-	boolean deleteTemplate(Template template);
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriverImpl.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriverImpl.java b/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriverImpl.java
deleted file mode 100644
index a88e669..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/driver/ImageDataStoreDriverImpl.java
+++ /dev/null
@@ -1,51 +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.image.driver;
-
-import org.apache.cloudstack.storage.image.Template;
-
-public class ImageDataStoreDriverImpl implements ImageDataStoreDriver {
-
-	@Override
-	public boolean registerTemplate(Template template) {
-		//TODO: check the availability of template 
-		return true;
-	}
-
-	@Override
-	public String grantAccess(long templateId, long endPointId) {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	@Override
-	public boolean revokeAccess(long templateId, long endPointId) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	@Override
-	public boolean deleteTemplate(Template template) {
-		// TODO Auto-generated method stub
-		return false;
-	}
-
-	
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/format/BAREMETAL.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/format/BAREMETAL.java b/platform/storage/src/org/apache/cloudstack/storage/image/format/BAREMETAL.java
deleted file mode 100644
index c3de2f1..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/format/BAREMETAL.java
+++ /dev/null
@@ -1,31 +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.image.format;
-
-import org.apache.cloudstack.storage.BaseType;
-import org.springframework.stereotype.Component;
-
-@Component
-public class BAREMETAL extends BaseType implements ImageFormat {
-	private final String type = "BAREMETAL";
-	@Override
-	public String toString() {
-		return type;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/format/ISO.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/format/ISO.java b/platform/storage/src/org/apache/cloudstack/storage/image/format/ISO.java
deleted file mode 100644
index f27d16b..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/format/ISO.java
+++ /dev/null
@@ -1,31 +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.image.format;
-
-import org.apache.cloudstack.storage.BaseType;
-import org.springframework.stereotype.Component;
-
-@Component
-public class ISO extends BaseType implements ImageFormat {
-	private final String type = "ISO";
-	@Override
-	public String toString() {
-		return type;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormat.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormat.java b/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormat.java
deleted file mode 100644
index f02694a..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormat.java
+++ /dev/null
@@ -1,23 +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.image.format;
-
-public interface ImageFormat {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/3dafea6e/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormatHelper.java
----------------------------------------------------------------------
diff --git a/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormatHelper.java b/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormatHelper.java
deleted file mode 100644
index 6ecb9b0..0000000
--- a/platform/storage/src/org/apache/cloudstack/storage/image/format/ImageFormatHelper.java
+++ /dev/null
@@ -1,44 +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.image.format;
-
-import java.util.List;
-
-import javax.inject.Inject;
-
-import org.springframework.stereotype.Component;
-
-@Component
-public class ImageFormatHelper {
-	private static List<ImageFormat> formats;
-	private static final ImageFormat defaultFormat = new Unknown();
-	@Inject
-	public void setFormats(List<ImageFormat> formats) {
-		ImageFormatHelper.formats = formats;
-	}
-	
-	public static ImageFormat getFormat(String format) {
-		for(ImageFormat fm : formats) {
-			if (fm.equals(format)) {
-				return fm;
-			}
-		}
-		return ImageFormatHelper.defaultFormat;
-	}
-}