Source code for ironic.common.exception

# Copyright 2010 United States Government as represented by the
# Administrator of the National Aeronautics and Space Administration.
# All Rights Reserved.
#
#    Licensed 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.

"""Ironic base exception handling.

SHOULD include dedicated exception logging.

"""

import collections

from oslo_log import log as logging
from oslo_serialization import jsonutils
import six
from six.moves import http_client

from ironic.common.i18n import _, _LE
from ironic.conf import CONF

LOG = logging.getLogger(__name__)


def _ensure_exception_kwargs_serializable(exc_class_name, kwargs):
    """Ensure that kwargs are serializable

    Ensure that all kwargs passed to exception constructor can be passed over
    RPC, by trying to convert them to JSON, or, as a last resort, to string.
    If it is not possible, unserializable kwargs will be removed, letting the
    receiver to handle the exception string as it is configured to.

    :param exc_class_name: an IronicException class name.
    :param kwargs: a dictionary of keyword arguments passed to the exception
        constructor.
    :returns: a dictionary of serializable keyword arguments.
    """
    serializers = [(jsonutils.dumps, _('when converting to JSON')),
                   (six.text_type, _('when converting to string'))]
    exceptions = collections.defaultdict(list)
    serializable_kwargs = {}
    for k, v in kwargs.items():
        for serializer, msg in serializers:
            try:
                serializable_kwargs[k] = serializer(v)
                exceptions.pop(k, None)
                break
            except Exception as e:
                exceptions[k].append(
                    '(%(serializer_type)s) %(e_type)s: %(e_contents)s' %
                    {'serializer_type': msg, 'e_contents': e,
                     'e_type': e.__class__.__name__})
    if exceptions:
        LOG.error(
            _LE("One or more arguments passed to the %(exc_class)s "
                "constructor as kwargs can not be serialized. The serialized "
                "arguments: %(serialized)s. These unserialized kwargs were "
                "dropped because of the exceptions encountered during their "
                "serialization:\n%(errors)s"),
            dict(errors=';\n'.join("%s: %s" % (k, '; '.join(v))
                                   for k, v in exceptions.items()),
                 exc_class=exc_class_name, serialized=serializable_kwargs)
        )
        # We might be able to actually put the following keys' values into
        # format string, but there is no guarantee, drop it just in case.
        for k in exceptions:
            del kwargs[k]
    return serializable_kwargs


