Search in sources :

Example 1 with DiscoveryException

use of com.cloud.exception.DiscoveryException in project CloudStack-archive by CloudStack-extras.

the class SimulatorDiscoverer method find.

/**
	 * Finds ServerResources of an in-process simulator
	 * 
	 * @see com.cloud.resource.Discoverer#find(long, java.lang.Long,
	 *      java.lang.Long, java.net.URI, java.lang.String, java.lang.String)
	 */
@Override
public Map<? extends ServerResource, Map<String, String>> find(long dcId, Long podId, Long clusterId, URI uri, String username, String password, List<String> hostTags) throws DiscoveryException {
    Map<AgentResourceBase, Map<String, String>> resources;
    try {
        //http://sim/count=$count, it will add $count number of hosts into the cluster
        String scheme = uri.getScheme();
        String host = uri.getAuthority();
        String commands = URLDecoder.decode(uri.getPath());
        long cpuSpeed = _mockAgentMgr.DEFAULT_HOST_SPEED_MHZ;
        long cpuCores = _mockAgentMgr.DEFAULT_HOST_CPU_CORES;
        long memory = _mockAgentMgr.DEFAULT_HOST_MEM_SIZE;
        long localstorageSize = _mockStorageMgr.DEFAULT_HOST_STORAGE_SIZE;
        if (scheme.equals("http")) {
            if (host == null || !host.startsWith("sim")) {
                String msg = "uri is not of simulator type so we're not taking care of the discovery for this: " + uri;
                if (s_logger.isDebugEnabled()) {
                    s_logger.debug(msg);
                }
                return null;
            }
            if (commands != null) {
                int index = commands.lastIndexOf("/");
                if (index != -1) {
                    commands = commands.substring(index + 1);
                    String[] cmds = commands.split("&");
                    for (String cmd : cmds) {
                        String[] parameter = cmd.split("=");
                        if (parameter[0].equalsIgnoreCase("cpuspeed") && parameter[1] != null) {
                            cpuSpeed = Long.parseLong(parameter[1]);
                        } else if (parameter[0].equalsIgnoreCase("cpucore") && parameter[1] != null) {
                            cpuCores = Long.parseLong(parameter[1]);
                        } else if (parameter[0].equalsIgnoreCase("memory") && parameter[1] != null) {
                            memory = Long.parseLong(parameter[1]);
                        } else if (parameter[0].equalsIgnoreCase("localstorage") && parameter[1] != null) {
                            localstorageSize = Long.parseLong(parameter[1]);
                        }
                    }
                }
            }
        } else {
            String msg = "uriString is not http so we're not taking care of the discovery for this: " + uri;
            if (s_logger.isDebugEnabled()) {
                s_logger.debug(msg);
            }
            return null;
        }
        String cluster = null;
        if (clusterId == null) {
            String msg = "must specify cluster Id when adding host";
            if (s_logger.isDebugEnabled()) {
                s_logger.debug(msg);
            }
            throw new RuntimeException(msg);
        } else {
            ClusterVO clu = _clusterDao.findById(clusterId);
            if (clu == null || (clu.getHypervisorType() != HypervisorType.Simulator)) {
                if (s_logger.isInfoEnabled())
                    s_logger.info("invalid cluster id or cluster is not for Simulator hypervisors");
                return null;
            }
            cluster = Long.toString(clusterId);
            if (clu.getGuid() == null) {
                clu.setGuid(UUID.randomUUID().toString());
            }
            _clusterDao.update(clusterId, clu);
        }
        String pod;
        if (podId == null) {
            String msg = "must specify pod Id when adding host";
            if (s_logger.isDebugEnabled()) {
                s_logger.debug(msg);
            }
            throw new RuntimeException(msg);
        } else {
            pod = Long.toString(podId);
        }
        Map<String, String> details = new HashMap<String, String>();
        Map<String, Object> params = new HashMap<String, Object>();
        details.put("username", username);
        params.put("username", username);
        details.put("password", password);
        params.put("password", password);
        params.put("zone", Long.toString(dcId));
        params.put("pod", pod);
        params.put("cluster", cluster);
        params.put("cpuspeed", Long.toString(cpuSpeed));
        params.put("cpucore", Long.toString(cpuCores));
        params.put("memory", Long.toString(memory));
        params.put("localstorage", Long.toString(localstorageSize));
        resources = createAgentResources(params);
        return resources;
    } catch (Exception ex) {
        s_logger.error("Exception when discovering simulator hosts: " + ex.getMessage());
    }
    return null;
}
Also used : ClusterVO(com.cloud.dc.ClusterVO) HashMap(java.util.HashMap) DiscoveryException(com.cloud.exception.DiscoveryException) ConfigurationException(javax.naming.ConfigurationException) ConnectionException(com.cloud.exception.ConnectionException) HashMap(java.util.HashMap) Map(java.util.Map)

