Source code for zhmcclient._manager

# Copyright 2016,2021 IBM Corp. 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.

"""
Base definitions for resource manager classes.

Resource manager classes exist for each resource type and are helper classes
that provide functionality common for the resource type.

Resource manager objects are not necessarily singleton objects, because they
have a scope of a certain set of resource objects. For example, the resource
manager object for LPARs exists once for each CPC managed by the HMC, and the
resource object scope of each LPAR manager object is the set of LPARs in that
CPC.
"""

from __future__ import absolute_import

import re
from datetime import datetime, timedelta
import time
import warnings
import threading
import six
from nocasedict import NocaseDict

from ._logging import logged_api_call
from ._exceptions import NotFound, NoUniqueMatch, HTTPError
from ._utils import repr_list, matches_filters, divide_filter_args, \
    make_query_str, RC_LOGICAL_PARTITION

__all__ = ['BaseManager']


REGEXP_SPECIAL_CHAR = re.compile(r'[\^\$\.\+\*\?\(\)\[\]\{\}\|\\]')


class _NameUriCache(object):
    """
    A Name-URI cache, that caches the mapping between resource names and
    resource URIs. It supports looking up resource URIs by resource names.

    This class is used by the implementation of manager classes, and is not
    part of the external API.
    """

    def __init__(self, manager, timetolive, case_insensitive_names):
        """
        Parameters:

          manager (BaseManager): Manager that holds this Name-URI cache. The
            manager object is expected to have a ``list()`` method, which
            is used to list the resources of that manager, in order to
            fill this cache.

          timetolive (number): Time in seconds until the cache will invalidate
            itself automatically, since it was last invalidated.

          case_insensitive_names (bool): Controls whether the name of the
            resource is treated case insensitively.
        """
        self._manager = manager
        self._timetolive = timetolive
        self._dict_type = NocaseDict if case_insensitive_names else dict

        # The cached data, as a dictionary with:
        # Key (string): Name of a resource (unique within its parent resource).
        # Value (string): tuple(name, uri) where name is the original name
        # of the resource (important for resources with case-insensitive names)
        # and uri is the URI of the resource.
        self._uris = self._dict_type()

        # Point in time when the cache was last invalidated
        self._invalidated = datetime.now()

    def get(self, name):
        """
        Get the resource name and URI for a specified resource name as a
        tuple(name, uri).

        Note that for case-inensitive caches, it may be important to get back
        the original name, so both name and URI are returned.

        If an entry for the specified resource name does not exist in the
        Name-URI cache, the cache is refreshed from the HMC with all resources
        of the manager holding this cache.

        If an entry for the specified resource name still does not exist after
        that, ``NotFound`` is raised.
        """
        self.auto_invalidate()
        try:
            return self._uris[name]
        except KeyError:
            self.refresh()
            try:
                return self._uris[name]
            except KeyError:
                # pylint: disable=protected-access
                new_exc = NotFound(
                    {self._manager._name_prop: name}, self._manager)
                new_exc.__cause__ = None
                raise new_exc  # zhmcclient.NotFound

    def auto_invalidate(self):
        """
        Invalidate the cache if the current time is past the time to live.
        """
        current = datetime.now()
        if current > self._invalidated + timedelta(seconds=self._timetolive):
            self.invalidate()

    def invalidate(self):
        """
        Invalidate the cache.

        This empties the cache and sets the time of last invalidation to the
        current time.
        """
        self._uris = self._dict_type()
        self._invalidated = datetime.now()

    def refresh(self):
        """
        Refresh the Name-URI cache from the HMC.

        This is done by invalidating the cache, listing the resources of this
        manager from the HMC, and populating the cache with that information.
        """
        # pylint: disable=protected-access
        self.invalidate()
        full = not self._manager._list_has_name
        res_list = self._manager.list(full_properties=full)
        self.update_from(res_list)

    def update_from(self, res_list):
        """
        Update the Name-URI cache from the provided resource list.

        This is done by going through the resource list and updating any cache
        entries for non-empty resource names in that list. Other cache entries
        remain unchanged.
        """
        # pylint: disable=protected-access
        for res in res_list:
            # We access the properties dictionary, in order to make sure
            # we don't drive additional HMC interactions.
            name = res.properties.get(self._manager._name_prop, None)
            uri = res.properties.get(self._manager._uri_prop, None)
            self.update(name, uri)

    def update(self, name, uri):
        """
        Update or create the entry for the specified resource name in the
        Name-URI cache, and set it to the specified name and URI as a
        tuple(name, uri).

        If the specified name is `None` or the empty string, do nothing.
        """
        if name:
            self._uris[name] = (name, uri)

    def delete(self, name):
        """
        Delete the entry for the specified resource name from the Name-URI
        cache.

        If the specified name is `None` or the empty string, or if an entry for
        the specified name does not exist, do nothing.
        """
        if name:
            try:
                del self._uris[name]
            except KeyError:
                pass