[docs]class IronicException(Exception): """Base Ironic Exception To correctly use this class, inherit from it and define a '_msg_fmt' property. That message will get printf'd with the keyword arguments provided to the constructor. If you need to access the message from an exception you should use six.text_type(exc) """ _msg_fmt = _("An unknown exception occurred.") code = http_client.INTERNAL_SERVER_ERROR headers = {} safe = False def __init__(self, message=None, **kwargs): self.kwargs = _ensure_exception_kwargs_serializable( self.__class__.__name__, kwargs) if 'code' not in self.kwargs: try: self.kwargs['code'] = self.code except AttributeError: pass if not message: try: message = self._msg_fmt % kwargs except Exception as e: # kwargs doesn't match a variable in self._msg_fmt # log the issue and the kwargs prs = ', '.join('%s: %s' % pair for pair in kwargs.items()) LOG.exception(_LE('Exception in string format operation ' '(arguments %s)'), prs) if CONF.fatal_exception_format_errors: raise e else: # at least get the core self._msg_fmt out if something # happened message = self._msg_fmt super(IronicException, self).__init__(message) def __str__(self): """Encode to utf-8 then wsme api can consume it as well.""" if not six.PY3: return six.text_type(self.args[0]).encode('utf-8') return self.args[0] def __unicode__(self): """Return a unicode representation of the exception message.""" return six.text_type(self.args[0])
[docs]class NotAuthorized(IronicException): _msg_fmt = _("Not authorized.") code = http_client.FORBIDDEN
[docs]class OperationNotPermitted(NotAuthorized): _msg_fmt = _("Operation not permitted.")
[docs]class Invalid(IronicException): _msg_fmt = _("Unacceptable parameters.") code = http_client.BAD_REQUEST
[docs]class Conflict(IronicException): _msg_fmt = _('Conflict.') code = http_client.CONFLICT
[docs]class TemporaryFailure(IronicException): _msg_fmt = _("Resource temporarily unavailable, please retry.") code = http_client.SERVICE_UNAVAILABLE
[docs]class NotAcceptable(IronicException): # TODO(deva): We need to set response headers in the API for this exception _msg_fmt = _("Request not acceptable.") code = http_client.NOT_ACCEPTABLE
[docs]class InvalidState(Conflict): _msg_fmt = _("Invalid resource state.")
[docs]class NodeAlreadyExists(Conflict): _msg_fmt = _("A node with UUID %(uuid)s already exists.")
[docs]class MACAlreadyExists(Conflict): _msg_fmt = _("A port with MAC address %(mac)s already exists.")
[docs]class ChassisAlreadyExists(Conflict): _msg_fmt = _("A chassis with UUID %(uuid)s already exists.")
[docs]class PortAlreadyExists(Conflict): _msg_fmt = _("A port with UUID %(uuid)s already exists.")
[docs]class PortgroupAlreadyExists(Conflict): _msg_fmt = _("A portgroup with UUID %(uuid)s already exists.")
[docs]class PortgroupDuplicateName(Conflict): _msg_fmt = _("A portgroup with name %(name)s already exists.")
[docs]class PortgroupMACAlreadyExists(Conflict): _msg_fmt = _("A portgroup with MAC address %(mac)s already exists.")
[docs]class InstanceAssociated(Conflict): _msg_fmt = _("Instance %(instance_uuid)s is already associated with a " "node, it cannot be associated with this other node %(node)s")
[docs]class DuplicateName(Conflict): _msg_fmt = _("A node with name %(name)s already exists.")
[docs]class InvalidUUID(Invalid): _msg_fmt = _("Expected a UUID but received %(uuid)s.")
[docs]class InvalidUuidOrName(Invalid): _msg_fmt = _("Expected a logical name or UUID but received %(name)s.")
[docs]class InvalidName(Invalid): _msg_fmt = _("Expected a logical name but received %(name)s.")
[docs]class InvalidIdentity(Invalid): _msg_fmt = _("Expected a UUID or int but received %(identity)s.")
[docs]class InvalidMAC(Invalid): _msg_fmt = _("Expected a MAC address but received %(mac)s.")
[docs]class InvalidSwitchID(Invalid): _msg_fmt = _("Expected a MAC address or OpenFlow datapath ID but " "received %(switch_id)s.")
[docs]class InvalidDatapathID(Invalid): _msg_fmt = _("Expected an OpenFlow datapath ID but received " "%(datapath_id)s.")
[docs]class InvalidStateRequested(Invalid): _msg_fmt = _('The requested action "%(action)s" can not be performed ' 'on node "%(node)s" while it is in state "%(state)s".')
[docs]class PatchError(Invalid): _msg_fmt = _("Couldn't apply patch '%(patch)s'. Reason: %(reason)s")
[docs]class InstanceDeployFailure(IronicException): _msg_fmt = _("Failed to deploy instance: %(reason)s")
[docs]class ImageUnacceptable(IronicException): _msg_fmt = _("Image %(image_id)s is unacceptable: %(reason)s")
[docs]class ImageConvertFailed(IronicException): _msg_fmt = _("Image %(image_id)s is unacceptable: %(reason)s") # Cannot be templated as the error syntax varies. # msg needs to be constructed when raised.
[docs]class InvalidParameterValue(Invalid): _msg_fmt = _("%(err)s")
[docs]class MissingParameterValue(InvalidParameterValue): _msg_fmt = _("%(err)s")
[docs]class Duplicate(IronicException): _msg_fmt = _("Resource already exists.")
[docs]class NotFound(IronicException): _msg_fmt = _("Resource could not be found.") code = http_client.NOT_FOUND
[docs]class DHCPLoadError(IronicException): _msg_fmt = _("Failed to load DHCP provider %(dhcp_provider_name)s, " "reason: %(reason)s")
[docs]class DriverNotFound(NotFound): _msg_fmt = _("Could not find the following driver(s): %(driver_name)s.")
[docs]class DriverNotFoundInEntrypoint(DriverNotFound): _msg_fmt = _("Could not find the following driver(s) in the " "'%(entrypoint)s' entrypoint: %(driver_name)s.")
[docs]class ImageNotFound(NotFound): _msg_fmt = _("Image %(image_id)s could not be found.")
[docs]class NoValidHost(NotFound): _msg_fmt = _("No valid host was found. Reason: %(reason)s")
[docs]class InstanceNotFound(NotFound): _msg_fmt = _("Instance %(instance)s could not be found.")
[docs]class InputFileError(IronicException): _msg_fmt = _("Error with file %(file_name)s. Reason: %(reason)s")
[docs]class NodeNotFound(NotFound): _msg_fmt = _("Node %(node)s could not be found.")
[docs]class PortgroupNotFound(NotFound): _msg_fmt = _("Portgroup %(portgroup)s could not be found.")
[docs]class PortgroupNotEmpty(Invalid): _msg_fmt = _("Cannot complete the requested action because portgroup " "%(portgroup)s contains ports.")
[docs]class NodeAssociated(InvalidState): _msg_fmt = _("Node %(node)s is associated with instance %(instance)s.")
[docs]class PortNotFound(NotFound): _msg_fmt = _("Port %(port)s could not be found.")
[docs]class FailedToUpdateDHCPOptOnPort(IronicException): _msg_fmt = _("Update DHCP options on port: %(port_id)s failed.")
[docs]class FailedToCleanDHCPOpts(IronicException): _msg_fmt = _("Clean up DHCP options on node: %(node)s failed.")
[docs]class FailedToGetIPAddressOnPort(IronicException): _msg_fmt = _("Retrieve IP address on port: %(port_id)s failed.")
[docs]class InvalidIPv4Address(IronicException): _msg_fmt = _("Invalid IPv4 address %(ip_address)s.")
[docs]class FailedToUpdateMacOnPort(IronicException): _msg_fmt = _("Update MAC address on port: %(port_id)s failed.")
[docs]class ChassisNotFound(NotFound): _msg_fmt = _("Chassis %(chassis)s could not be found.")
[docs]class NoDriversLoaded(IronicException): _msg_fmt = _("Conductor %(conductor)s cannot be started " "because no drivers were loaded.")
[docs]class ConductorNotFound(NotFound): _msg_fmt = _("Conductor %(conductor)s could not be found.")
[docs]class ConductorAlreadyRegistered(IronicException): _msg_fmt = _("Conductor %(conductor)s already registered.")
[docs]class PowerStateFailure(InvalidState): _msg_fmt = _("Failed to set node power state to %(pstate)s.")
[docs]class ExclusiveLockRequired(NotAuthorized): _msg_fmt = _("An exclusive lock is required, " "but the current context has a shared lock.")
[docs]class NodeMaintenanceFailure(Invalid): _msg_fmt = _("Failed to toggle maintenance-mode flag " "for node %(node)s: %(reason)s")
[docs]class NodeConsoleNotEnabled(Invalid): _msg_fmt = _("Console access is not enabled on node %(node)s")
[docs]class NodeInMaintenance(Invalid): _msg_fmt = _("The %(op)s operation can't be performed on node " "%(node)s because it's in maintenance mode.")
[docs]class ChassisNotEmpty(Invalid): _msg_fmt = _("Cannot complete the requested action because chassis " "%(chassis)s contains nodes.")
[docs]class IPMIFailure(IronicException): _msg_fmt = _("IPMI call failed: %(cmd)s.")
[docs]class AMTConnectFailure(IronicException): _msg_fmt = _("Failed to connect to AMT service. This could be caused " "by the wrong amt_address or bad network environment.")
[docs]class AMTFailure(IronicException): _msg_fmt = _("AMT call failed: %(cmd)s.")
[docs]class MSFTOCSClientApiException(IronicException): _msg_fmt = _("MSFT OCS call failed.")
[docs]class SSHConnectFailed(IronicException): _msg_fmt = _("Failed to establish SSH connection to host %(host)s.")
[docs]class SSHCommandFailed(IronicException): _msg_fmt = _("Failed to execute command via SSH: %(cmd)s.")
[docs]class UnsupportedDriverExtension(Invalid): _msg_fmt = _('Driver %(driver)s does not support %(extension)s ' '(disabled or not implemented).')
[docs]class GlanceConnectionFailed(IronicException): _msg_fmt = _("Connection to glance host %(host)s:%(port)s failed: " "%(reason)s")
[docs]class ImageNotAuthorized(NotAuthorized): _msg_fmt = _("Not authorized for image %(image_id)s.")
[docs]class InvalidImageRef(Invalid): _msg_fmt = _("Invalid image href %(image_href)s.")
[docs]class ImageRefValidationFailed(IronicException): _msg_fmt = _("Validation of image href %(image_href)s failed, " "reason: %(reason)s")
[docs]class ImageDownloadFailed(IronicException): _msg_fmt = _("Failed to download image %(image_href)s, reason: %(reason)s")
[docs]class KeystoneUnauthorized(IronicException): _msg_fmt = _("Not authorized in Keystone.")
[docs]class KeystoneFailure(IronicException): pass
[docs]class CatalogNotFound(IronicException): _msg_fmt = _("Service type %(service_type)s with endpoint type " "%(endpoint_type)s not found in keystone service catalog.")
[docs]class ServiceUnavailable(IronicException): _msg_fmt = _("Connection failed")
[docs]class Forbidden(IronicException): _msg_fmt = _("Requested OpenStack Images API is forbidden")
[docs]class BadRequest(IronicException): pass
[docs]class InvalidEndpoint(IronicException): _msg_fmt = _("The provided endpoint is invalid")
[docs]class CommunicationError(IronicException): _msg_fmt = _("Unable to communicate with the server.")
[docs]class HTTPForbidden(NotAuthorized): _msg_fmt = _("Access was denied to the following resource: %(resource)s")
[docs]class Unauthorized(IronicException): pass
[docs]class HTTPNotFound(NotFound): pass
[docs]class ConfigNotFound(IronicException): _msg_fmt = _("Could not find config at %(path)s")
[docs]class NodeLocked(Conflict): _msg_fmt = _("Node %(node)s is locked by host %(host)s, please retry " "after the current operation is completed.")
[docs]class NodeNotLocked(Invalid): _msg_fmt = _("Node %(node)s found not to be locked on release")
[docs]class NoFreeConductorWorker(TemporaryFailure): _msg_fmt = _('Requested action cannot be performed due to lack of free ' 'conductor workers.') code = http_client.SERVICE_UNAVAILABLE
[docs]class VendorPassthruException(IronicException): pass
[docs]class ConfigInvalid(IronicException): _msg_fmt = _("Invalid configuration file. %(error_msg)s")
[docs]class DriverLoadError(IronicException): _msg_fmt = _("Driver %(driver)s could not be loaded. Reason: %(reason)s.")
[docs]class ConsoleError(IronicException): pass
[docs]class NoConsolePid(ConsoleError): _msg_fmt = _("Could not find pid in pid file %(pid_path)s")
[docs]class ConsoleSubprocessFailed(ConsoleError): _msg_fmt = _("Console subprocess failed to start. %(error)s")
[docs]class PasswordFileFailedToCreate(IronicException): _msg_fmt = _("Failed to create the password file. %(error)s")
[docs]class IloOperationError(IronicException): _msg_fmt = _("%(operation)s failed, error: %(error)s")
[docs]class IloOperationNotSupported(IronicException): _msg_fmt = _("%(operation)s not supported. error: %(error)s")
[docs]class DracOperationError(IronicException): _msg_fmt = _('DRAC operation failed. Reason: %(error)s')
[docs]class FailedToGetSensorData(IronicException): _msg_fmt = _("Failed to get sensor data for node %(node)s. " "Error: %(error)s")
[docs]class FailedToParseSensorData(IronicException): _msg_fmt = _("Failed to parse sensor data for node %(node)s. " "Error: %(error)s")
[docs]class InsufficientDiskSpace(IronicException): _msg_fmt = _("Disk volume where '%(path)s' is located doesn't have " "enough disk space. Required %(required)d MiB, " "only %(actual)d MiB available space present.")
[docs]class ImageCreationFailed(IronicException): _msg_fmt = _('Creating %(image_type)s image failed: %(error)s')
[docs]class SwiftOperationError(IronicException): _msg_fmt = _("Swift operation '%(operation)s' failed: %(error)s")
[docs]class SwiftObjectNotFoundError(SwiftOperationError): _msg_fmt = _("Swift object %(object)s from container %(container)s " "not found. Operation '%(operation)s' failed.")
[docs]class SNMPFailure(IronicException): _msg_fmt = _("SNMP operation '%(operation)s' failed: %(error)s")
[docs]class FileSystemNotSupported(IronicException): _msg_fmt = _("Failed to create a file system. " "File system %(fs)s is not supported.")
[docs]class IRMCOperationError(IronicException): _msg_fmt = _('iRMC %(operation)s failed. Reason: %(error)s')
[docs]class IRMCSharedFileSystemNotMounted(IronicException): _msg_fmt = _("iRMC shared file system '%(share)s' is not mounted.")
[docs]class VirtualBoxOperationFailed(IronicException): _msg_fmt = _("VirtualBox operation '%(operation)s' failed. " "Error: %(error)s")
[docs]class HardwareInspectionFailure(IronicException): _msg_fmt = _("Failed to inspect hardware. Reason: %(error)s")
[docs]class NodeCleaningFailure(IronicException): _msg_fmt = _("Failed to clean node %(node)s: %(reason)s")
[docs]class PathNotFound(IronicException): _msg_fmt = _("Path %(dir)s does not exist.")
[docs]class DirectoryNotWritable(IronicException): _msg_fmt = _("Directory %(dir)s is not writable.")
[docs]class UcsOperationError(IronicException): _msg_fmt = _("Cisco UCS client: operation %(operation)s failed for node" " %(node)s. Reason: %(error)s")
[docs]class UcsConnectionError(IronicException): _msg_fmt = _("Cisco UCS client: connection failed for node " "%(node)s. Reason: %(error)s")
[docs]class WolOperationError(IronicException): pass
[docs]class ImageUploadFailed(IronicException): _msg_fmt = _("Failed to upload %(image_name)s image to web server " "%(web_server)s, reason: %(reason)s")
[docs]class CIMCException(IronicException): _msg_fmt = _("Cisco IMC exception occurred for node %(node)s: %(error)s")
[docs]class OneViewError(IronicException): _msg_fmt = _("OneView exception occurred. Error: %(error)s")
[docs]class OneViewInvalidNodeParameter(OneViewError): _msg_fmt = _("Error while obtaining OneView info from node %(node_uuid)s. " "Error: %(error)s")
[docs]class NodeTagNotFound(IronicException): _msg_fmt = _("Node %(node_id)s doesn't have a tag '%(tag)s'")
[docs]class NetworkError(IronicException): _msg_fmt = _("Network operation failure.")
[docs]class IncompleteLookup(Invalid): _msg_fmt = _("At least one of 'addresses' and 'node_uuid' parameters " "is required")
[docs]class NotificationSchemaObjectError(IronicException): _msg_fmt = _("Expected object %(obj)s when populating notification payload" " but got object %(source)s")
[docs]class NotificationSchemaKeyError(IronicException): _msg_fmt = _("Object %(obj)s doesn't have the field \"%(field)s\" " "required for populating notification schema key " "\"%(key)s\"")
[docs]class NotificationPayloadError(IronicException): _msg_fmt = _("Payload not populated when trying to send notification " "\"%(class_name)s\"")

Project Source