Example 2 with DiscoveryException

use of com.cloud.exception.DiscoveryException in project CloudStack-archive by CloudStack-extras.

the class AddSecondaryStorageCmd method execute.

@Override
public void execute() {
    try {
        List<? extends Host> result = _resourceService.discoverHosts(this);
        HostResponse hostResponse = null;
        if (result != null && result.size() > 0) {
            for (Host host : result) {
                // There should only be one secondary storage host per add
                hostResponse = _responseGenerator.createHostResponse(host);
                hostResponse.setResponseName(getCommandName());
                hostResponse.setObjectName("secondarystorage");
                this.setResponseObject(hostResponse);
            }
        } else {
            throw new ServerApiException(BaseCmd.INTERNAL_ERROR, "Failed to add secondary storage");
        }
    } catch (DiscoveryException ex) {
        s_logger.warn("Exception: ", ex);
        throw new ServerApiException(BaseCmd.INTERNAL_ERROR, ex.getMessage());
    }
}
Also used : ServerApiException(com.cloud.api.ServerApiException) HostResponse(com.cloud.api.response.HostResponse) Host(com.cloud.host.Host) DiscoveryException(com.cloud.exception.DiscoveryException)

Example 3 with DiscoveryException

use of com.cloud.exception.DiscoveryException in project cloudstack by apache.

the class AddVmwareDcCmd method execute.

@Override
public void execute() {
    try {
        VmwareDatacenterResponse response = new VmwareDatacenterResponse();
        VmwareDatacenterVO result = _vmwareDatacenterService.addVmwareDatacenter(this);
        if (result != null) {
            response.setId(result.getUuid());
            response.setName(result.getVmwareDatacenterName());
            response.setResponseName(getCommandName());
            response.setObjectName("vmwaredc");
        } else {
            throw new ServerApiException(ApiErrorCode.INTERNAL_ERROR, "Failed to add VMware Datacenter to zone.");
        }
        this.setResponseObject(response);
    } catch (DiscoveryException ex) {
        s_logger.warn("Exception: ", ex);
        throw new ServerApiException(ApiErrorCode.INTERNAL_ERROR, ex.getMessage());
    } catch (ResourceInUseException ex) {
        s_logger.warn("Exception: ", ex);
        ServerApiException e = new ServerApiException(ApiErrorCode.INTERNAL_ERROR, ex.getMessage());
        for (String proxyObj : ex.getIdProxyList()) {
            e.addProxyObject(proxyObj);
        }
        throw e;
    } catch (IllegalArgumentException ex) {
        throw new IllegalArgumentException(ex.getMessage());
    } catch (CloudRuntimeException runtimeEx) {
        throw new ServerApiException(ApiErrorCode.INTERNAL_ERROR, runtimeEx.getMessage());
    }
}
Also used : VmwareDatacenterResponse(org.apache.cloudstack.api.response.VmwareDatacenterResponse) ServerApiException(org.apache.cloudstack.api.ServerApiException) VmwareDatacenterVO(com.cloud.hypervisor.vmware.VmwareDatacenterVO) CloudRuntimeException(com.cloud.utils.exception.CloudRuntimeException) ResourceInUseException(com.cloud.exception.ResourceInUseException) DiscoveryException(com.cloud.exception.DiscoveryException)

Example 4 with DiscoveryException

use of com.cloud.exception.DiscoveryException in project cloudstack by apache.

the class ResourceManagerImpl method discoverHostsFull.