class _ResourceList(object):
    """
    A list of resources, for use by resource manager objects for auto-updating.

    The resources in the list are the zhmcclient resource objects, organized by
    resource URI.

    This class is used by the implementation of manager classes, and is not
    part of the external API.
    """

    def __init__(self, manager):
        """
        Parameters:

          manager (BaseManager): Manager that holds this list of resources. The
            manager object is expected to have a ``list()`` method, which is
            used to list the resources of that manager.
        """
        self._manager = manager

        # Attributes that are updated under the lock
        self._lock = threading.RLock()
        self._resources = {}  # key: resource URI, value: resource obj
        self._needs_pull = True  # list() method needs to pull from HMC
        self._enabled = False  # Auto-updating of manager is enabled

    def __repr__(self):
        """
        Return a string with the state of this object, for debug purposes.
        """
        ret = (
            "{classname} at 0x{id:08x} (\n"
            "  _enabled={_enabled!r},\n"
            "  _resources(keys)={_resource_keys!r}\n"
            ")".format(
                classname=self.__class__.__name__,
                id=id(self),
                _enabled=self._enabled,
                _resource_keys=list(self._resources.keys()),
            ))
        return ret

    def enabled(self):
        """
        Return whether this list of resources is enabled.

        Return:
          bool: Indicates whether this list of resources is enabled.
        """
        return self._enabled

    def needs_pull(self):
        """
        Return whether this list of resources needs to be pulled from the HMC.
        """
        return self._needs_pull

    def enable(self):
        """
        Enable this list of resources, if currently disabled.

        When enabling, the session to which this manager belongs is subscribed
        for auto-updating if needed (see
        :meth:`~zhmcclient.Session.subscribe_auto_update`), the manager
        object is registered with the session's auto updater via
        :meth:`~zhmcclient.AutoUpdater.register_object`, and all resources
        of this manager object are retrieved using :meth:`list` in order to
        have the most current list of resources as a basis for the future
        auto-updating.

        Raises:

          :exc:`~zhmcclient.HTTPError`
          :exc:`~zhmcclient.ParseError`
          :exc:`~zhmcclient.AuthError`
          :exc:`~zhmcclient.ConnectionError`
        """
        if not self._enabled:
            session = self._manager.session
            session.subscribe_auto_update()
            session.auto_updater.register_object(self._manager)

            # The following list() call needs to pull from HMC. That is
            # happening because the resource list is still disabled at this
            # point.
            resource_list = self._manager.list()

            with self._lock:
                self._resources = {}
                for res_obj in resource_list:
                    self._resources[res_obj.uri] = res_obj
                self._needs_pull = False
                self._enabled = True

    def disable(self):
        """
        Disable this list of resources, if currently enabled.

        When disabling, the manager object is unregistered from the session's
        auto updater via
        :meth:`~zhmcclient.AutoUpdater.unregister_object`, and the session
        is unsubscribed from auto-updating if the auto updater has no more
        objects registered. Also, the list of resources is cleared.
        """
        if self._enabled:
            session = self._manager.session
            session.auto_updater.unregister_object(self._manager)
            if not session.auto_updater.has_objects():
                session.unsubscribe_auto_update()
            with self._lock:
                self._resources = {}
                self._needs_pull = True
                self._enabled = False

    def list(self):
        """
        Return a new list with the resource objects from this list of resources.
        """
        res_list = []
        with self._lock:
            for res_obj in self._resources.values():
                res_list.append(res_obj)
        return res_list

    def list_uris(self):
        """
        Return a new list with the resource URIs from this list of resources.
        """
        uri_list = []
        with self._lock:
            for res_uri in self._resources:
                uri_list.append(res_uri)
        return uri_list

    def add_list(self, resource_obj_list):
        """
        Add a new resource object list to this list of resources and mark
        it as no longer needing pull from the HMC.

        This method is called in list() to put resources pulled from the HMC
        into the list of resources. It should not be called by the user.
        """
        with self._lock:
            for res_obj in resource_obj_list:
                self._resources[res_obj.uri] = res_obj
            self._needs_pull = False

    def trigger_pull(self):
        """
        Trigger that resources need to be pulled from the HMC upon the next
        list() call of the manager object.

        This method is called when an inventory change notification indicates
        that a new object on the HMC has been created. It should not be called
        by the user.
        """
        with self._lock:
            self._needs_pull = True

    def remove(self, resource_uri):
        """
        Remove the item for a resource URI from this list of resources.

        If the resource URI is not in that list, do nothing.

        This method is called when an inventory change notification indicates
        that an object on the HMC has been deleted. It should not be called
        by the user.
        """
        with self._lock:
            try:
                del self._resources[resource_uri]
            except KeyError:
                pass


[docs] class BaseManager(object): """ Abstract base class for manager classes (e.g. :class:`~zhmcclient.CpcManager`). It defines the interface for the derived manager classes, and implements methods that have a common implementation for the derived manager classes. Objects of derived manager classes should not be created by users of this package by simply instantiating them. Instead, such objects are created by this package as instance variables of :class:`~zhmcclient.Client` and other resource objects, e.g. :attr:`~zhmcclient.Client.cpcs`. For this reason, the `__init__()` method of this class and of its derived manager classes are considered internal interfaces and their parameters are not documented and may change incompatibly. """ def __init__(self, resource_class, class_name, session, parent, base_uri, oid_prop, uri_prop, name_prop, query_props, list_has_name=True, case_insensitive_names=False, supports_properties=False): # This method intentionally has no docstring, because it is internal. # # Parameters: # resource_class (class): # Python class for the resources of this manager. # Must not be `None`. # class_name (string): # Resource class name (e.g. 'cpc' for a CPC resource). Must # be the value of the 'class' property of the resource. # Must not be `None`. # session (:class:`~zhmcclient.Session`): # Session for this manager. # Must not be `None`. # parent (subclass of :class:`~zhmcclient.BaseResource`): # Parent resource defining the scope for this manager. # `None`, if the manager has no parent, i.e. when it manages # top-level resources (e.g. CPC). # base_uri (string): # Base URI of the resources of this manager. The base URI has no # trailing slash and becomes the resource URI by appending '/' and # the value of the property specified in 'oid_prop'. # Must not be `None`. # oid_prop (string): # Name of the resource property whose value is appended to the # base URI to form the resource URI (e.g. 'object-id' or # 'element-id'). # Must not be `None`. # uri_prop (string): # Name of the resource property that is the canonical URI path of # the resource (e.g. 'object-uri' or 'element-uri'). # Must not be `None`. # name_prop (string): # Name of the resource property that is the name of the resource # (e.g. 'name'). # Must not be `None`. # query_props (iterable of strings): # List of names of resource properties that are supported as filter # query parameters in HMC list operations for this type of resource # (i.e. for server-side filtering). # May be `None`. # If the support for a resource property changes within the set of # HMC versions that support this type of resource, this list must # represent the version of the HMC this session is connected to. # list_has_name (bool): # Indicates whether the list() method for the resource populates # the name property (i.e. name_prop). For example, for NICs the # list() method returns minimalistic Nic objects without name. # case_insensitive_names (bool): # Indicates whether the name of the resource is treated case # insensitively. # supports_properties (bool): # Indicates whether the Get Properties operation for this type of # resource supports the 'properties' query parameter in the latest # released version of the HMC. # We want to surface precondition violations as early as possible, # so we test those that are not surfaced through the init code: assert resource_class is not None assert class_name is not None assert session is not None assert base_uri is not None assert oid_prop is not None assert uri_prop is not None assert name_prop is not None self._resource_class = resource_class self._class_name = class_name self._uri = None self._session = session self._parent = parent self._base_uri = base_uri self._oid_prop = oid_prop self._uri_prop = uri_prop self._name_prop = name_prop self._query_props = query_props self._list_has_name = list_has_name self._case_insensitive_names = case_insensitive_names self._supports_properties = supports_properties self._resource_list = _ResourceList(self) self._name_uri_cache = _NameUriCache( self, session.retry_timeout_config.name_uri_cache_timetolive, case_insensitive_names)
[docs] def __repr__(self): """ Return a string with the state of this manager object, for debug purposes. """ ret = ( "{classname} at 0x{id:08x} (\n" " _resource_class={_resource_class!r},\n" " _class_name={_class_name!r},\n" " _uri={_uri!r},\n" " _session={_session_classname} at 0x{_session_id:08x},\n" " _parent={_parent_classname} at 0x{_parent_id:08x},\n" " _base_uri={_base_uri!r},\n" " _oid_prop={_oid_prop!r},\n" " _uri_prop={_uri_prop!r},\n" " _name_prop={_name_prop!r},\n" " _query_props={_query_props},\n" " _list_has_name={_list_has_name!r},\n" " _case_insensitive_names={_case_insensitive_names!r},\n" " _supports_properties={_supports_properties!r},\n" " _resource_list={_resource_list!r},\n" " _name_uri_cache={_name_uri_cache!r}\n" ")".format( classname=self.__class__.__name__, id=id(self), _resource_class=self._resource_class, _class_name=self._class_name, _uri=self._uri, _session_classname=self._session.__class__.__name__, _session_id=id(self._session), _parent_classname=self._parent.__class__.__name__, _parent_id=id(self._parent), _base_uri=self._base_uri, _oid_prop=self._oid_prop, _uri_prop=self._uri_prop, _name_prop=self._name_prop, _query_props=repr_list(self._query_props, indent=2), _list_has_name=self._list_has_name, _case_insensitive_names=self._case_insensitive_names, _supports_properties=self._supports_properties, _resource_list=self._resource_list, _name_uri_cache=self._name_uri_cache, )) return ret
[docs] def invalidate_cache(self): """ Invalidate the Name-URI cache of this manager. The zhmcclient maintains a Name-URI cache in each manager object, which caches the mappings between resource URIs and resource names, to speed up certain zhmcclient methods. The Name-URI cache is properly updated during changes on the resource name (e.g. via :meth:`~zhmcclient.Partition.update_properties`) or changes on the resource URI (e.g. via resource creation or deletion), if these changes are performed through the same Python manager object. However, changes performed through a different manager object (e.g. because a different session, client or parent resource object was used), or changes performed in a different Python process, or changes performed via other means than the zhmcclient library (e.g. directly on the HMC) will not automatically update the Name-URI cache of this manager. In cases where the resource name or resource URI are effected by such changes, the Name-URI cache can be manually invalidated by the user, using this method. Note that the Name-URI cache automatically invalidates itself after a certain time since the last invalidation. That auto invalidation time can be configured using the :attr:`~zhmcclient.RetryTimeoutConfig.name_uri_cache_timetolive` attribute of the :class:`~zhmcclient.RetryTimeoutConfig` class. """ self._name_uri_cache.invalidate()
def _try_optimized_lookup(self, filter_args): """ Try to find a resource in an optimized way when the filter arguments allow for that. The following cases of optimized filtering are supported: - A single filter on the resource name, that does not use regular expression matching. - A single filter on the resource object/element ID, that does not use regular expression matching. Returns `None` if the filter arguments do not meet these optimization criteria, or if they do but no resource was found. Parameters: filter_args (dict): Filter arguments. For details, see :ref:`Filtering`. Returns: resource object, or `None` if the the filter arguments did not meet the optimization criteria, or if they did but no resource was found. """ if filter_args is None or len(filter_args) != 1: return None if self._name_prop in filter_args: name_match = filter_args[self._name_prop] if not isinstance(name_match, six.string_types) or \ REGEXP_SPECIAL_CHAR.search(name_match): return None try: resource_obj = self.find_by_name(name_match) except NotFound: return None return resource_obj if self._oid_prop in filter_args: oid_match = filter_args[self._oid_prop] if not isinstance(oid_match, six.string_types) or \ REGEXP_SPECIAL_CHAR.search(oid_match): return None # Construct the resource URI from the filter property # and issue a Get <Resource> Properties on that URI uri = self._base_uri + '/' + oid_match try: props = self.session.get(uri) except HTTPError as exc: if exc.http_status == 404 and exc.reason == 1: # No such resource return None raise resource_obj = self.resource_class( manager=self, uri=props[self._uri_prop], name=props.get(self._name_prop, None), properties=props) # pylint: disable=protected-access resource_obj._full_properties = True return resource_obj return None @property def resource_class(self): """ The Python class of the parent resource of this manager. """ return self._resource_class @property def class_name(self): """ The resource class name """ return self._class_name @property def name_prop(self): """ The name of the resource property indicating the resource name """ return self._name_prop @property def session(self): """ :class:`~zhmcclient.Session`: Session with the HMC. """ assert self._session is not None, \ "{}.session: No session set (in top-level resource manager " \ "class?)" .format(self.__class__.__name__) return self._session @property def parent(self): """ Subclass of :class:`~zhmcclient.BaseResource`: Parent resource defining the scope for this manager. `None`, if the manager has no parent, i.e. when it manages top-level resources. """ return self._parent @property def uri(self): """ string: The canonical URI path of the manager. Will not be `None`. This URI uniquely identifies the list of HMC resources in scope of the manager, consistent with how the canonical URI path of a resource identifies the HMC resource. The format of this URI is undocumented. This URI is used in the implementation of auto-updated manager objects, it does not have any meaning on the HMC, and there should be no need for users to use it. """ if self._uri is None: if self._parent: parent_uri = self._parent.uri else: parent_uri = '/' # top-level resource self._uri = '{}#{}'.format(parent_uri, self._class_name) return self._uri @property def case_insensitive_names(self): """ :class:`py:bool`: Indicates whether the names of the resources are treated case insensitively. """ return self._case_insensitive_names @property def supports_properties(self): """ :class:`py:bool`: Indicates whether the "Get Properties" operation for this type of resource supports the 'properties' query parameter in the latest released version of the HMC. """ return self._supports_properties def _list_with_operation( self, list_uri, result_prop, full_properties, filter_args, additional_properties): """ List resource objects by using a List operation. Any resource property may be specified in a filter argument. For details about filter arguments, see :ref:`Filtering`. The listing of resources is handled in an optimized way: * If this manager is enabled for :ref:`auto-updating`, a locally maintained resource list is used (which is automatically updated via inventory notifications from the HMC) and the provided filter arguments are applied. * Otherwise, the HMC List operation is performed with the subset of the provided filter arguments that can be handled on the HMC side and the remaining filter arguments are applied on the client side on the list result. Parameters: list_uri (string): Canonical URI for the list operation. result_prop (string): Name of property in result of list operation that contains the resource list. full_properties (bool): Controls whether the full set of resource properties should be retrieved, vs. only the short set as returned by the list operation. filter_args (dict): Filter arguments that narrow the list of returned resources to those that match the specified filter arguments. For details, see :ref:`Filtering`. `None` causes no filtering to happen, i.e. all resources are returned. additional_properties (list of string): List of property names that are to be returned in addition to the default properties. Must be `None` for resource types whose List operation does not support the 'additional-properties' query parameter. Returns: : A list of zhmcclient resource objects. Raises: :exc:`~zhmcclient.HTTPError` :exc:`~zhmcclient.ParseError` :exc:`~zhmcclient.AuthError` :exc:`~zhmcclient.ConnectionError` """ resource_obj_list = [] if self.auto_update_enabled() and not self.auto_update_needs_pull(): for resource_obj in self.list_resources_local(): if matches_filters(resource_obj, filter_args): resource_obj_list.append(resource_obj) else: query_parms, client_filters = divide_filter_args( self._query_props, filter_args) if additional_properties: ap_parm = 'additional-properties={}'.format( ','.join(additional_properties)) query_parms.append(ap_parm) query_parms_str = make_query_str(query_parms) uri = '{}{}'.format(list_uri, query_parms_str) try: result = self.session.get(uri) except HTTPError as exc: if self.class_name == RC_LOGICAL_PARTITION and \ exc.http_status == 404 and exc.reason == 1: # Unlike other list operations, "List Logical Partitions # of CPC" fails with 404.1 "ERROR: found no Images" if # no LPAR matches the filters in the query parms. result = [] else: raise if result: props_list = result[result_prop] if full_properties: resource_obj_list.extend( self._get_properties_bulk( props_list, client_filters)) else: for props in props_list: resource_obj = self.resource_class( manager=self, uri=props[self._uri_prop], name=props.get(self._name_prop, None), properties=props) if matches_filters(resource_obj, client_filters): resource_obj_list.append(resource_obj) self.add_resources_local(resource_obj_list) self._name_uri_cache.update_from(resource_obj_list) return resource_obj_list def _get_properties_bulk(self, props_list, client_filters): """ Get resource properties using a bulk operation. Parameters: props_list (list of dict): List of resource properties from List operation. Must contain the resource URIs. These properties will appear in the returned zhmcclient resource objects, updated by the actual property values from the HMC. This allows adding properties to those returned by the HMC. client_filters (dict): Filter arguments to be applied on the client side after the resource properties have been retrieved. `None` causes no client filtering to happen. Returns: : A list of zhmcclient resource objects. Raises: :exc:`~zhmcclient.HTTPError` :exc:`~zhmcclient.ParseError` :exc:`~zhmcclient.AuthError` :exc:`~zhmcclient.ConnectionError` """ resource_obj_list = [] bulk_reqs = [] req_by_id = {} req_id = 0 for props in props_list: req_id += 1 req_id_str = str(req_id) req = { 'method': 'GET', 'uri': props[self._uri_prop], 'id': req_id_str, } bulk_reqs.append(req) req_by_id[req_id_str] = (req, props) if bulk_reqs: uri = '/api/services/aggregation/submit' # 10 threads is the supported maximum threads = min(10, round(len(props_list) / 2 + 0.51)) body = { 'requests': bulk_reqs, 'threads': threads, } result = self.session.post(uri, body=body) for res in result: req_id = res['id'] req, props = req_by_id[req_id] # We first use the properties from the props_list parameter, # and then update that with the properties returned from the # HMC: resource_props = dict(props) resource_props.update(res['body']) if res['status'] != 200: # Similar to the non-full case: The first # error raises an exception. raise HTTPError(resource_props) resource_obj = self.resource_class( manager=self, uri=req['uri'], name=resource_props.get(self._name_prop, None), properties=resource_props) # pylint: disable=protected-access with resource_obj._property_lock: resource_obj._properties = dict(resource_props) resource_obj._properties_timestamp = int(time.time()) resource_obj._full_properties = True # pylint: enable=protected-access if matches_filters(resource_obj, client_filters): resource_obj_list.append(resource_obj) return resource_obj_list def _list_with_parent_array( self, parent_obj, uris_prop, full_properties, filter_args): """ List resource objects by using an array of URIs in the parent object. Any resource property may be specified in a filter argument. For details about filter arguments, see :ref:`Filtering`. The listing of resources is handled in an optimized way: * If this manager is enabled for :ref:`auto-updating`, a locally maintained resource list is used (which is automatically updated via inventory notifications from the HMC) and the provided filter arguments are applied. * Otherwise, the corresponding array property for this resource in the parent object is used to list the resources, and the provided filter arguments are applied. Parameters: parent_obj (zhmcclient.BaseResource): The parent object. uris_prop (string): Name of the array property with URIs in the parent object. full_properties (bool): Controls whether the full set of resource properties should be retrieved, vs. only the short set as returned by the list operation. filter_args (dict): Filter arguments that narrow the list of returned resources to those that match the specified filter arguments. For details, see :ref:`Filtering`. `None` causes no filtering to happen, i.e. all resources are returned. Returns: : A list of zhmcclient resource objects. Raises: :exc:`~zhmcclient.HTTPError` :exc:`~zhmcclient.ParseError` :exc:`~zhmcclient.AuthError` :exc:`~zhmcclient.ConnectionError` """ resource_obj_list = [] if self.auto_update_enabled() and not self.auto_update_needs_pull(): for resource_obj in self.list_resources_local(): if matches_filters(resource_obj, filter_args): resource_obj_list.append(resource_obj) else: uris = parent_obj.get_property(uris_prop) if uris: for uri in uris: resource_obj = self.resource_class( manager=self, uri=uri, name=None, properties=None) if matches_filters(resource_obj, filter_args): resource_obj_list.append(resource_obj) if full_properties: resource_obj.pull_full_properties() self.add_resources_local(resource_obj_list) self._name_uri_cache.update_from(resource_obj_list) return resource_obj_list
[docs] def auto_update_enabled(self): """ Return whether :ref:`auto-updating` is currently enabled for the manager object. Return: bool: Indicates whether auto-update is enabled. """ return self._resource_list.enabled()
[docs] def auto_update_needs_pull(self): """ Return whether there is a need to pull the resources from the HMC, in the list() method. This method is called in the list() method. It should not be called by the user. """ return self._resource_list.needs_pull()
[docs] def enable_auto_update(self): """ Enable :ref:`auto-updating` for this manager object, if currently disabled. When enabling auto-update, the session to which this manager belongs is subscribed for auto-updating if needed (see :meth:`~zhmcclient.Session.subscribe_auto_update`), the manager object is registered with the session's auto updater via :meth:`~zhmcclient.AutoUpdater.register_object`, and all resources of this manager object are retrieved using :meth:`list` in order to have the most current list of resources as a basis for the future auto-updating. Raises: :exc:`~zhmcclient.HTTPError` :exc:`~zhmcclient.ParseError` :exc:`~zhmcclient.AuthError` :exc:`~zhmcclient.ConnectionError` """ self._resource_list.enable()
[docs] def disable_auto_update(self): """ Disable :ref:`auto-updating` for this manager object, if currently enabled. When disabling auto-updating, the manager object is unregistered from the session's auto updater via :meth:`~zhmcclient.AutoUpdater.unregister_object`, and the session is unsubscribed from auto-updating if the auto updater has no more objects registered. """ self._resource_list.disable()
[docs] def auto_update_trigger_pull(self): """ Trigger the need to pull the resources from the HMC, in the list() method. This method is called when an inventory change notification indicates that a new object on the HMC has been created. It should not be called by the user. """ self._resource_list.trigger_pull()
[docs] def add_resources_local(self, resource_obj_list): """ Add a resource object to the local auto-updated list of resources. This method is called in list() to put resources pulled from the HMC into the list of resources. It should not be called by the user. """ self._resource_list.add_list(resource_obj_list)
[docs] def remove_resource_local(self, resource_uri): """ Remove the resource object for a resource URI from the local auto-updated list of resources. If the resource URI is not in that list, do nothing. This method is called when an inventory change notification indicates that an object on the HMC has been deleted. It should not be called by the user. """ self._resource_list.remove(resource_uri)
[docs] def list_resources_local(self): """ List the resource objects from the local auto-updated list of resources. This method is called by the list() methods of resource manager classes. It should not be called by the user. """ return self._resource_list.list()
[docs] def resource_object(self, uri_or_oid, props=None): """ Return a minimalistic Python resource object for this resource class, that is scoped to this manager. This method is an internal helper function and is not normally called by users. The returned resource object will have the following minimal set of properties set automatically: * `object-uri` or `element-uri` * `object-id` or `element-id` * `parent` * `class` Additional properties for the Python resource object can be specified by the caller. Parameters: uri_or_oid (string): `object-uri` or `object-id` of the resource. props (dict): Property values in addition to the minimal list of properties that are set automatically (see above). Returns: Subclass of :class:`~zhmcclient.BaseResource`: A Python resource object for this resource class. """ if uri_or_oid.startswith('/api/'): assert uri_or_oid[-1] != '/' uri = uri_or_oid oid = uri.split('/')[-1] # For the Console, we can predict the URI but not the OID. if oid == 'console': oid = None else: assert '/' not in uri_or_oid oid = uri_or_oid uri = '{}/{}'.format(self._base_uri, oid) res_props = { 'parent': self.parent.uri if self.parent is not None else None, 'class': self.class_name, } if oid: res_props[self._oid_prop] = oid name = None if props: res_props.update(props) try: name = props[self._name_prop] except KeyError: pass return self.resource_class(self, uri, name, res_props)
[docs] @logged_api_call def findall(self, **filter_args): """ Find zero or more resources in scope of this manager, by matching resource properties against the specified filter arguments, and return a list of their Python resource objects (e.g. for CPCs, a list of :class:`~zhmcclient.Cpc` objects is returned). Any resource property may be specified in a filter argument. For details about filter arguments, see :ref:`Filtering`. The listing of resources is handled in an optimized way, as described in :meth:`~zhmcclient.BaseManager.list`. Authorization requirements: * see the `list()` method in the derived classes. Parameters: \\**filter_args: All keyword arguments are used as filter arguments. Specifying no keyword arguments causes no filtering to happen. See the examples for usage details. Returns: List of resource objects in scope of this manager object that match the filter arguments. These resource objects have a minimal set of properties. Raises: : Exceptions raised by the `list()` methods in derived resource manager classes (see :ref:`Resources`). Examples: * The following example finds partitions in a CPC by status. Because the 'status' resource property is also a valid Python variable name, there are two ways for the caller to specify the filter arguments for this method: As named parameters:: run_states = ['active', 'degraded'] run_parts = cpc.partitions.find(status=run_states) As a parameter dictionary:: run_parts = cpc.partitions.find(**{'status': run_states}) * The following example finds adapters of the OSA family in a CPC with an active status. Because the resource property for the adapter family is named 'adapter-family', it is not suitable as a Python variable name. Therefore, the caller can specify the filter argument only as a parameter dictionary:: filter_args = {'adapter-family': 'osa', 'status': 'active'} active_osa_adapters = cpc.adapters.findall(**filter_args) """ obj_list = self.list(filter_args=filter_args) return obj_list
[docs] @logged_api_call def find(self, **filter_args): """ Find exactly one resource in scope of this manager, by matching resource properties against the specified filter arguments, and return its Python resource object (e.g. for a CPC, a :class:`~zhmcclient.Cpc` object is returned). Any resource property may be specified in a filter argument. For details about filter arguments, see :ref:`Filtering`. The listing of resources is handled in an optimized way, as described in :meth:`~zhmcclient.BaseManager.list`. Authorization requirements: * see the `list()` method in the derived classes. Parameters: \\**filter_args: All keyword arguments are used as filter arguments. Specifying no keyword arguments causes no filtering to happen. See the examples for usage details. If the resource name is specified in the filter arguments, it is matched with string comparison (i.e. not as a regular expression). The string comparison is case sensitive or case insensitive, dependent on the resource type. Any other filter arguments are ignored if the resource name is specified, because the name is unique within the scope of this resource manager. Returns: Resource object in scope of this manager object that matches the filter arguments. This resource object has a minimal set of properties. Raises: :exc:`~zhmcclient.NotFound`: No matching resource found. :exc:`~zhmcclient.NoUniqueMatch`: More than one matching resource found. : Exceptions raised by the `list()` methods in derived resource manager classes (see :ref:`Resources`). Examples: * The following example finds a CPC by its name. Because the 'name' resource property is also a valid Python variable name, there are two ways for the caller to specify the filter arguments for this method: As named parameters:: cpc = client.cpcs.find(name='CPC001') As a parameter dictionary:: filter_args = {'name': 'CPC0001'} cpc = client.cpcs.find(**filter_args) * The following example finds a CPC by its object ID. Because the 'object-id' resource property is not a valid Python variable name, the caller can specify the filter argument only as a parameter dictionary:: filter_args = {'object-id': '12345-abc...de-12345'} cpc = client.cpcs.find(**filter_args) """ if self._name_prop in filter_args: return self.find_by_name(filter_args[self._name_prop]) obj_list = self.findall(**filter_args) num_objs = len(obj_list) if num_objs == 0: raise NotFound(filter_args, self) if num_objs > 1: raise NoUniqueMatch(filter_args, self, obj_list) return obj_list[0]
[docs] def list(self, full_properties=False, filter_args=None): """ Find zero or more resources in scope of this manager, by matching resource properties against the specified filter arguments, and return a list of their Python resource objects (e.g. for CPCs, a list of :class:`~zhmcclient.Cpc` objects is returned). Any resource property may be specified in a filter argument. For details about filter arguments, see :ref:`Filtering`. The listing of resources is handled in an optimized way: * If this manager is enabled for :ref:`auto-updating`, a locally maintained resource list is used (which is automatically updated via inventory notifications from the HMC) and the provided filter arguments are applied. * Otherwise, for resources that have a List operation, the List operation is performed with the subset of the provided filter arguments that can be handled on the HMC side (this varies by resource type) and the remaining filter arguments are applied on the client side on the list result. For resources that are element objects without a List operation, the corresponding array property of the parent object is used to list the resources, and the provided filter arguments are applied. At the level of the :class:`~zhmcclient.BaseManager` class, this method defines the interface for the `list()` methods implemented in the derived resource classes. Authorization requirements: * see the `list()` method in the derived classes. Parameters: full_properties (bool): Controls whether the full set of resource properties should be retrieved, vs. only a minimal set as returned by the list operation. filter_args (dict): Filter arguments. `None` causes no filtering to happen. See the examples for usage details. Returns: List of resource objects in scope of this manager object that match the filter arguments. These resource objects have a set of properties according to the `full_properties` parameter. Raises: : Exceptions raised by the `list()` methods in derived resource manager classes (see :ref:`Resources`). Examples: * The following example finds those OSA adapters in cage '1234' of a given CPC, whose state is 'stand-by', 'reserved', or 'unknown':: filter_args = { 'adapter-family': 'osa', 'card-location': '1234-.*', 'state': ['stand-by', 'reserved', 'unknown'], } osa_adapters = cpc.adapters.list(full_properties=True, filter_args=filter_args) The returned resource objects will have the full set of properties. """ raise NotImplementedError
[docs] @logged_api_call def find_by_name(self, name): """ Find a resource by name and return its Python resource object (e.g. for a CPC, a :class:`~zhmcclient.Cpc` object is returned). This method performs an optimized lookup that uses a name-to-URI mapping cached in this manager object. This method is automatically used by the :meth:`~zhmcclient.BaseManager.find` and :meth:`~zhmcclient.BaseManager.findall` methods, so it does not normally need to be used directly by users. Authorization requirements: * see the `list()` method in the derived classes. Parameters: name (string): Name of the resource. The name is matched with string comparison (i.e. not as a regular expression). The string comparison is case sensitive or case insensitive, dependent on the resource type. Must not be `None`. Returns: Resource object in scope of this manager object that has the specified name. This resource object has a minimal set of properties. Raises: :exc:`~zhmcclient.NotFound`: No matching resource found. : Exceptions raised by the `list()` methods in derived resource manager classes (see :ref:`Resources`). Examples: * The following example finds a CPC by its name:: cpc = client.cpcs.find_by_name('CPC001') """ name, uri = self._name_uri_cache.get(name) resource_props = { self._name_prop: name, } resource_obj = self.resource_object(uri, resource_props) return resource_obj
[docs] @logged_api_call def find_local(self, name, uri, properties=None): """ Return a local resource object without fetching it from the HMC. The resource object is fully functional, for example it has the proper parent resource object set and its properties can be fetched using :meth:`~zhmcclient.BaseResource.pull_full_properties`. If the resource object is in the name-to-URI cache, it is returned from there, and dependent on the history it may have a minimal set of properties or the full set of properties. Otherwise, a new resource object is constructed locally from the specified name, uri and properties parameters. That resource object is not put into the name-to-URI cache because there was no validation that the specified properties are up to date or even valid at all. Parameters: name (string): Name of the resource. The name is matched with string comparison (i.e. not as a regular expression). The string comparison is case sensitive or case insensitive, dependent on the resource type. Must not be `None`. uri (string): Object URI of the resource. Must not be `None`. properties (dict): Additional properties. Only used when the resource is not found in the name-to-URI cache. It is the responsibility of the user to ensure that the properties are valid. Returns: Resource object. """ # Get the resource object from the name-to-URI cache, if possible. resource_obj = self._try_optimized_lookup(dict(name=name)) if resource_obj: assert uri == resource_obj.uri return resource_obj # Create a new local resource object. resource_props = { self._name_prop: name, } resource_props.update(properties) resource_obj = self.resource_object(uri, resource_props) return resource_obj
[docs] @logged_api_call def flush(self): """ Invalidate the Name-URI cache of this manager. **Deprecated:** This method is deprecated and using it will cause a :exc:`~py:exceptions.DeprecationWarning` to be issued. Use :meth:`~zhmcclient.BaseManager.invalidate_cache` instead. """ warnings.warn( "Use of flush() on zhmcclient manager objects is deprecated; " "use invalidate_cache() instead", DeprecationWarning) self.invalidate_cache()
[docs] def dump(self): """ Dump the resources of this resource manager as a resource definition. This is the default implementation for the case where the resource manager has no internal state that needs to be saved. If the resource manager does have internal state, this method needs to be overridden in the resource manager subclass. The returned resource definition of this implementation has the following format:: [ {...}, # resource definition ... ] Returns: list: Resource definitions of the resources of this resource manager. """ res_list = [] for res in self.list(): res_list.append(res.dump()) return res_list