private List<HostVO> discoverHostsFull(final Long dcId, final Long podId, Long clusterId, final String clusterName, String url, String username, String password, final String hypervisorType, final List<String> hostTags, final Map<String, String> params, final boolean deferAgentCreation) throws IllegalArgumentException, DiscoveryException, InvalidParameterValueException {
    URI uri = null;
    // Check if the zone exists in the system
    final DataCenterVO zone = _dcDao.findById(dcId);
    if (zone == null) {
        throw new InvalidParameterValueException("Can't find zone by id " + dcId);
    }
    final Account account = CallContext.current().getCallingAccount();
    if (Grouping.AllocationState.Disabled == zone.getAllocationState() && !_accountMgr.isRootAdmin(account.getId())) {
        final PermissionDeniedException ex = new PermissionDeniedException("Cannot perform this operation, Zone with specified id is currently disabled");
        ex.addProxyObject(zone.getUuid(), "dcId");
        throw ex;
    }
    // Check if the pod exists in the system
    if (podId != null) {
        final HostPodVO pod = _podDao.findById(podId);
        if (pod == null) {
            throw new InvalidParameterValueException("Can't find pod by id " + podId);
        }
        // check if pod belongs to the zone
        if (!Long.valueOf(pod.getDataCenterId()).equals(dcId)) {
            final InvalidParameterValueException ex = new InvalidParameterValueException("Pod with specified podId" + podId + " doesn't belong to the zone with specified zoneId" + dcId);
            ex.addProxyObject(pod.getUuid(), "podId");
            ex.addProxyObject(zone.getUuid(), "dcId");
            throw ex;
        }
    }
    // Verify cluster information and create a new cluster if needed
    if (clusterName != null && clusterId != null) {
        throw new InvalidParameterValueException("Can't specify cluster by both id and name");
    }
    if (hypervisorType == null || hypervisorType.isEmpty()) {
        throw new InvalidParameterValueException("Need to specify Hypervisor Type");
    }
    if ((clusterName != null || clusterId != null) && podId == null) {
        throw new InvalidParameterValueException("Can't specify cluster without specifying the pod");
    }
    if (clusterId != null) {
        if (_clusterDao.findById(clusterId) == null) {
            throw new InvalidParameterValueException("Can't find cluster by id " + clusterId);
        }
        if (hypervisorType.equalsIgnoreCase(HypervisorType.VMware.toString())) {
            // VMware only allows adding host to an existing cluster, as we
            // already have a lot of information
            // in cluster object, to simplify user input, we will construct
            // neccessary information here
            final Map<String, String> clusterDetails = _clusterDetailsDao.findDetails(clusterId);
            username = clusterDetails.get("username");
            assert username != null;
            password = clusterDetails.get("password");
            assert password != null;
            try {
                uri = new URI(UriUtils.encodeURIComponent(url));
                url = clusterDetails.get("url") + "/" + uri.getHost();
            } catch (final URISyntaxException e) {
                throw new InvalidParameterValueException(url + " is not a valid uri");
            }
        }
    }
    if ((hypervisorType.equalsIgnoreCase(HypervisorType.BareMetal.toString()))) {
        if (hostTags.isEmpty()) {
            throw new InvalidParameterValueException("hosttag is mandatory while adding host of type Baremetal");
        }
    }
    if (clusterName != null) {
        final HostPodVO pod = _podDao.findById(podId);
        if (pod == null) {
            throw new InvalidParameterValueException("Can't find pod by id " + podId);
        }
        ClusterVO cluster = new ClusterVO(dcId, podId, clusterName);
        cluster.setHypervisorType(hypervisorType);
        try {
            cluster = _clusterDao.persist(cluster);
        } catch (final Exception e) {
            cluster = _clusterDao.findBy(clusterName, podId);
            if (cluster == null) {
                final CloudRuntimeException ex = new CloudRuntimeException("Unable to create cluster " + clusterName + " in pod with specified podId and data center with specified dcID", e);
                ex.addProxyObject(pod.getUuid(), "podId");
                ex.addProxyObject(zone.getUuid(), "dcId");
                throw ex;
            }
        }
        clusterId = cluster.getId();
        if (_clusterDetailsDao.findDetail(clusterId, "cpuOvercommitRatio") == null) {
            final ClusterDetailsVO cluster_cpu_detail = new ClusterDetailsVO(clusterId, "cpuOvercommitRatio", "1");
            final ClusterDetailsVO cluster_memory_detail = new ClusterDetailsVO(clusterId, "memoryOvercommitRatio", "1");
            _clusterDetailsDao.persist(cluster_cpu_detail);
            _clusterDetailsDao.persist(cluster_memory_detail);
        }
    }
    try {
        uri = new URI(UriUtils.encodeURIComponent(url));
        if (uri.getScheme() == null) {
            throw new InvalidParameterValueException("uri.scheme is null " + url + ", add nfs:// (or cifs://) as a prefix");
        } else if (uri.getScheme().equalsIgnoreCase("nfs")) {
            if (uri.getHost() == null || uri.getHost().equalsIgnoreCase("") || uri.getPath() == null || uri.getPath().equalsIgnoreCase("")) {
                throw new InvalidParameterValueException("Your host and/or path is wrong.  Make sure it's of the format nfs://hostname/path");
            }
        } else if (uri.getScheme().equalsIgnoreCase("cifs")) {
            // Don't validate against a URI encoded URI.
            final URI cifsUri = new URI(url);
            final String warnMsg = UriUtils.getCifsUriParametersProblems(cifsUri);
            if (warnMsg != null) {
                throw new InvalidParameterValueException(warnMsg);
            }
        }
    } catch (final URISyntaxException e) {
        throw new InvalidParameterValueException(url + " is not a valid uri");
    }
    final List<HostVO> hosts = new ArrayList<HostVO>();
    s_logger.info("Trying to add a new host at " + url + " in data center " + dcId);
    boolean isHypervisorTypeSupported = false;
    for (final Discoverer discoverer : _discoverers) {
        if (params != null) {
            discoverer.putParam(params);
        }
        if (!discoverer.matchHypervisor(hypervisorType)) {
            continue;
        }
        isHypervisorTypeSupported = true;
        Map<? extends ServerResource, Map<String, String>> resources = null;
        processResourceEvent(ResourceListener.EVENT_DISCOVER_BEFORE, dcId, podId, clusterId, uri, username, password, hostTags);
        try {
            resources = discoverer.find(dcId, podId, clusterId, uri, username, password, hostTags);
        } catch (final DiscoveryException e) {
            throw e;
        } catch (final Exception e) {
            s_logger.info("Exception in host discovery process with discoverer: " + discoverer.getName() + ", skip to another discoverer if there is any");
        }
        processResourceEvent(ResourceListener.EVENT_DISCOVER_AFTER, resources);
        if (resources != null) {
            for (final Map.Entry<? extends ServerResource, Map<String, String>> entry : resources.entrySet()) {
                final ServerResource resource = entry.getKey();
                /*
                     * For KVM, if we go to here, that means kvm agent is
                     * already connected to mgt svr.
                     */
                if (resource instanceof KvmDummyResourceBase) {
                    final Map<String, String> details = entry.getValue();
                    final String guid = details.get("guid");
                    final List<HostVO> kvmHosts = listAllUpAndEnabledHosts(Host.Type.Routing, clusterId, podId, dcId);
                    for (final HostVO host : kvmHosts) {
                        if (host.getGuid().equalsIgnoreCase(guid)) {
                            if (hostTags != null) {
                                if (s_logger.isTraceEnabled()) {
                                    s_logger.trace("Adding Host Tags for KVM host, tags:  :" + hostTags);
                                }
                                _hostTagsDao.persist(host.getId(), hostTags);
                            }
                            hosts.add(host);
                            _agentMgr.notifyMonitorsOfNewlyAddedHost(host.getId());
                            return hosts;
                        }
                    }
                    return null;
                }
                HostVO host = null;
                if (deferAgentCreation) {
                    host = (HostVO) createHostAndAgentDeferred(resource, entry.getValue(), true, hostTags, false);
                } else {
                    host = (HostVO) createHostAndAgent(resource, entry.getValue(), true, hostTags, false);
                }
                if (host != null) {
                    hosts.add(host);
                }
                discoverer.postDiscovery(hosts, _nodeId);
            }
            s_logger.info("server resources successfully discovered by " + discoverer.getName());
            return hosts;
        }
    }
    if (!isHypervisorTypeSupported) {
        final String msg = "Do not support HypervisorType " + hypervisorType + " for " + url;
        s_logger.warn(msg);
        throw new DiscoveryException(msg);
    }
    s_logger.warn("Unable to find the server resources at " + url);
    throw new DiscoveryException("Unable to add the host");
}
Also used : DataCenterVO(com.cloud.dc.DataCenterVO) Account(com.cloud.user.Account) ClusterVO(com.cloud.dc.ClusterVO) ArrayList(java.util.ArrayList) URISyntaxException(java.net.URISyntaxException) URI(java.net.URI) HostPodVO(com.cloud.dc.HostPodVO) NoTransitionException(com.cloud.utils.fsm.NoTransitionException) AgentUnavailableException(com.cloud.exception.AgentUnavailableException) CloudRuntimeException(com.cloud.utils.exception.CloudRuntimeException) ResourceInUseException(com.cloud.exception.ResourceInUseException) URISyntaxException(java.net.URISyntaxException) DiscoveryException(com.cloud.exception.DiscoveryException) SshException(com.cloud.utils.ssh.SshException) InvalidParameterValueException(com.cloud.exception.InvalidParameterValueException) ConfigurationException(javax.naming.ConfigurationException) PermissionDeniedException(com.cloud.exception.PermissionDeniedException) StoragePoolHostVO(com.cloud.storage.StoragePoolHostVO) HostVO(com.cloud.host.HostVO) InvalidParameterValueException(com.cloud.exception.InvalidParameterValueException) CloudRuntimeException(com.cloud.utils.exception.CloudRuntimeException) KvmDummyResourceBase(com.cloud.hypervisor.kvm.discoverer.KvmDummyResourceBase) PermissionDeniedException(com.cloud.exception.PermissionDeniedException) ClusterDetailsVO(com.cloud.dc.ClusterDetailsVO) Map(java.util.Map) HashMap(java.util.HashMap) DiscoveryException(com.cloud.exception.DiscoveryException)

Example 5 with DiscoveryException

use of com.cloud.exception.DiscoveryException in project cloudstack by apache.

the class AddImageStoreCmd method execute.

@Override
public void execute() {
    try {
        ImageStore result = _storageService.discoverImageStore(getName(), getUrl(), getProviderName(), getZoneId(), getDetails());
        ImageStoreResponse storeResponse = null;
        if (result != null) {
            storeResponse = _responseGenerator.createImageStoreResponse(result);
            storeResponse.setResponseName(getCommandName());
            storeResponse.setObjectName("imagestore");
            setResponseObject(storeResponse);
        } else {
            throw new ServerApiException(ApiErrorCode.INTERNAL_ERROR, "Failed to add secondary storage");
        }
    } catch (DiscoveryException ex) {
        s_logger.warn("Exception: ", ex);
        throw new ServerApiException(ApiErrorCode.INTERNAL_ERROR, ex.getMessage());
    }
}
Also used : ImageStoreResponse(org.apache.cloudstack.api.response.ImageStoreResponse) ServerApiException(org.apache.cloudstack.api.ServerApiException) DiscoveryException(com.cloud.exception.DiscoveryException) ImageStore(com.cloud.storage.ImageStore)

Aggregations

DiscoveryException (com.cloud.exception.DiscoveryException)29 HashMap (java.util.HashMap)15 ConfigurationException (javax.naming.ConfigurationException)14 ClusterVO (com.cloud.dc.ClusterVO)12 Map (java.util.Map)12 ResourceInUseException (com.cloud.exception.ResourceInUseException)9 CloudRuntimeException (com.cloud.utils.exception.CloudRuntimeException)9 ServerApiException (org.apache.cloudstack.api.ServerApiException)9 DataCenterVO (com.cloud.dc.DataCenterVO)6 AgentUnavailableException (com.cloud.exception.AgentUnavailableException)6 InvalidParameterValueException (com.cloud.exception.InvalidParameterValueException)6 HostVO (com.cloud.host.HostVO)6 InetAddress (java.net.InetAddress)6 ArrayList (java.util.ArrayList)6 ConnectionException (com.cloud.exception.ConnectionException)5 DiscoveredWithErrorException (com.cloud.exception.DiscoveredWithErrorException)5 UnableDeleteHostException (com.cloud.resource.UnableDeleteHostException)5 URISyntaxException (java.net.URISyntaxException)5 UnknownHostException (java.net.UnknownHostException)5 ServerApiException (com.cloud.api.ServerApiException)4