From cd0efa4807dd13d7bc85258b309deb601cf7e9a4 Mon Sep 17 00:00:00 2001 From: Yongxue Hong Date: Fri, 12 Nov 2021 14:34:25 +0800 Subject: [PATCH 1/3] migration: Support multiple hosts migration Signed-off-by: Yongxue Hong --- avocado_vt/plugins/vt_bootstrap.py | 9 + avocado_vt/plugins/vt_cluster.py | 110 +++++ avocado_vt/test.py | 70 ++++ examples/tests/vt_node_test.cfg | 11 + examples/tests/vt_node_test.py | 14 + setup.py | 1 + virttest/bootstrap.py | 43 ++ virttest/data_dir.py | 2 +- virttest/vt_agent/__init__.py | 5 + virttest/vt_agent/__main__.py | 47 +++ virttest/vt_agent/api.py | 86 ++++ virttest/vt_agent/app/__init__.py | 0 virttest/vt_agent/app/args.py | 42 ++ virttest/vt_agent/app/cmd.py | 57 +++ virttest/vt_agent/core/__init__.py | 1 + virttest/vt_agent/core/data_dir.py | 85 ++++ virttest/vt_agent/core/logger.py | 42 ++ virttest/vt_agent/core/server.py | 103 +++++ virttest/vt_agent/core/service.py | 94 +++++ virttest/vt_agent/managers/__init__.py | 5 + virttest/vt_agent/managers/connect.py | 3 + virttest/vt_agent/managers/console.py | 3 + virttest/vt_agent/services/README | 1 + virttest/vt_agent/services/__init__.py | 0 .../vt_agent/services/unittest/__init__.py | 1 + virttest/vt_agent/services/unittest/cpu.py | 21 + virttest/vt_agent/services/unittest/hello.py | 9 + .../services/unittest/testcase/__init__.py | 1 + .../vt_agent/services/unittest/testcase/vm.py | 9 + virttest/vt_cluster/__init__.py | 205 ++++++++++ virttest/vt_cluster/logger.py | 142 +++++++ virttest/vt_cluster/node.py | 387 ++++++++++++++++++ virttest/vt_cluster/node_metadata.py | 66 +++ virttest/vt_cluster/proxy.py | 119 ++++++ virttest/vt_cluster/selector.py | 166 ++++++++ 35 files changed, 1959 insertions(+), 1 deletion(-) create mode 100644 avocado_vt/plugins/vt_cluster.py create mode 100644 examples/tests/vt_node_test.cfg create mode 100644 examples/tests/vt_node_test.py create mode 100644 virttest/vt_agent/__init__.py create mode 100644 virttest/vt_agent/__main__.py create mode 100644 virttest/vt_agent/api.py create mode 100644 virttest/vt_agent/app/__init__.py create mode 100644 virttest/vt_agent/app/args.py create mode 100644 virttest/vt_agent/app/cmd.py create mode 100644 virttest/vt_agent/core/__init__.py create mode 100644 virttest/vt_agent/core/data_dir.py create mode 100644 virttest/vt_agent/core/logger.py create mode 100644 virttest/vt_agent/core/server.py create mode 100644 virttest/vt_agent/core/service.py create mode 100644 virttest/vt_agent/managers/__init__.py create mode 100644 virttest/vt_agent/managers/connect.py create mode 100644 virttest/vt_agent/managers/console.py create mode 100644 virttest/vt_agent/services/README create mode 100644 virttest/vt_agent/services/__init__.py create mode 100644 virttest/vt_agent/services/unittest/__init__.py create mode 100644 virttest/vt_agent/services/unittest/cpu.py create mode 100644 virttest/vt_agent/services/unittest/hello.py create mode 100644 virttest/vt_agent/services/unittest/testcase/__init__.py create mode 100644 virttest/vt_agent/services/unittest/testcase/vm.py create mode 100644 virttest/vt_cluster/__init__.py create mode 100644 virttest/vt_cluster/logger.py create mode 100644 virttest/vt_cluster/node.py create mode 100644 virttest/vt_cluster/node_metadata.py create mode 100644 virttest/vt_cluster/proxy.py create mode 100644 virttest/vt_cluster/selector.py diff --git a/avocado_vt/plugins/vt_bootstrap.py b/avocado_vt/plugins/vt_bootstrap.py index b985382bef..c349f81dca 100644 --- a/avocado_vt/plugins/vt_bootstrap.py +++ b/avocado_vt/plugins/vt_bootstrap.py @@ -142,6 +142,15 @@ def configure(self, parser): "generating the host configuration entry." ), ) + parser.add_argument( + "--vt-cluster-config", + action="store", + metavar="CLUSTER_CONFIG", + help=( + "The cluster config json file to be used when " + "generating the cluster hosts configuration entry." + ), + ) def run(self, config): try: diff --git a/avocado_vt/plugins/vt_cluster.py b/avocado_vt/plugins/vt_cluster.py new file mode 100644 index 0000000000..399e82eb4b --- /dev/null +++ b/avocado_vt/plugins/vt_cluster.py @@ -0,0 +1,110 @@ +import logging +import os +import sys + +from avocado.core import exit_codes +from avocado.core.plugin_interfaces import JobPostTests as Post +from avocado.core.plugin_interfaces import JobPreTests as Pre +from avocado.utils.stacktrace import log_exc_info +from virttest.vt_cluster import cluster, node_metadata + + +class ClusterSetupError(Exception): + """ + Represents any error situation when attempting to create a cluster. + """ + + pass + + +class ClusterManagerSetupError(ClusterSetupError): + pass + + +class ClusterCleanupError(Exception): + pass + + +class ClusterManagerCleanupError(ClusterCleanupError): + pass + + +class VTCluster(Pre, Post): + + name = "vt-cluster" + description = "Avocado-VT Cluster Pre/Post" + + def __init__(self, **kwargs): + self._log = logging.getLogger("avocado.app") + + @staticmethod + def _pre_node_setup(): + try: + for node in cluster.get_all_nodes(): + node.start_agent_server() + node_metadata.load_metadata() + except Exception as err: + raise ClusterSetupError(err) + + @staticmethod + def _pre_mgr_setup(): + try: + # Pre-setup the cluster manager + # e.g: + # startup_resmgr() + # vt_imgr.startup() + pass + except Exception as err: + raise ClusterManagerSetupError(err) + + @staticmethod + def _post_mgr_cleanup(): + try: + # Post-cleanup the cluster manager + # e.g: + # teardown_resmgr() + # vt_imgr.teardown() + pass + except Exception as err: + raise ClusterManagerCleanupError(err) + + def _post_node_setup(self, job): + cluster_dir = os.path.join(job.logdir, "cluster") + for node in cluster.get_all_nodes(): + node_dir = os.path.join(cluster_dir, node.name) + os.makedirs(node_dir) + try: + node.upload_agent_log(node_dir) + except Exception as err: + self._log.warning(err) + finally: + try: + node.stop_agent_server() + except Exception as detail: + err = ClusterCleanupError(detail) + msg = ( + f"Failed to stop the agent " + f"server on node '{node.name}': {err}" + ) + self._log.warning(msg) + node_metadata.unload_metadata() + + def pre_tests(self, job): + if cluster.get_all_nodes(): + try: + self._pre_node_setup() + self._pre_mgr_setup() + except Exception as detail: + msg = "Failure trying to set Avocado-VT job env: %s" % detail + self._log.error(msg) + log_exc_info(sys.exc_info(), self._log.name) + sys.exit(exit_codes.AVOCADO_JOB_FAIL | job.exitcode) + + def post_tests(self, job): + if cluster.get_all_nodes(): + try: + self._post_mgr_cleanup() + except ClusterManagerCleanupError as err: + self._log.warning(err) + finally: + self._post_node_setup(job) diff --git a/avocado_vt/test.py b/avocado_vt/test.py index 71161f8f60..921140a468 100644 --- a/avocado_vt/test.py +++ b/avocado_vt/test.py @@ -36,6 +36,7 @@ version, ) from virttest._wrappers import load_source +from virttest.vt_cluster import cluster, logger, selector # avocado-vt no longer needs autotest for the majority of its functionality, # except by: @@ -115,6 +116,10 @@ def __init__(self, **kwargs): utils_logfile.set_log_file_dir(self.logdir) self.__status = None self.__exc_info = None + self._cluster_partition = None + self._logger_server = logger.LoggerServer( + cluster.logger_server_host, cluster.logger_server_port, self.log + ) @property def params(self): @@ -262,6 +267,10 @@ def _runTest(self): try: try: + self._init_partition() + self._setup_partition() + self._logger_server.start() + self._start_logger_client() try: # Pre-process try: @@ -321,6 +330,14 @@ def _runTest(self): or params.get("env_cleanup", "no") == "yes" ): env.destroy() # Force-clean as it can't be stored + self._stop_logger_client() + self._logger_server.stop() + self._clear_partition() + if ( + self._safe_env_save(env) + or params.get("env_cleanup", "no") == "yes" + ): + env.destroy() # Force-clean as it can't be stored except Exception as e: if params.get("abort_on_error") != "yes": @@ -345,3 +362,56 @@ def _runTest(self): raise exceptions.JobError("Abort requested (%s)" % e) return test_passed + + def _init_partition(self): + self._cluster_partition = cluster.create_partition() + + def _setup_partition(self): + for node in self.params.objects("nodes"): + node_params = self.params.object_params(node) + node_selectors = node_params.get("node_selectors") + _node = selector.select_node(cluster.free_nodes, node_selectors) + if not _node: + raise selector.SelectorError( + f'No available nodes for "{node}" with "{node_selectors}"' + ) + _node.tag = node + self._cluster_partition.add_node(_node) + + def _clear_partition(self): + cluster_dir = os.path.join(self.resultsdir, "cluster") + if self._cluster_partition.nodes: + for node in self._cluster_partition.nodes: + node_dir = os.path.join(cluster_dir, node.tag) + os.makedirs(node_dir) + # node.upload_service_log(node_dir) + node.upload_logs(node_dir) + cluster.clear_partition(self._cluster_partition) + self._cluster_partition = None + + def _start_logger_client(self): + if self._cluster_partition.nodes: + for node in self._cluster_partition.nodes: + try: + node.proxy.api.start_logger_client( + cluster.logger_server_host, cluster.logger_server_port + ) + except ModuleNotFoundError: + pass + + def _stop_logger_client(self): + if self._cluster_partition.nodes: + for node in self._cluster_partition.nodes: + try: + node.proxy.api.stop_logger_client() + except ModuleNotFoundError: + pass + + @property + def nodes(self): + return self._cluster_partition.nodes + + def get_node(self, node_tag): + for node in self._cluster_partition.nodes: + if node_tag == node.tag: + return node diff --git a/examples/tests/vt_node_test.cfg b/examples/tests/vt_node_test.cfg new file mode 100644 index 0000000000..d71c642e0f --- /dev/null +++ b/examples/tests/vt_node_test.cfg @@ -0,0 +1,11 @@ +- vt_node_test: + type = vt_node_test + start_vm = no + not_preprocess = yes + nodes = node1 node2 node3 + node_selectors_node1 = [{"key": "cpu_vendor_id", "operator": "eq", "values": "AuthenticAMD"}, + node_selectors_node1 += {"key": "hostname", "operator": "contains", "values": "redhat.com"}] + node_selectors_node2 = [{"key": "cpu_vendor_id", "operator": "==", "values": "AuthenticAMD"}, + node_selectors_node2 += {"key": "hostname", "operator": "contains", "values": "redhat.com"}] + node_selectors_node3 = [{"key": "cpu_vendor_id", "operator": "==", "values": "AuthenticAMD"}, + node_selectors_node3 += {"key": "hostname", "operator": "contains", "values": "redhat.com"}] diff --git a/examples/tests/vt_node_test.py b/examples/tests/vt_node_test.py new file mode 100644 index 0000000000..93a0edbc18 --- /dev/null +++ b/examples/tests/vt_node_test.py @@ -0,0 +1,14 @@ +""" +Simple vt node handling test. + +Please put the configuration file vt_node_test.cfg into $tests/cfg/ directory. + +""" + + +def run(test, params, env): + for node in test.nodes: + test.log.info("========Start test on %s========", node.name) + node.proxy.unittest.hello.say() + node.proxy.unittest.testcase.vm.boot_up() + test.log.info("========End test========") diff --git a/setup.py b/setup.py index eb21f7869f..7737a6a0af 100644 --- a/setup.py +++ b/setup.py @@ -82,6 +82,7 @@ def run(self): ], "avocado.plugins.result_events": [ "vt-joblock = avocado_vt.plugins.vt_joblock:VTJobLock", + "vt-cluster = avocado_vt.plugins.vt_cluster:VTCluster", ], "avocado.plugins.init": [ "vt-init = avocado_vt.plugins.vt_init:VtInit", diff --git a/virttest/bootstrap.py b/virttest/bootstrap.py index 959add0188..b192f0d233 100644 --- a/virttest/bootstrap.py +++ b/virttest/bootstrap.py @@ -1,4 +1,5 @@ import glob +import json import logging import os import re @@ -10,6 +11,8 @@ from avocado.utils import path as utils_path from avocado.utils import process +from virttest.vt_cluster import cluster, node + from . import arch, asset, cartesian_config, data_dir, defaults, utils_selinux from .compat import get_opt @@ -875,6 +878,34 @@ def verify_selinux(datadir, imagesdir, isosdir, tmpdir, interactive, selinux=Fal LOG.info("Corrected contexts on %d files/dirs", len(changes)) +def _load_cluster_config(cluster_config): + """Load the cluster config""" + with open(cluster_config, "r") as config: + return json.load(config) + + +def _register_hosts(hosts_configs): + """Register the configs of the hosts into the cluster.""" + if hosts_configs: + cluster.cleanup_env() + for host, host_params in hosts_configs.items(): + _node = node.Node(host_params, host) + _node.setup_agent_env() + cluster.register_node(_node.name, _node) + LOG.debug("Host %s registered", host) + + +def _config_master_server(master_config): + """Configure the master server.""" + if master_config: + logger_server_host = master_config.get("logger_server_host") + if logger_server_host: + cluster.assign_logger_server_host(logger_server_host) + logger_server_port = master_config.get("logger_server_port") + if logger_server_port: + cluster.assign_logger_server_port(logger_server_port) + + def bootstrap(options, interactive=False): """ Common virt test assistant module. @@ -1042,6 +1073,18 @@ def bootstrap(options, interactive=False): else: LOG.debug("Module %s loaded", module) + # Setup the cluster environment. + vt_cluster_config = get_opt(options, "vt_cluster_config") + if vt_cluster_config: + LOG.info("") + step += 1 + LOG.info( + "%d - Setting up the cluster environment via %s", step, vt_cluster_config + ) + cluster_config = _load_cluster_config(vt_cluster_config) + _register_hosts(cluster_config.get("hosts")) + _config_master_server(cluster_config.get("master")) + LOG.info("") LOG.info("VT-BOOTSTRAP FINISHED") LOG.debug("You may take a look at the following online docs for more info:") diff --git a/virttest/data_dir.py b/virttest/data_dir.py index 87aed63f2e..f21b689661 100755 --- a/virttest/data_dir.py +++ b/virttest/data_dir.py @@ -201,7 +201,7 @@ def get_tmp_dir(public=True): :param public: If public for all users' access """ persistent_dir = get_settings_value("vt.common", "tmp_dir", default="") - if persistent_dir != "": + if persistent_dir is not None: return persistent_dir tmp_dir = None # apparmor deny /tmp/* /var/tmp/* and cause failure across tests diff --git a/virttest/vt_agent/__init__.py b/virttest/vt_agent/__init__.py new file mode 100644 index 0000000000..6b80ee6c48 --- /dev/null +++ b/virttest/vt_agent/__init__.py @@ -0,0 +1,5 @@ +import sys + +from .core.data_dir import get_root_dir + +sys.path.append(get_root_dir()) diff --git a/virttest/vt_agent/__main__.py b/virttest/vt_agent/__main__.py new file mode 100644 index 0000000000..13bcfe4460 --- /dev/null +++ b/virttest/vt_agent/__main__.py @@ -0,0 +1,47 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +""" +Main entry point when called by 'python -m'. +""" + +import os +import shutil + +from .app.args import init_arguments +from .app.cmd import run +from .core.data_dir import get_data_dir, get_download_dir, get_log_dir +from .core.logger import init_logger + +args = init_arguments() +data_dir = get_data_dir() +log_dir = get_log_dir() +download_dir = get_download_dir() + +dirs = (data_dir, log_dir, download_dir) + +try: + for _dir in dirs: + shutil.rmtree(data_dir) + os.remove(args.pid_file) +except (FileNotFoundError, OSError): + pass + +for _dir in dirs: + os.makedirs(_dir) + +root_logger = init_logger() + +if __name__ == "__main__": + run(args.host, args.port, args.pid_file) diff --git a/virttest/vt_agent/api.py b/virttest/vt_agent/api.py new file mode 100644 index 0000000000..7bdc68386c --- /dev/null +++ b/virttest/vt_agent/api.py @@ -0,0 +1,86 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +import logging.handlers +import os +import signal + +from .core.data_dir import AGENT_LOG_FILENAME, SERVICE_LOG_FILENAME, get_log_dir +from .core.logger import LOG_FORMAT + +log_dir = get_log_dir() + +LOG = logging.getLogger("avocado.agent." + __name__) + + +def quit(): + """Quit the agent server.""" + pid = os.getpid() + LOG.info("Quit the server daemon(PID:%s).", pid) + os.kill(pid, signal.SIGKILL) + + +def is_alive(): + """Check whether the agent server is alive.""" + LOG.info("The server daemon is alive.") + return True + + +def start_logger_client(host, port): + """Start the agent logger client""" + try: + os.remove(SERVICE_LOG_FILENAME) + except FileNotFoundError: + pass + + logger = logging.getLogger("avocado.service") + logger.setLevel(logging.DEBUG) + file_handler = logging.FileHandler(filename=SERVICE_LOG_FILENAME) + file_handler.setFormatter(logging.Formatter(fmt=LOG_FORMAT)) + logger.addHandler(file_handler) + + virttest_logger = logging.getLogger("avocado.virttest") + virttest_logger.setLevel(logging.DEBUG) + file_handler = logging.FileHandler(filename=SERVICE_LOG_FILENAME) + file_handler.setFormatter(logging.Formatter(fmt=LOG_FORMAT)) + virttest_logger.addHandler(file_handler) + + LOG.info("Start the logger client.") + socket_handler = logging.handlers.SocketHandler(host, port) + socket_handler.setLevel(logging.DEBUG) + logger.addHandler(socket_handler) + virttest_logger.addHandler(socket_handler) + + +def stop_logger_client(): + """Stop the agent logger client.""" + LOG.info("Stop the logger client.") + for handler in logging.getLogger("avocado.service").handlers: + handler.close() + logging.getLogger("avocado.service").handlers.clear() + + +def get_agent_log_filename(): + """Get the filename of the agent log.""" + return AGENT_LOG_FILENAME + + +def get_service_log_filename(): + """Get the filename of the service log.""" + return SERVICE_LOG_FILENAME + + +def get_log_dir(): + """Get the filename of the logs.""" + return log_dir diff --git a/virttest/vt_agent/app/__init__.py b/virttest/vt_agent/app/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/virttest/vt_agent/app/args.py b/virttest/vt_agent/app/args.py new file mode 100644 index 0000000000..2108d0eaea --- /dev/null +++ b/virttest/vt_agent/app/args.py @@ -0,0 +1,42 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +import argparse + + +def init_arguments(): + """ + Initialize the arguments from the command line. + + :return: The populated namespace of arguments. + :rtype: argparse.Namespace + """ + parser = argparse.ArgumentParser() + parser.add_argument( + "--host", + action="store", + default="0.0.0.0", + nargs="?", + help='Specify alternate host [default: "0.0.0.0"]', + ) + parser.add_argument( + "--port", + action="store", + default=8000, + type=int, + nargs="?", + help="Specify alternate port [default: 8000]", + ) + parser.add_argument("--pid-file", required=True, help="Specify the file of pid.") + return parser.parse_args() diff --git a/virttest/vt_agent/app/cmd.py b/virttest/vt_agent/app/cmd.py new file mode 100644 index 0000000000..3e42a26128 --- /dev/null +++ b/virttest/vt_agent/app/cmd.py @@ -0,0 +1,57 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +import logging.handlers +import os +import sys + +from .. import core + +LOG = logging.getLogger("avocado.agent." + __name__) + + +def run(host, port, pid_file): + """ + Run the agent server. + + :param host: The host of agent server. + :type host: str + :param port: The port of agent server to be listened. + :type port: int + :param pid_file: The PID file. + :type pid_file: str + """ + try: + LOG.info("Serving VT agent on %s:%s", host, port) + pid = str(os.getpid()) + LOG.info("Running the agent daemon with PID %s", pid) + services = core.service.load_services() + server = core.server.RPCServer((host, port)) + server.register_services(services) + LOG.info("Waiting for connecting.") + + with open(pid_file, "w+") as f: + f.write(pid + "\n") + server.serve_forever() + except KeyboardInterrupt: + LOG.warn("Keyboard interrupt received, exiting.") + sys.exit(0) + except Exception as e: + LOG.error(e, exc_info=True) + sys.exit(-1) + finally: + try: + os.remove(pid_file) + except OSError: + pass diff --git a/virttest/vt_agent/core/__init__.py b/virttest/vt_agent/core/__init__.py new file mode 100644 index 0000000000..c22eaf64dd --- /dev/null +++ b/virttest/vt_agent/core/__init__.py @@ -0,0 +1 @@ +from . import data_dir, logger, server, service diff --git a/virttest/vt_agent/core/data_dir.py b/virttest/vt_agent/core/data_dir.py new file mode 100644 index 0000000000..e1e55c0297 --- /dev/null +++ b/virttest/vt_agent/core/data_dir.py @@ -0,0 +1,85 @@ +import glob +import logging +import os +import shutil +import stat +import tempfile + +BASE_DIR = os.path.dirname(os.path.dirname(__file__)) +DATA_DIR = os.path.join(BASE_DIR, "data") +LOG_DIR = os.path.join(DATA_DIR, "log") +DOWNLOAD_DIR = os.path.join(DATA_DIR, "download") +BACKING_MGR_ENV_FILENAME = os.path.join(DATA_DIR, "backing_mgr.env") + +AGENT_LOG_FILENAME = os.path.join(LOG_DIR, "agent.log") +SERVICE_LOG_FILENAME = os.path.join(LOG_DIR, "service.log") + + +LOG = logging.getLogger("avocado.agent" + __name__) + + +class MissingDirError(Exception): + pass + + +def get_root_dir(): + return BASE_DIR + + +def get_data_dir(): + return DATA_DIR + + +def get_log_dir(): + return LOG_DIR + + +def get_download_dir(): + return DOWNLOAD_DIR + + +def get_tmp_dir(public=True): + """ + Get the most appropriate tmp dir location. + + :param public: If public for all users' access + """ + tmp_dir = tempfile.mkdtemp(prefix="agent_tmp_", dir=get_data_dir()) + if public: + tmp_dir_st = os.stat(tmp_dir) + os.chmod( + tmp_dir, + tmp_dir_st.st_mode + | stat.S_IXUSR + | stat.S_IXGRP + | stat.S_IXOTH + | stat.S_IRGRP + | stat.S_IROTH, + ) + return tmp_dir + + +def get_service_module_dir(): + return os.path.join(get_root_dir(), "services") + + +def get_managers_module_dir(): + return os.path.join(get_root_dir(), "managers") + + +def clean_tmp_files(): + tmp_dir = get_tmp_dir() + if os.path.isdir(tmp_dir): + hidden_paths = glob.glob(os.path.join(tmp_dir, ".??*")) + paths = glob.glob(os.path.join(tmp_dir, "*")) + for path in paths + hidden_paths: + shutil.rmtree(path, ignore_errors=True) + + +if __name__ == "__main__": + print("base dir: " + get_root_dir()) + print("data dir: " + get_data_dir()) + print("log dir: " + get_log_dir()) + print("service module dir: " + get_service_module_dir()) + print("download dir: " + get_download_dir()) + print("tmp dir: " + get_tmp_dir()) diff --git a/virttest/vt_agent/core/logger.py b/virttest/vt_agent/core/logger.py new file mode 100644 index 0000000000..6f34292d43 --- /dev/null +++ b/virttest/vt_agent/core/logger.py @@ -0,0 +1,42 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +import logging.handlers + +from .data_dir import AGENT_LOG_FILENAME + +LOG_FORMAT = "%(asctime)s %(name)s %(levelname)-5.5s| %(message)s" + + +def init_logger(): + """ + Initialize the agent logger client. + + :return: The logger client obj. + :rtype: logging.Logger + """ + logger = logging.getLogger("avocado.agent") + logger.setLevel(logging.DEBUG) + + stream_handler = logging.StreamHandler() + stream_handler.setLevel(logging.DEBUG) + stream_handler.setFormatter(logging.Formatter(fmt=LOG_FORMAT)) + logger.addHandler(stream_handler) + + file_handler = logging.FileHandler(filename=AGENT_LOG_FILENAME) + file_handler.setLevel(logging.DEBUG) + file_handler.setFormatter(logging.Formatter(fmt=LOG_FORMAT)) + logger.addHandler(file_handler) + + return logger diff --git a/virttest/vt_agent/core/server.py b/virttest/vt_agent/core/server.py new file mode 100644 index 0000000000..cdccd5c2d1 --- /dev/null +++ b/virttest/vt_agent/core/server.py @@ -0,0 +1,103 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +import inspect +import logging +import sys +import traceback +from xmlrpc.client import Fault, dumps, loads +from xmlrpc.server import SimpleXMLRPCServer + +from .. import api + +LOG = logging.getLogger("avocado.agent." + __name__) + + +class _CustomsSimpleXMLRPCServer(SimpleXMLRPCServer): + def _marshaled_dispatch(self, data, dispatch_method=None, path=None): + try: + params, method = loads(data, use_builtin_types=self.use_builtin_types) + + # generate response + if dispatch_method is not None: + response = dispatch_method(method, params) + else: + response = self._dispatch(method, params) + # wrap response in a singleton tuple + response = (response,) + response = dumps( + response, + methodresponse=1, + allow_none=self.allow_none, + encoding=self.encoding, + ) + except Fault as fault: + response = dumps(fault, allow_none=self.allow_none, encoding=self.encoding) + except: + # report exception back to server + exc_type, exc_value, exc_tb = sys.exc_info() + + tb_info = traceback.format_exception(exc_type, exc_value, exc_tb.tb_next) + tb_info = "".join([_ for _ in tb_info]) + try: + mod = exc_type.__dict__.get("__module__", "") + if mod: + _exc_type = ".".join((mod, exc_type.__name__)) + _exc_value = exc_value.__dict__ + else: + _exc_type = exc_type.__name__ + _exc_value = str(exc_value) + response = dumps( + Fault((_exc_type, _exc_value), tb_info), + encoding=self.encoding, + allow_none=self.allow_none, + ) + logging.error(tb_info) + finally: + pass + + return response.encode(self.encoding, "xmlcharrefreplace") + + +class RPCServer(object): + def __init__(self, addr=()): + self._server = _CustomsSimpleXMLRPCServer( + addr, allow_none=True, use_builtin_types=False + ) + self._load_server_api() + + def _load_server_api(self): + for m in inspect.getmembers(api): + if inspect.isfunction(m[1]): + name = ".".join( + (".".join(api.__dict__["__name__"].split(".")[1:]), m[0]) + ) + self._server.register_function(m[1], name) + + def register_services(self, services): + service_list = [] + for name, service in services: + service_list.append(name) + members = [_ for _ in inspect.getmembers(service)] + for member in members: + member_name = member[0] + member_obj = member[1] + if inspect.isfunction(member_obj): + function_name = ".".join((name, member_name)) + self._server.register_function(member_obj, function_name) + services = ", ".join([_ for _ in service_list]) + LOG.info("Services registered: %s" % services) + + def serve_forever(self): + self._server.serve_forever() diff --git a/virttest/vt_agent/core/service.py b/virttest/vt_agent/core/service.py new file mode 100644 index 0000000000..f54cb44e65 --- /dev/null +++ b/virttest/vt_agent/core/service.py @@ -0,0 +1,94 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +import importlib +import importlib.util +import logging +import os +import sys + +from .data_dir import get_managers_module_dir, get_service_module_dir + + +class ServiceError(Exception): + pass + + +LOG = logging.getLogger("avocado.agent." + __name__) + + +class _Services(object): + """The representation of the services.""" + + def __init__(self): + self._services = {} + + def register_service(self, name, service): + self._services[name] = service + + def get_service(self, name): + try: + return self._services[name] + except KeyError: + raise ServiceError("No support service '%s'." % name) + + def __iter__(self): + for name, service in self._services.items(): + yield name, service + + +def _import_services(services_dir): + """Import all the services.""" + service_sources = [] + for root, dirs, files in os.walk(services_dir): + for file in files: + if file.endswith(".py") and file != "__init__.py": + service_sources.append(os.path.join(root, file)) + + modules = [] + for source in service_sources: + module_name = source[:-3] + spec = importlib.util.spec_from_file_location(module_name, source) + if spec is None: + raise ImportError(f"Can not find spec for {module_name} at {source}") + module = importlib.util.module_from_spec(spec) + sys.modules[spec.name] = module + spec.loader.exec_module(module) + modules.append(module) + return modules + + +def load_services(): + """Load all the services.""" + services = _Services() + + # Import the managers module firstly since we need its instances + # from __init__ and import it as new module "managers" on the worker node. + managers_package_path = get_managers_module_dir() + init_file_path = os.path.join(managers_package_path, "__init__.py") + spec = importlib.util.spec_from_file_location("managers", init_file_path) + if spec is None: + raise ImportError(f"Can not find spec for managers at {init_file_path}") + module = importlib.util.module_from_spec(spec) + sys.modules[spec.name] = module + spec.loader.exec_module(module) + + services_dir = get_service_module_dir() + modules = _import_services(services_dir) + + for service in modules: + name = service.__dict__["__name__"] + name = ".".join(name.split(services_dir)[-1].split("/")[1:]) + services.register_service(name, service) + return services diff --git a/virttest/vt_agent/managers/__init__.py b/virttest/vt_agent/managers/__init__.py new file mode 100644 index 0000000000..4e973d4c42 --- /dev/null +++ b/virttest/vt_agent/managers/__init__.py @@ -0,0 +1,5 @@ +from .connect import ConnectManager +from .console import ConsoleManager + +connect_mgr = ConnectManager() +console_mgr = ConsoleManager() diff --git a/virttest/vt_agent/managers/connect.py b/virttest/vt_agent/managers/connect.py new file mode 100644 index 0000000000..4f2347cd82 --- /dev/null +++ b/virttest/vt_agent/managers/connect.py @@ -0,0 +1,3 @@ +class ConnectManager(object): + def __init__(self): + self._connects = {} diff --git a/virttest/vt_agent/managers/console.py b/virttest/vt_agent/managers/console.py new file mode 100644 index 0000000000..fa868717e7 --- /dev/null +++ b/virttest/vt_agent/managers/console.py @@ -0,0 +1,3 @@ +class ConsoleManager(object): + def __init__(self): + self._consoles = {} diff --git a/virttest/vt_agent/services/README b/virttest/vt_agent/services/README new file mode 100644 index 0000000000..88c7b85681 --- /dev/null +++ b/virttest/vt_agent/services/README @@ -0,0 +1 @@ +The guideline of structure services: TBD diff --git a/virttest/vt_agent/services/__init__.py b/virttest/vt_agent/services/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/virttest/vt_agent/services/unittest/__init__.py b/virttest/vt_agent/services/unittest/__init__.py new file mode 100644 index 0000000000..d1eabd0bce --- /dev/null +++ b/virttest/vt_agent/services/unittest/__init__.py @@ -0,0 +1 @@ +from . import cpu, hello, testcase diff --git a/virttest/vt_agent/services/unittest/cpu.py b/virttest/vt_agent/services/unittest/cpu.py new file mode 100644 index 0000000000..a3fadd9ada --- /dev/null +++ b/virttest/vt_agent/services/unittest/cpu.py @@ -0,0 +1,21 @@ +import logging +import socket + +from avocado.utils import process + +LOG = logging.getLogger("avocado.service." + __name__) + + +def __get_cpu_info(): + cmd = "lscpu | tee" + output = process.run(cmd, shell=True, ignore_status=True).stdout_text.splitlines() + cpu_info = dict(map(lambda x: [i.strip() for i in x.split(":", 1)], output)) + return cpu_info + + +def get_vendor_id(): + hostname = socket.gethostname() + info = __get_cpu_info() + vendor_id = info.get("Vendor ID") + LOG.info(f"The vendor id is {vendor_id} on the {hostname}") + return vendor_id diff --git a/virttest/vt_agent/services/unittest/hello.py b/virttest/vt_agent/services/unittest/hello.py new file mode 100644 index 0000000000..95c6293ef1 --- /dev/null +++ b/virttest/vt_agent/services/unittest/hello.py @@ -0,0 +1,9 @@ +import logging +import socket + +LOG = logging.getLogger("avocado.service." + __name__) + + +def say(): + hostname = socket.gethostname() + LOG.info(f'Say "Hello", from the {hostname}') diff --git a/virttest/vt_agent/services/unittest/testcase/__init__.py b/virttest/vt_agent/services/unittest/testcase/__init__.py new file mode 100644 index 0000000000..52f1841610 --- /dev/null +++ b/virttest/vt_agent/services/unittest/testcase/__init__.py @@ -0,0 +1 @@ +from . import vm diff --git a/virttest/vt_agent/services/unittest/testcase/vm.py b/virttest/vt_agent/services/unittest/testcase/vm.py new file mode 100644 index 0000000000..198a5c1b84 --- /dev/null +++ b/virttest/vt_agent/services/unittest/testcase/vm.py @@ -0,0 +1,9 @@ +import logging +import socket + +LOG = logging.getLogger("avocado.service." + __name__) + + +def boot_up(): + hostname = socket.gethostname() + LOG.info(f"Boot up a guest on the {hostname}") diff --git a/virttest/vt_cluster/__init__.py b/virttest/vt_cluster/__init__.py new file mode 100644 index 0000000000..2e67c2870a --- /dev/null +++ b/virttest/vt_cluster/__init__.py @@ -0,0 +1,205 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +""" +Module for providing the interface of cluster for virt test. +""" + +import os +import pickle + +from virttest import data_dir + + +class ClusterError(Exception): + """The generic cluster error.""" + + pass + + +class _Partition(object): + """The representation of the partition of the cluster.""" + + def __init__(self): + self._nodes = set() + + def add_node(self, node): + """ + Add the node into the partition. + + :param node: The node to be added. + :type node: vt_cluster.node.Node + """ + self._nodes.add(node) + + def del_node(self, node): + """ + delete the node from the partition. + + :param node: The node to be deleted. + :type node: vt_cluster.node.Node + """ + self._nodes.remove(node) + + @property + def nodes(self): + return self._nodes + + +class _Cluster(object): + """The representation of the cluster.""" + + def __init__(self): + self._filename = os.path.join(data_dir.get_base_backend_dir(), "cluster_env") + self._empty_data = { + "logger_server_host": "", + "logger_server_port": 0, + "partitions": [], + "nodes": {}, + } + if os.path.isfile(self._filename): + self._data = self._load() + else: + self._data = self._empty_data + + def _save(self): + with open(self._filename, "wb") as f: + pickle.dump(self._data, f, protocol=0) + + def _load(self): + with open(self._filename, "rb") as f: + return pickle.load(f) + + def cleanup_env(self): + self._data = self._empty_data + if os.path.isfile(self._filename): + os.unlink(self._filename) + + def register_node(self, name, node): + """ + Register the node into the cluster. + + :param name: the node name + :type name: str + :param node: the node object + :type node: vt_node.Node + """ + self._data["nodes"][name] = node + self._save() + + def unregister_node(self, name): + """ + Unregister the node from the cluster. + + :param name: the node name + """ + del self._data["nodes"][name] + self._save() + + def get_node_by_tag(self, name): + """ + Get the node from the cluster by the node tag. + + :param name: the node name + :type name: str + :return: the node object + :rtype: vt_node.Node + """ + for node in self.get_all_nodes(): + if node.tag == name: + return node + + def get_node(self, name): + """ + Get the node from the cluster. + + :param name: the node name + :type name: str + :return: the node object + :rtype: vt_node.Node + """ + return self._data["nodes"].get(name) + + def get_all_nodes(self): + """ + Get the all nodes. + + :return: the list of all nodes + :rtype: list + """ + return [_ for _ in self._data["nodes"].values()] + + def assign_logger_server_host(self, host="localhost"): + """ + Assign the host for the master logger server. + + :param host: The host of server. + :type host: str + """ + self._data["logger_server_host"] = host + self._save() + + @property + def logger_server_host(self): + return self._data["logger_server_host"] + + def assign_logger_server_port(self, port=9999): + """ + Assign the port for the master logger server. + + :param port: The port of server. + :type port: int + """ + self._data["logger_server_port"] = port + self._save() + + @property + def logger_server_port(self): + return self._data["logger_server_port"] + + @property + def metadata_file(self): + return os.path.join(data_dir.get_base_backend_dir(), "cluster_metadata.json") + + def create_partition(self): + """ + Create a partition for the cluster. + + :return: The partition obj + :rtype: _Partition + """ + partition = _Partition() + self._data["partitions"].append(partition) + self._save() + return partition + + def clear_partition(self, partition): + """ + Clear a partition from the cluster. + + :param partition: The partition to be cleared + :type partition: _Partition + """ + self._data["partitions"].remove(partition) + self._save() + + @property + def free_nodes(self): + nodes = set(self.get_all_nodes()[:]) + for partition in self._data["partitions"]: + nodes = nodes - partition.nodes + return list(nodes) + + +cluster = _Cluster() diff --git a/virttest/vt_cluster/logger.py b/virttest/vt_cluster/logger.py new file mode 100644 index 0000000000..e8de12777e --- /dev/null +++ b/virttest/vt_cluster/logger.py @@ -0,0 +1,142 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +import logging +import pickle +import select +import socketserver +import struct +import threading + +from . import ClusterError, cluster + +_logger = logging.getLogger("") + + +class LoggerServerError(ClusterError): + """Generic LoggerServerError.""" + + pass + + +class _LoggerStreamHandler(socketserver.StreamRequestHandler): + """ + Handler for a streaming logging request. + + This basically logs the record using whatever logging policy is + configured locally. + """ + + def __init__(self, request, client_address, server): + super(_LoggerStreamHandler, self).__init__(request, client_address, server) + self.server = server + + def handle(self): + """ + Handle multiple requests - each expected to be a 4-byte length, + followed by the LogRecord in pickle format. Logs the record + according to whatever policy is configured locally. + """ + while True: + chunk = self.connection.recv(4) + if len(chunk) < 4: + break + slen = struct.unpack(">L", chunk)[0] + chunk = self.connection.recv(slen) + while len(chunk) < slen: + chunk = chunk + self.connection.recv(slen - len(chunk)) + obj = self.unpickle(chunk) + record = logging.makeLogRecord(obj) + self.handle_logger(record) + + def unpickle(self, data): + _data = pickle.loads(data) + self.server.last_output_lines = _data.get("msg") + return _data + + def handle_logger(self, record): + client = "Unknown" + for node in cluster.get_all_nodes(): + if self.client_address[0] == node.address: + client = node.tag + break + format_str = "{client}({address}) {asctime} {module} {levelname} | {msg}" + _logger.info( + format_str.format( + asctime=record.asctime, + module=record.name, + levelname=record.levelname, + msg=record.msg, + client=client, + address=self.client_address[0], + ) + ) + + +class _Server(socketserver.ThreadingTCPServer): + allow_reuse_address = True + + def __init__(self, host, port, handler=_LoggerStreamHandler): + socketserver.ThreadingTCPServer.__init__(self, (host, port), handler) + self.abort = False + self.timeout = 1 + self.last_output_lines = "" + + def run_server_forever(self): + abort = False + while not abort: + rd, wr, ex = select.select([self.socket.fileno()], [], [], self.timeout) + if rd: + self.handle_request() + abort = self.abort + + +class LoggerServer(object): + """ + Handler for receiving the log content from the agent node. + + """ + + def __init__(self, host, port, logger=None): + self._host = host + self._port = port + self._server = _Server(host, port) + self._thread = None + global _logger + _logger = logger + _logger.setLevel(logging.DEBUG) + + @property + def host(self): + return self._host + + @property + def port(self): + return self._port + + def start(self): + """Start the logger server""" + self._thread = threading.Thread( + target=self._server.run_server_forever, name="logger_server", args=() + ) + self._thread.daemon = True + self._thread.start() + + def stop(self): + """Stop the logger server""" + self._server.abort = True + + @property + def last_output_lines(self): + return self._server.last_output_lines diff --git a/virttest/vt_cluster/node.py b/virttest/vt_cluster/node.py new file mode 100644 index 0000000000..126822168a --- /dev/null +++ b/virttest/vt_cluster/node.py @@ -0,0 +1,387 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +""" +Module for providing the interface of node for virt test. +""" + +import inspect +import logging +import os + +import avocado +from aexpect import remote +from aexpect.client import RemoteSession + +import virttest +from virttest import utils_misc, vt_agent + +from . import ClusterError, proxy + +LOG = logging.getLogger("avocado." + __name__) +AGENT_MOD = vt_agent.__name__.split(".")[-1] +AGENT_MOD_PATH = os.path.dirname(vt_agent.__file__) + + +class NodeError(ClusterError): + """Generic Node Error.""" + + pass + + +def _remote_login(client, host, port, username, password, prompt, auto_close, timeout): + cmd = ( + "ssh -o UserKnownHostsFile=/dev/null " + "-o StrictHostKeyChecking=no -p %s" % port + ) + cmd += " -o PreferredAuthentications=password" + cmd += " %s@%s" % (username, host) + + session = RemoteSession( + cmd, + linesep="\n", + prompt=prompt, + status_test_command="echo $?", + client=client, + host=host, + port=port, + username=username, + password=password, + auto_close=auto_close, + ) + try: + remote.handle_prompts(session, username, password, prompt, timeout) + except Exception as e: + session.close() + raise NodeError(e) + return session + + +class Node(object): + """ + Node representation. + + """ + + def __init__(self, params, name): + self._params = params + self._name = name + self._host = self.address + _uri = "http://%s:%s/" % (self._host, self.proxy_port) + self._uri = None if self.master_node else _uri + self._agent_server_daemon_pid = None + self._is_remote_node = not self.master_node + self._server_daemon_pid_file = None + self._logger_server = None + self._session_daemon = None + self.tag = None + + def __repr__(self): + return f"" + + @property + def name(self): + return self._name + + @property + def hostname(self): + return self._params.get("hostname") + + @property + def address(self): + return self._params.get("address") + + @property + def password(self): + return self._params.get("password") + + @property + def username(self): + return self._params.get("username", "root") + + @property + def proxy_port(self): + return self._params.get("proxy_port", "8000") + + @property + def shell_port(self): + return self._params.get("shell_port", "22") + + @property + def shell_prompt(self): + return self._params.get("shell_prompt", "^\[.*\][\#\$]\s*$") + + @property + def proxy(self): + return proxy.get_server_proxy(self._uri) + + @property + def master_node(self): + return self._params.get("master_node", "no") == "yes" + + @property + def agent_server_name(self): + if self._is_remote_node: + return "server-%s" % self.name + + @property + def agent_server_dir(self): + if self._is_remote_node: + return "/var/run/agent-server/%s" % self.agent_server_name + + @property + def agent_server_daemon_pid(self): + if self._is_remote_node: + return self._agent_server_daemon_pid + + @property + def logger_server(self): + if self._is_remote_node: + return self._logger_server + + def __eq__(self, other): + if not isinstance(other, Node): + return False + return self.address == other.address + + def __ne__(self, other): + return not self.__eq__(other) + + def __hash__(self): + return hash(self._name) + + def _scp_from_remote(self, source, dest, timeout=600): + remote.scp_to_remote( + self._host, + self.shell_port, + self.username, + self.password, + source, + dest, + timeout=timeout, + ) + + def _setup_agent_server_components(self): + self._scp_from_remote(AGENT_MOD_PATH, self.agent_server_dir) + + def _setup_agent_server_pkgs(self): + dest_path = os.path.join(self.agent_server_dir, AGENT_MOD) + for pkg in (avocado, virttest): + pkg_path = os.path.dirname(inspect.getfile(pkg)) + self._scp_from_remote(pkg_path, dest_path) + + session = self.create_session() + # FIXME: "pkg_resources.DistributionNotFound" + target_file = os.path.join(dest_path, "avocado", "__init__.py") + session.cmd("sed -i 's/initialize_plugins()//g' %s" % target_file) + + # FIXME: fix TypeError: expected str, bytes or os.PathLike object, not tuple + target_file = os.path.join(dest_path, "virttest", "data_dir.py") + session.cmd( + "sed -i 's/persistent_dir != " + ":/persistent_dir is not None:/g' %s" % target_file + ) + + # FIXME: workaround to install aexpect module + target_file = os.path.join(dest_path, "aexpect") + session.cmd_output("rm -rf %s" % target_file, timeout=300) + cmd = ( + "git clone https://github.com/avocado-framework/aexpect.git %s" + % target_file + ) + session.cmd(cmd, timeout=300) + session.cmd("cd %s && python setup.py develop" % target_file) + session.close() + + def setup_agent_env(self): + """Setup the agent environment of node""" + if self._is_remote_node: + self.cleanup_agent_env() + session = self.create_session() + session.cmd("mkdir -p %s" % self.agent_server_dir) + session.close() + self._setup_agent_server_components() + self._setup_agent_server_pkgs() + + def cleanup_agent_env(self): + """Cleanup the agent environment of node""" + if self._is_remote_node: + agent_session = self.create_session() + if self.agent_server_dir: + agent_session.cmd_output("rm -rf %s" % self.agent_server_dir) + agent_session.close() + + def _start_server_daemon(self, name, host, port, pidfile): + LOG.info("Starting the server daemon on %s", self.name) + self._server_daemon_pid_file = pidfile + self._session_daemon = self.create_session(auto_close=False) + pythonpath = os.path.join(self.agent_server_dir, AGENT_MOD) + self._session_daemon.cmd("export PYTHONPATH=%s" % pythonpath) + self._daemon_cmd = "cd %s &&" % self.agent_server_dir + self._daemon_cmd += " python3 -m %s" % name + self._daemon_cmd += " --host=%s" % host + self._daemon_cmd += " --port=%s" % port + self._daemon_cmd += " --pid-file=%s" % pidfile + LOG.info("Sending command line: %s", self._daemon_cmd) + self._session_daemon.sendline(self._daemon_cmd) + + end_str = "Waiting for connecting." + timeout = 3 + if not utils_misc.wait_for( + lambda: ( + end_str in self._session_daemon.get_output() and self.is_server_alive() + ), + timeout, + ): + err_info = self._session_daemon.get_output() + LOG.error( + "Failed to start the server daemon on %s.\n" "The output:\n%s", + self.name, + err_info, + ) + return False + LOG.info("Start the server daemon successfully on %s.", self.name) + return True + + def start_agent_server(self): + """Start the agent server on the node""" + if self._is_remote_node: + pidfile = os.path.join( + self.agent_server_dir, "agent_server_%s.pid" % self.name + ) + if not self._start_server_daemon( + name=AGENT_MOD, host=self.address, port=self.proxy_port, pidfile=pidfile + ): + raise NodeError("Failed to start agent node daemon on %s" % self.name) + + def stop_agent_server(self): + """Stop the agent server on the node""" + if self._is_remote_node: + if self.is_server_alive(): + try: + self.proxy.api.quit() + except Exception: + pass + + if self._session_daemon: + try: + self._session_daemon.close() + except Exception: + pass + + def upload_agent_log(self, target_path): + """ + Upload the agent server log to the master node. + + :param target_path: The path of target. + :type target_path: str + """ + if self._is_remote_node: + remote_path = self.proxy.api.get_agent_log_filename() + remote.scp_from_remote( + self._host, + self.shell_port, + self.username, + self.password, + remote_path=remote_path, + local_path=target_path, + ) + + def upload_service_log(self, target_path): + """ + Upload the agent service log to the master node. + + :param target_path: The path of target. + :type target_path: str + """ + if self._is_remote_node: + remote_path = self.proxy.api.get_service_log_filename() + remote.scp_from_remote( + self._host, + self.shell_port, + self.username, + self.password, + remote_path=remote_path, + local_path=target_path, + ) + + def upload_logs(self, target_path): + """ + Upload the agent service log to the master node. + + :param target_path: The path of target. + :type target_path: str + """ + if self._is_remote_node: + remote_path = os.path.join(self.proxy.api.get_log_dir(), "*") + remote.scp_from_remote( + self._host, + self.shell_port, + self.username, + self.password, + remote_path=remote_path, + local_path=target_path, + ) + + def create_session(self, auto_close=True, timeout=300): + """Create a session of the node.""" + session = _remote_login( + "ssh", + self._host, + self.shell_port, + self.username, + self.password, + self.shell_prompt, + auto_close, + timeout, + ) + return session + + def get_server_pid(self): + """ + Get the PID of the server. + + :return: The PID of the server. + :type: str + """ + if self._server_daemon_pid_file: + _session = self.create_session() + cmd_open = "cat %s" % self._server_daemon_pid_file + try: + pid = _session.cmd_output(cmd_open).strip() + if pid: + self._agent_server_daemon_pid = pid + return pid + except Exception as e: + raise NodeError(e) + finally: + _session.close() + return None + + def is_server_alive(self): + """ + Check whether the server is alive. + + :return: True if the server is alive otherwise False. + :rtype: bool + """ + if not self.get_server_pid(): + return False + + try: + if not self.proxy.api.is_alive(): + return False + except Exception as e: + raise NodeError(e) + return True diff --git a/virttest/vt_cluster/node_metadata.py b/virttest/vt_cluster/node_metadata.py new file mode 100644 index 0000000000..3a17f9ab6e --- /dev/null +++ b/virttest/vt_cluster/node_metadata.py @@ -0,0 +1,66 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +""" +Module for providing the interface of cluster for virt test. +""" + +import json +import logging +import os + +from . import cluster + +LOG = logging.getLogger("avocado." + __name__) + + +def dump_metadata_file(nodes_metadata): + """Dump the metadata into the file.""" + with open(cluster.metadata_file, "w") as metadata_file: + json.dump(nodes_metadata, metadata_file) + + +def load_metadata_file(): + """Load the metadata from the file.""" + try: + with open(cluster.metadata_file, "r") as metadata_file: + return json.load(metadata_file) + except Exception: + return {} + + +def load_metadata(): + """Load the metadata of the nodes.""" + if os.path.exists(cluster.metadata_file): + os.remove(cluster.metadata_file) + + _meta = {} + for node in cluster.get_all_nodes(): + LOG.debug(f"{node}: Loading the node metadata") + _meta[node.name] = {} + _meta[node.name]["hostname"] = node.hostname + _meta[node.name]["address"] = node.address + + # just an example for getting the metadata + _meta[node.name]["cpu_vendor_id"] = node.proxy.unittest.cpu.get_vendor_id() + + dump_metadata_file(_meta) + + +def unload_metadata(): + """Unload the metadata of the nodes""" + try: + os.remove(cluster.metadata_file) + except OSError: + pass diff --git a/virttest/vt_cluster/proxy.py b/virttest/vt_cluster/proxy.py new file mode 100644 index 0000000000..3d324eb155 --- /dev/null +++ b/virttest/vt_cluster/proxy.py @@ -0,0 +1,119 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +""" +This module provides VT Proxy interfaces. +""" + +import importlib +import importlib.util +import logging +import os +import sys +from xmlrpc import client + +from virttest import vt_agent +from virttest.vt_agent import services + +from . import ClusterError + +LOG = logging.getLogger("avocado." + __name__) + + +class ServerProxyError(ClusterError): + """Generic Server Proxy Error.""" + + def __init__(self, code, message): + self.code = code + self.message = message + + +class _ClientMethod: + def __init__(self, send, name): + self.__send = send + self.__name = name + + def __getattr__(self, name): + return _ClientMethod(self.__send, "%s.%s" % (self.__name, name)) + + def __call__(self, *args): + root_mod = None + exc_type = None + try: + return self.__send(self.__name, args) + except client.Fault as e: + if "." in e.faultCode[0]: + root_mod = ".".join(e.faultCode[0].split(".")[:-1]) + exc_type = e.faultCode[0].split(".")[-1] + kargs = e.faultCode[1] + root_mod = importlib.import_module(root_mod) + try: + if isinstance(kargs, dict): + # TODO: Can not ensure initialize the any Exception here + raise getattr(root_mod, exc_type)(**kargs) + elif isinstance(kargs, str): + raise eval(e.faultCode[0])(kargs) + except Exception: + raise ServerProxyError(e.faultCode, e.faultString) + + +class _ClientProxy(client.ServerProxy): + def __init__(self, uri): + super(_ClientProxy, self).__init__(uri, allow_none=True, use_builtin_types=True) + + def __getattr__(self, name): + return _ClientMethod(self._ServerProxy__request, name) + + +class _LocalProxy(object): + def __init__(self): + # FIXME: This is to compatibility with the remote node and local node + agent_module_name = vt_agent.__name__ + module_name = agent_module_name.split(".")[-1] + if module_name not in sys.modules: + agent_module = importlib.import_module(agent_module_name) + sys.modules[module_name] = agent_module + + if "managers" not in sys.modules: + managers_package_path = vt_agent.core.data_dir.get_managers_module_dir() + init_file_path = os.path.join(managers_package_path, "__init__.py") + spec = importlib.util.spec_from_file_location("managers", init_file_path) + if spec is None: + raise ImportError(f"Can not find spec for managers at {init_file_path}") + + module = importlib.util.module_from_spec(spec) + sys.modules[spec.name] = module + spec.loader.exec_module(module) + + def __getattr__(self, name): + module_name = ".".join((services.__name__, name)) + if module_name in sys.modules: + return sys.modules[module_name] + + module = importlib.import_module(module_name) + sys.modules[module_name] = module + return module + + +def get_server_proxy(uri=None): + """ + Get the server proxy. + + :param uri: The URI of the server proxy. + e.g: + :type uri: str + :return: The proxy obj. + :rtype: _ClientProxy or _LocalProxy + """ + return _ClientProxy(uri) if uri else _LocalProxy() diff --git a/virttest/vt_cluster/selector.py b/virttest/vt_cluster/selector.py new file mode 100644 index 0000000000..0f2d404d23 --- /dev/null +++ b/virttest/vt_cluster/selector.py @@ -0,0 +1,166 @@ +# This program is free software; you can redistribute it and/or modify +# it under the terms of the GNU General Public License as published by +# the Free Software Foundation; either version 2 of the License, or +# (at your option) any later version. +# +# This program is distributed in the hope that it will be useful, +# but WITHOUT ANY WARRANTY; without even the implied warranty of +# MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. +# +# See LICENSE for more details. +# +# Copyright: Red Hat Inc. 2022 +# Authors: Yongxue Hong + +""" +Module for providing the interface of cluster for virt test. +""" + +import ast +import logging +import operator + +from . import ClusterError, cluster, node_metadata + +LOG = logging.getLogger("avocado." + __name__) + + +class SelectorError(ClusterError): + """Generic Selector Error.""" + + pass + + +class OperatorError(ClusterError): + """Generic Operator Error.""" + + pass + + +class _MatchExpression(object): + def __init__(self, key, op, values): + self._key = key + self._operator = op + self._values = values + + def __str__(self): + return " ".join((self.key, self.operator, self.values)) + + @property + def key(self): + return self._key + + @property + def operator(self): + return self._operator + + @property + def values(self): + return self._values + + +class _Operator(object): + @classmethod + def operate(cls, name, left, right=None): + operators_mapping = { + "<": cls._lt, + "lt": cls._lt, + ">": cls._gt, + "gt": cls._gt, + "==": cls._eq, + "eq": cls._eq, + "contains": cls._contains, + "not contains": cls._not_contains, + } + try: + if right: + return operators_mapping[name](left, right) + return operators_mapping[name](left) + except KeyError: + raise OperatorError("No support operator '%s'" % name) + + @staticmethod + def _lt(left, right): + return operator.lt(left, right) + + @staticmethod + def _gt(left, right): + return operator.gt(left, right) + + @staticmethod + def _eq(left, right): + return operator.eq(left, right) + + @staticmethod + def _contains(left, right): + return operator.contains(left, right) + + @staticmethod + def _not_contains(left, right): + return not operator.contains(left, right) + + +class _Selector(object): + """ + Handler for selecting the corresponding node from the cluster + according to the node selectors. + Node selector is the simplest recommended form of node selection constraint. + You can add the node selector field to your node specification you want the + target node to have. + + """ + + def __init__(self, node_selectors): + self._node_selectors = ast.literal_eval(node_selectors) + self._match_expressions = [] + for node_selector in self._node_selectors: + self._match_expressions.append( + _MatchExpression( + node_selector.get("key"), + node_selector.get("operator"), + node_selector.get("values"), + ) + ) + + self._metadata = node_metadata.load_metadata_file() + + def match_node(self, free_nodes): + """ + Match the corresponding node with the node metadata and node selectors. + + :return: The node obj + :rtype: vt_cluster.node.Node + """ + if free_nodes is None: + return None + for node_name, meta in self._metadata.items(): + node = cluster.get_node(node_name) + if node not in free_nodes: + continue + for match_expression in self._match_expressions: + key = match_expression.key + op = match_expression.operator + values = match_expression.values + if key not in meta: + raise SelectorError("No support metadata '%s'" % key) + if not _Operator.operate(op, meta[key], values): + break + else: + return node + return None + + +def select_node(candidates, selectors=None): + """ + Select the node according to the node selectors. + + :param candidates: The list of candidates for selecting. + :type candidates: list + :param selectors: The selectors of node. + :type selectors: str + :rtype: vt_cluster.node.Node + """ + if selectors: + selector = _Selector(selectors) + return selector.match_node(candidates) + return candidates.pop() if candidates else None From 3f666d8c98bae63761834f671e5a52345d33e71a Mon Sep 17 00:00:00 2001 From: Zhenchao Liu Date: Fri, 8 Mar 2024 15:53:07 +0800 Subject: [PATCH 2/3] Add storage and image management support Added pool_selectors and image_pool_name Signed-off-by: Zhenchao Liu --- avocado_vt/plugins/vt_cluster.py | 14 +- avocado_vt/test.py | 15 + virttest/bootstrap.py | 6 + virttest/env_process.py | 103 +++- virttest/vt_agent/managers/__init__.py | 4 + virttest/vt_agent/managers/image.py | 26 + virttest/vt_agent/managers/images/__init__.py | 16 + .../vt_agent/managers/images/qemu/__init__.py | 1 + .../images/qemu/qemu_image_handlers.py | 495 ++++++++++++++++++ .../vt_agent/managers/resource_backing.py | 120 +++++ .../managers/resource_backings/__init__.py | 29 + .../managers/resource_backings/backing.py | 63 +++ .../resource_backings/cvm/__init__.py | 27 + .../resource_backings/cvm/_sev_resmgr.py | 98 ++++ .../resource_backings/pool_connection.py | 32 ++ .../resource_backings/storage/__init__.py | 4 + .../resource_backings/storage/dir/__init__.py | 2 + .../storage/dir/dir_backing.py | 76 +++ .../storage/dir/dir_pool_connection.py | 33 ++ .../resource_backings/storage/nfs/__init__.py | 2 + .../storage/nfs/nfs_backing.py | 75 +++ .../storage/nfs/nfs_pool_connection.py | 59 +++ virttest/vt_agent/services/image.py | 15 + virttest/vt_agent/services/resource.py | 115 ++++ virttest/vt_cluster/__init__.py | 23 + virttest/vt_cluster/selector.py | 72 +++ virttest/vt_imgr/__init__.py | 1 + virttest/vt_imgr/images/__init__.py | 12 + virttest/vt_imgr/images/image.py | 95 ++++ virttest/vt_imgr/images/qemu/__init__.py | 1 + virttest/vt_imgr/images/qemu/qemu_image.py | 367 +++++++++++++ .../images/qemu/qemu_virt_image/__init__.py | 16 + .../qemu_virt_image/luks_qemu_virt_image.py | 31 ++ .../qemu_virt_image/qcow2_qemu_virt_image.py | 40 ++ .../qemu/qemu_virt_image/qemu_virt_image.py | 58 ++ .../qemu_virt_image/raw_qemu_virt_image.py | 17 + virttest/vt_imgr/images/virt_image.py | 96 ++++ virttest/vt_imgr/vt_imgr.py | 240 +++++++++ virttest/vt_resmgr/__init__.py | 1 + virttest/vt_resmgr/resources/__init__.py | 19 + virttest/vt_resmgr/resources/cvm/__init__.py | 1 + virttest/vt_resmgr/resources/pool.py | 178 +++++++ virttest/vt_resmgr/resources/resource.py | 135 +++++ .../vt_resmgr/resources/storage/__init__.py | 14 + .../resources/storage/ceph/__init__.py | 1 + .../resources/storage/dir/__init__.py | 1 + .../resources/storage/dir/dir_pool.py | 75 +++ .../resources/storage/dir/dir_resources.py | 109 ++++ .../storage/iscsi_direct/__init__.py | 1 + .../storage/iscsi_direct/iscsi_direct_pool.py | 20 + .../resources/storage/nbd/__init__.py | 1 + .../resources/storage/nfs/__init__.py | 1 + .../resources/storage/nfs/nfs_pool.py | 67 +++ .../resources/storage/nfs/nfs_resources.py | 113 ++++ .../vt_resmgr/resources/storage/volume.py | 81 +++ virttest/vt_resmgr/vt_resmgr.py | 438 ++++++++++++++++ virttest/vt_utils/image/qemu.py | 177 +++++++ 57 files changed, 3898 insertions(+), 34 deletions(-) create mode 100644 virttest/vt_agent/managers/image.py create mode 100644 virttest/vt_agent/managers/images/__init__.py create mode 100644 virttest/vt_agent/managers/images/qemu/__init__.py create mode 100644 virttest/vt_agent/managers/images/qemu/qemu_image_handlers.py create mode 100644 virttest/vt_agent/managers/resource_backing.py create mode 100644 virttest/vt_agent/managers/resource_backings/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/backing.py create mode 100644 virttest/vt_agent/managers/resource_backings/cvm/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/cvm/_sev_resmgr.py create mode 100644 virttest/vt_agent/managers/resource_backings/pool_connection.py create mode 100644 virttest/vt_agent/managers/resource_backings/storage/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/storage/dir/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/storage/dir/dir_backing.py create mode 100644 virttest/vt_agent/managers/resource_backings/storage/dir/dir_pool_connection.py create mode 100644 virttest/vt_agent/managers/resource_backings/storage/nfs/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_backing.py create mode 100644 virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_pool_connection.py create mode 100644 virttest/vt_agent/services/image.py create mode 100644 virttest/vt_agent/services/resource.py create mode 100644 virttest/vt_imgr/__init__.py create mode 100644 virttest/vt_imgr/images/__init__.py create mode 100644 virttest/vt_imgr/images/image.py create mode 100644 virttest/vt_imgr/images/qemu/__init__.py create mode 100644 virttest/vt_imgr/images/qemu/qemu_image.py create mode 100644 virttest/vt_imgr/images/qemu/qemu_virt_image/__init__.py create mode 100644 virttest/vt_imgr/images/qemu/qemu_virt_image/luks_qemu_virt_image.py create mode 100644 virttest/vt_imgr/images/qemu/qemu_virt_image/qcow2_qemu_virt_image.py create mode 100644 virttest/vt_imgr/images/qemu/qemu_virt_image/qemu_virt_image.py create mode 100644 virttest/vt_imgr/images/qemu/qemu_virt_image/raw_qemu_virt_image.py create mode 100644 virttest/vt_imgr/images/virt_image.py create mode 100644 virttest/vt_imgr/vt_imgr.py create mode 100644 virttest/vt_resmgr/__init__.py create mode 100644 virttest/vt_resmgr/resources/__init__.py create mode 100644 virttest/vt_resmgr/resources/cvm/__init__.py create mode 100644 virttest/vt_resmgr/resources/pool.py create mode 100644 virttest/vt_resmgr/resources/resource.py create mode 100644 virttest/vt_resmgr/resources/storage/__init__.py create mode 100644 virttest/vt_resmgr/resources/storage/ceph/__init__.py create mode 100644 virttest/vt_resmgr/resources/storage/dir/__init__.py create mode 100644 virttest/vt_resmgr/resources/storage/dir/dir_pool.py create mode 100644 virttest/vt_resmgr/resources/storage/dir/dir_resources.py create mode 100644 virttest/vt_resmgr/resources/storage/iscsi_direct/__init__.py create mode 100644 virttest/vt_resmgr/resources/storage/iscsi_direct/iscsi_direct_pool.py create mode 100644 virttest/vt_resmgr/resources/storage/nbd/__init__.py create mode 100644 virttest/vt_resmgr/resources/storage/nfs/__init__.py create mode 100644 virttest/vt_resmgr/resources/storage/nfs/nfs_pool.py create mode 100644 virttest/vt_resmgr/resources/storage/nfs/nfs_resources.py create mode 100644 virttest/vt_resmgr/resources/storage/volume.py create mode 100644 virttest/vt_resmgr/vt_resmgr.py create mode 100644 virttest/vt_utils/image/qemu.py diff --git a/avocado_vt/plugins/vt_cluster.py b/avocado_vt/plugins/vt_cluster.py index 399e82eb4b..1c77daa80d 100644 --- a/avocado_vt/plugins/vt_cluster.py +++ b/avocado_vt/plugins/vt_cluster.py @@ -7,6 +7,8 @@ from avocado.core.plugin_interfaces import JobPreTests as Pre from avocado.utils.stacktrace import log_exc_info from virttest.vt_cluster import cluster, node_metadata +from virttest.vt_imgr import vt_imgr +from virttest.vt_resmgr import resmgr class ClusterSetupError(Exception): @@ -50,10 +52,8 @@ def _pre_node_setup(): def _pre_mgr_setup(): try: # Pre-setup the cluster manager - # e.g: - # startup_resmgr() - # vt_imgr.startup() - pass + resmgr.startup() + vt_imgr.startup() except Exception as err: raise ClusterManagerSetupError(err) @@ -61,10 +61,8 @@ def _pre_mgr_setup(): def _post_mgr_cleanup(): try: # Post-cleanup the cluster manager - # e.g: - # teardown_resmgr() - # vt_imgr.teardown() - pass + vt_imgr.teardown() + resmgr.teardown() except Exception as err: raise ClusterManagerCleanupError(err) diff --git a/avocado_vt/test.py b/avocado_vt/test.py index 921140a468..4f0024cb45 100644 --- a/avocado_vt/test.py +++ b/avocado_vt/test.py @@ -37,6 +37,7 @@ ) from virttest._wrappers import load_source from virttest.vt_cluster import cluster, logger, selector +from virttest.vt_resmgr import resmgr # avocado-vt no longer needs autotest for the majority of its functionality, # except by: @@ -378,7 +379,21 @@ def _setup_partition(self): _node.tag = node self._cluster_partition.add_node(_node) + # Select the pools when the user specifies the pools param + for pool_tag in self.params.objects("pools"): + pool_params = self.params.object_params(pool_tag) + pool_selectors = pool_params.get("pool_selectors") + + pools = set(resmgr.get_all_pools()) - set(cluster.partition.pools.values()) + pool_id = selector.select_resource_pool(list(pools), pool_selectors) + if not pool_id: + raise selector.SelectorError( + f"No pool selected for {pool_tag} with {pool_selectors}" + ) + self._cluster_partition.pools[pool_tag] = pool_id + def _clear_partition(self): + self._cluster_partition.pools.clear() cluster_dir = os.path.join(self.resultsdir, "cluster") if self._cluster_partition.nodes: for node in self._cluster_partition.nodes: diff --git a/virttest/bootstrap.py b/virttest/bootstrap.py index b192f0d233..c13b4a8610 100644 --- a/virttest/bootstrap.py +++ b/virttest/bootstrap.py @@ -12,6 +12,7 @@ from avocado.utils import process from virttest.vt_cluster import cluster, node +from virttest.vt_resmgr import resmgr from . import arch, asset, cartesian_config, data_dir, defaults, utils_selinux from .compat import get_opt @@ -895,6 +896,10 @@ def _register_hosts(hosts_configs): LOG.debug("Host %s registered", host) +def _initialize_managers(pools_params): + resmgr.initialize(pools_params) + + def _config_master_server(master_config): """Configure the master server.""" if master_config: @@ -1084,6 +1089,7 @@ def bootstrap(options, interactive=False): cluster_config = _load_cluster_config(vt_cluster_config) _register_hosts(cluster_config.get("hosts")) _config_master_server(cluster_config.get("master")) + _initialize_managers(cluster_config.get("pools")) LOG.info("") LOG.info("VT-BOOTSTRAP FINISHED") diff --git a/virttest/env_process.py b/virttest/env_process.py index 748fb6e0c3..0534ec91b3 100644 --- a/virttest/env_process.py +++ b/virttest/env_process.py @@ -62,6 +62,8 @@ from virttest.test_setup.storage import StorageConfig from virttest.test_setup.vms import UnrequestedVMHandler from virttest.utils_version import VersionInterval +from virttest.vt_imgr import vt_imgr + utils_libvirtd = lazy_import("virttest.utils_libvirtd") virsh = lazy_import("virttest.virsh") @@ -124,7 +126,7 @@ def _get_qemu_version(qemu_cmd): return "Unknown" -def preprocess_image(test, params, image_name, vm_process_status=None): +def preprocess_image(test, params, image_name, vm_process_status=None, vm_name=None): """ Preprocess a single QEMU image according to the instructions in params. @@ -132,34 +134,62 @@ def preprocess_image(test, params, image_name, vm_process_status=None): :param params: A dict containing image preprocessing parameters. :param vm_process_status: This is needed in postprocess_image. Add it here only for keep it work with process_images() + :param vm_name: vm tag defined in 'vms' :note: Currently this function just creates an image if requested. """ + # FIXME: + image_id = None + if params.get_boolean("multihost"): + params = params.copy() + params[f"image_owner_{image_name}"] = vm_name + image_config = vt_imgr.define_image_config(image_name, params) + image_id = vt_imgr.create_image_object(image_config) + + params = params.object_params(image_name) base_dir = params.get("images_base_dir", data_dir.get_data_dir()) if not storage.preprocess_image_backend(base_dir, params, image_name): LOG.error("Backend can't be prepared correctly.") - image_filename = storage.get_image_filename(params, base_dir) + image_filename = None + if not params.get_boolean("multihost"): + image_filename = storage.get_image_filename(params, base_dir) create_image = False if params.get("force_create_image") == "yes": create_image = True - elif params.get("create_image") == "yes" and not storage.file_exists( - params, image_filename - ): - create_image = True + elif params.get("create_image") == "yes": + # FIXME: check all volumes allocated + if params.get_boolean("multihost"): + volume = vt_imgr.get_image_info( + image_id, request=f"spec.virt-images.{image_name}.spec.volume.meta" + ) + create_image = True if not volume["meta"]["allocated"] else False + else: + create_image = ( + True if not storage.file_exists(params, image_filename) else False + ) + else: + # FIXME: sync all volumes configurations + if params.get_boolean("multihost"): + vt_imgr.get_image_info(image_id) + # TODO: check if file allocated if params.get("backup_image_before_testing", "no") == "yes": + # FIXME: add backup_image image = qemu_storage.QemuImg(params, base_dir, image_name) image.backup_image(params, base_dir, "backup", True, True) if create_image: - if storage.file_exists(params, image_filename): - # As rbd image can not be covered, so need remove it if we need - # force create a new image. - storage.file_remove(params, image_filename) - image = qemu_storage.QemuImg(params, base_dir, image_name) - LOG.info("Create image on %s." % image.storage_type) - image.create(params) + if params.get_boolean("multihost"): + vt_imgr.handle_image(image_id, {"create": {}}) + else: + if storage.file_exists(params, image_filename): + # As rbd image can not be covered, so need remove it if we need + # force create a new image. + storage.file_remove(params, image_filename) + image = qemu_storage.QemuImg(params, base_dir, image_name) + LOG.info("Create image on %s." % image.storage_type) + image.create(params) def preprocess_fs_source(test, params, fs_name, vm_process_status=None): @@ -522,7 +552,7 @@ def check_image(test, params, image_name, vm_process_status=None): raise e -def postprocess_image(test, params, image_name, vm_process_status=None): +def postprocess_image(test, params, image_name, vm_process_status=None, vm_name=None): """ Postprocess a single QEMU image according to the instructions in params. @@ -539,6 +569,16 @@ def postprocess_image(test, params, image_name, vm_process_status=None): ) return + # FIXME: multihost + image_id = None + if params.get_boolean("multihost"): + image_id = vt_imgr.query_image(image_name, vm_name) + if image_id is None: + LOG.warning(f"Cannot find the image {image_name}") + image_config = vt_imgr.define_image_config(image_name, params) + image_id = vt_imgr.create_image_object(image_config) + params = params.object_params(image_name) + restored, removed = (False, False) clone_master = params.get("clone_master", None) base_dir = params.get("images_base_dir", data_dir.get_data_dir()) @@ -596,10 +636,18 @@ def postprocess_image(test, params, image_name, vm_process_status=None): ) LOG.info("Remove image on %s." % image.storage_type) if clone_master is None: - image.remove() + if params.get_boolean("multihost"): + vt_imgr.handle_image(image_id, {"destroy": {}}) + vt_imgr.destroy_image_object(image_id) + else: + image.remove() elif clone_master == "yes": if image_name in params.get("master_images_clone").split(): - image.remove() + if params.get_boolean("multihost"): + vt_imgr.handle_image(image_id, {"destroy": {}}) + vt_imgr.destroy_image_object(image_id) + else: + image.remove() def postprocess_fs_source(test, params, fs_name, vm_process_status=None): @@ -754,7 +802,7 @@ class _CreateImages(threading.Thread): in self.exc_info """ - def __init__(self, image_func, test, images, params, exit_event, vm_process_status): + def __init__(self, image_func, test, images, params, exit_event, vm_process_status, vm_name=None): threading.Thread.__init__(self) self.image_func = image_func self.test = test @@ -763,6 +811,7 @@ def __init__(self, image_func, test, images, params, exit_event, vm_process_stat self.exit_event = exit_event self.exc_info = None self.vm_process_status = vm_process_status + self.vm_name = vm_name def run(self): try: @@ -773,13 +822,14 @@ def run(self): self.params, self.exit_event, self.vm_process_status, + self.vm_name, ) except Exception: self.exc_info = sys.exc_info() self.exit_event.set() -def process_images(image_func, test, params, vm_process_status=None): +def process_images(image_func, test, params, vm_process_status=None, vm_name=None): """ Wrapper which chooses the best way to process images. @@ -792,11 +842,11 @@ def process_images(image_func, test, params, vm_process_status=None): images = params.objects("images") if len(images) > 20: # Lets do it in parallel _process_images_parallel( - image_func, test, params, vm_process_status=vm_process_status + image_func, test, params, vm_process_status=vm_process_status,vm_name=vm_name ) else: _process_images_serial( - image_func, test, images, params, vm_process_status=vm_process_status + image_func, test, images, params, vm_process_status=vm_process_status, vm_name=vm_name ) @@ -816,7 +866,7 @@ def process_fs_sources(fs_source_func, test, params, vm_process_status=None): def _process_images_serial( - image_func, test, images, params, exit_event=None, vm_process_status=None + image_func, test, images, params, exit_event=None, vm_process_status=None, vm_name=None ): """ Original process_image function, which allows custom set of images @@ -829,14 +879,15 @@ def _process_images_serial( or None for no vm exist. """ for image_name in images: - image_params = params.object_params(image_name) - image_func(test, image_params, image_name, vm_process_status) + # image_params = params.object_params(image_name) + # image_func(test, image_params, image_name, vm_process_status) + image_func(test, params, image_name, vm_process_status, vm_name) if exit_event and exit_event.is_set(): LOG.error("Received exit_event, stop processing of images.") break -def _process_images_parallel(image_func, test, params, vm_process_status=None): +def _process_images_parallel(image_func, test, params, vm_process_status=None, vm_name=None): """ The same as _process_images but in parallel. :param image_func: Process function @@ -852,7 +903,7 @@ def _process_images_parallel(image_func, test, params, vm_process_status=None): for i in xrange(no_threads): imgs = images[i::no_threads] threads.append( - _CreateImages(image_func, test, imgs, params, exit_event, vm_process_status) + _CreateImages(image_func, test, imgs, params, exit_event, vm_process_status, vm_name) ) threads[-1].start() @@ -907,7 +958,7 @@ def _call_image_func(): unpause_vm = True vm_params["skip_cluster_leak_warn"] = "yes" try: - process_images(image_func, test, vm_params, vm_process_status) + process_images(image_func, test, vm_params, vm_process_status, vm_name) finally: if unpause_vm: vm.resume() diff --git a/virttest/vt_agent/managers/__init__.py b/virttest/vt_agent/managers/__init__.py index 4e973d4c42..8fa6cd208b 100644 --- a/virttest/vt_agent/managers/__init__.py +++ b/virttest/vt_agent/managers/__init__.py @@ -1,5 +1,9 @@ from .connect import ConnectManager from .console import ConsoleManager +from .image import ImageHandlerManager +from .resource_backing import ResourceBackingManager connect_mgr = ConnectManager() console_mgr = ConsoleManager() +resbacking_mgr = ResourceBackingManager() +image_handler_mgr = ImageHandlerManager() diff --git a/virttest/vt_agent/managers/image.py b/virttest/vt_agent/managers/image.py new file mode 100644 index 0000000000..b13db2cabb --- /dev/null +++ b/virttest/vt_agent/managers/image.py @@ -0,0 +1,26 @@ +import logging + +from .images import get_image_handler + + +LOG = logging.getLogger("avocado.agents." + __name__) + + +class ImageHandlerManager(object): + + def __init__(self): + pass + + def handle_image(self, image_config, config): + r, o = 0, dict() + try: + cmd, arguments = config.popitem() + image_type = image_config["meta"]["type"] + handler = get_image_handler(image_type, cmd) + ret = handler(image_config, arguments) + if ret: + o["out"] = ret + except Exception as e: + r, o["out"] = 1, str(e) + LOG.debug("Failed to handle image(%s): %s", str(e)) + return r, o diff --git a/virttest/vt_agent/managers/images/__init__.py b/virttest/vt_agent/managers/images/__init__.py new file mode 100644 index 0000000000..708b13576d --- /dev/null +++ b/virttest/vt_agent/managers/images/__init__.py @@ -0,0 +1,16 @@ +from .qemu import get_qemu_image_handler +# from .xen import get_xen_image_handler + + +_image_handler_getters = { + "qemu": get_qemu_image_handler, + # "xen": get_xen_image_handler, +} + + +def get_image_handler(image_type, cmd): + getter = _image_handler_getters.get(image_type) + return getter(cmd) + + +__all__ = ["get_image_handler"] diff --git a/virttest/vt_agent/managers/images/qemu/__init__.py b/virttest/vt_agent/managers/images/qemu/__init__.py new file mode 100644 index 0000000000..3e42b78b16 --- /dev/null +++ b/virttest/vt_agent/managers/images/qemu/__init__.py @@ -0,0 +1 @@ +from .qemu_image_handlers import get_qemu_image_handler diff --git a/virttest/vt_agent/managers/images/qemu/qemu_image_handlers.py b/virttest/vt_agent/managers/images/qemu/qemu_image_handlers.py new file mode 100644 index 0000000000..2feeb6289d --- /dev/null +++ b/virttest/vt_agent/managers/images/qemu/qemu_image_handlers.py @@ -0,0 +1,495 @@ +import collections +import json +import logging +import os +import re +import string + +from avocado.utils import process +from avocado.utils import path as utils_path + +from virttest.utils_numeric import normalize_data_size +from virttest.vt_utils.image.qemu import get_image_opts + + +LOG = logging.getLogger("avocado.service." + __name__) + + +class _ParameterAssembler(string.Formatter): + """ + Command line parameter assembler. + + This will automatically prepend parameter if corresponding value is passed + to the format string. + """ + + sentinal = object() + + def __init__(self, cmd_params=None): + string.Formatter.__init__(self) + self.cmd_params = cmd_params or {} + + def format(self, format_string, *args, **kwargs): + """Remove redundant whitespaces and return format string.""" + ret = string.Formatter.format(self, format_string, *args, **kwargs) + return re.sub(" +", " ", ret) + + def get_value(self, key, args, kwargs): + try: + val = string.Formatter.get_value(self, key, args, kwargs) + except KeyError: + if key in self.cmd_params: + val = None + else: + raise + return (self.cmd_params.get(key, self.sentinal), val) + + def convert_field(self, value, conversion): + """ + Do conversion on the resulting object. + + supported conversions: + 'b': keep the parameter only if bool(value) is True. + 'v': keep both the parameter and its corresponding value, + the default mode. + """ + if value[0] is self.sentinal: + return string.Formatter.convert_field(self, value[1], conversion) + if conversion is None: + conversion = "v" + if conversion == "v": + return "" if value[1] is None else " ".join(value) + if conversion == "b": + return value[0] if bool(value[1]) else "" + raise ValueError("Unknown conversion specifier {}".format(conversion)) + + +QEMU_IMG_BINARY = utils_path.find_command("qemu-img") +qemu_img_parameters = { + "image_format": "-f", + "backing_file": "-b", + "backing_format": "-F", + "unsafe": "-u", + "quiet": "-q", + "options": "-o", + "secret_object": "", + "tls_creds_object": "", + "image_opts": "--image-opts", + "check_repair": "-r", + "output_format": "--output", + "force_share": "-U", + "resize_preallocation": "--preallocation", + "resize_shrink": "--shrink", + "convert_compressed": "-c", + "cache_mode": "-t", + "source_cache_mode": "-T", + "target_image_format": "-O", + "convert_sparse_size": "-S", + "rate_limit": "-r", + "convert_target_is_zero": "--target-is-zero", + "convert_backing_file": "-B", + "commit_drop": "-d", + "compare_strict_mode": "-s", + "compare_second_image_format": "-F", + "backing_chain": "--backing-chain", +} +cmd_formatter = _ParameterAssembler(qemu_img_parameters) + + +def get_qemu_img_object_repr(sec_opts, obj_type="secret"): + mapping = { + "secret": "--object secret,id={name}", + "cookie": "--object secret,id={name}", + "tls-creds-x509": "--object tls-creds-x509,id={name},endpoint=client,dir={dir}", + } + + obj_str = mapping.get(obj_type) + if obj_str is None: + raise ValueError(f"Unknown object type {obj_type}") + + if "format" in sec_opts: + obj_str += ",format={format}" + if "file" in sec_opts: + obj_str += ",file={file}" + elif obj_type != "tls-creds-x509": + obj_str += ",data={data}" + + return obj_str.format(**sec_opts) + + +def get_qemu_virt_image_json_repr(virt_image_opts): + """Generate image json representation.""" + return "'json:%s'" % json.dumps(virt_image_opts) + + +def get_qemu_virt_image_opts_repr(virt_image_opts): + """Generate image-opts.""" + + def _dict_to_dot(dct): + """Convert dictionary to dot representation.""" + flat = [] + prefix = [] + stack = [dct.items()] + while stack: + it = stack[-1] + try: + key, value = next(it) + except StopIteration: + if prefix: + prefix.pop() + stack.pop() + continue + if isinstance(value, collections.Mapping): + prefix.append(key) + stack.append(value.items()) + else: + flat.append((".".join(prefix + [key]), value)) + return flat + + return ",".join( + ["%s=%s" % (attr, value) for attr, value in _dict_to_dot(virt_image_opts)] + ) + + +def parse_qemu_img_options(virt_image_spec): + options = [ + "preallocation", + "cluster_size", + "lazy_refcounts", + "compat", + "extent_size_hint", + "compression_type", + ] + opts = {k: v for k in options if k in virt_image_spec and virt_image_spec[k]} + + # TODO: data_file, backing_file + return opts + + +def get_qemu_virt_image_repr(virt_image_config, output=None): + virt_image_spec = virt_image_config["spec"] + + mapping = { + "uri": lambda i: virt_image_spec["volume"]["spec"]["uri"], + "json": get_qemu_virt_image_json_repr, + "opts": get_qemu_virt_image_opts_repr, + } + + auth_opts, sec_opts, img_opts = get_image_opts(virt_image_config) + func = mapping.get(output) + if func is None: + func = mapping["json"] if auth_opts or sec_opts else mapping["uri"] + virt_image_repr = func(img_opts) + + objs = [] + if auth_opts: + objs.append(get_qemu_img_object_repr(auth_opts)) + if sec_opts: + objs.append(get_qemu_img_object_repr(sec_opts)) + objs_repr = " ".join(objs) + + opts_repr = "" + options = parse_qemu_img_options(virt_image_spec) + if auth_opts: + # FIXME: cookie-secret + if "file" in auth_opts: + options["password-secret"] = auth_opts["name"] + elif "dir" in auth_opts: + options["tls-creds"] = auth_opts["name"] + else: + options["key-secret"] = auth_opts["name"] + + if sec_opts: + virt_image_format = virt_image_spec["format"] + if virt_image_format == "luks": + key = "password-secret" if "file" in sec_opts else "key-secret" + elif virt_image_format == "qcow2": + key = "encrypt.key-secret" + options.update({f"encrypt.{k}": v for k, v in sec_opts.items()}) + else: + raise ValueError( + f"Encryption of a {virt_image_format} image is not supported" + ) + options[key] = sec_opts["name"] + opts_repr = ",".join([f"{k}={v}" for k, v in options.items()]) + + return objs_repr, opts_repr, virt_image_repr + + +def _create(image_config, arguments): + def _dd(image_tag): + qemu_img_cmd = "" + virt_image_config = image_spec["virt-images"][image_tag] + volume_config = virt_image_config["spec"]["volume"] + + if virt_image_config["spec"]["format"] == "raw": + count = utils_numeric.normalize_data_size( + int(volume_config["spec"]["size"]), order_magnitude="M" + ) + qemu_img_cmd = "dd if=/dev/zero of=%s count=%s bs=1M" % ( + volume_config["spec"]["path"], + count, + block_size, + ) + else: + raise + + def _qemu_img_create(virt_image_tag): + qemu_img_cmd = "" + virt_image_config = image_spec["virt-images"][virt_image_tag] + virt_image_spec = virt_image_config["spec"] + volume_config = virt_image_config["spec"]["volume"] + + # Prepare the secret data storage file + encryption = virt_image_spec.get("encryption", {}) + if encryption.get("storage") == "file": + # FIXME: + os.makedirs(os.path.dirname(encryption["file"]), exist_ok=True) + with open(encryption["file"], "w") as fd: + fd.write(encryption["data"]) + + cmd_dict = { + "image_format": virt_image_spec["format"], + "image_size": int(volume_config["spec"]["size"]), + } + + secret_objects = list() + base_tag = virt_image_spec.get("backing") + if base_tag is not None: + base_virt_image_config = image_spec["virt-images"][base_tag] + objs_repr, _, cmd_dict["backing_file"] = get_qemu_virt_image_repr( + base_virt_image_config, image_repr_format + ) + if objs_repr: + secret_objects.append(objs_repr) + cmd_dict["backing_format"] = base_virt_image_config["spec"]["format"] + + # Add all backings' secret and access auth objects + for tag in list(image_meta["topology"].values())[0]: + if tag == base_tag: + break + config = image_spec["virt-images"][tag] + objs_repr, _, _ = get_qemu_virt_image_repr(config) + if objs_repr: + secret_objects.append(objs_repr) + + objs_repr, options_repr, cmd_dict["image_filename"] = get_qemu_virt_image_repr( + virt_image_config, "uri" + ) + if objs_repr: + secret_objects.append(objs_repr) + if options_repr: + cmd_dict["options"] = options_repr + + cmd_dict["secret_object"] = " ".join(secret_objects) + + qemu_img_cmd = ( + qemu_image_binary + " " + cmd_formatter.format(create_cmd, **cmd_dict) + ) + + LOG.info(f"Create image with command: {qemu_img_cmd}") + process.run(qemu_img_cmd, shell=True, verbose=False, ignore_status=False) + + create_cmd = ( + "create {secret_object} {image_format} " + "{backing_file} {backing_format} {unsafe!b} {options} " + "{image_filename} {image_size}" + ) + + qemu_image_binary = arguments.pop("qemu_img_binary", QEMU_IMG_BINARY) + image_repr_format = arguments.pop("repr", None) + image_meta = image_config["meta"] + image_spec = image_config["spec"] + + tag = arguments.pop("target", None) + virt_images = [tag] if tag else list(image_meta["topology"].values())[0] + for tag in virt_images: + _qemu_img_create(tag) + + +def _snapshot(image_config, arguments): + pass + + +def _rebase(image_config, arguments): + qemu_image_binary = arguments.pop("qemu_img_binary", QEMU_IMG_BINARY) + image_repr_format = arguments.pop("repr", None) + backing = arguments.pop("source") + backing_config = image_config["spec"]["virt-images"][backing] + target = arguments.pop("target") + target_config = image_config["spec"]["virt-images"][target] + + rebase_cmd = ( + "rebase {secret_object} {image_format} {cache_mode} " + "{source_cache_mode} {unsafe!b} {options} " + "{backing_file} {backing_format} {image_filename}" + ) + + cmd_dict = { + "image_format": target_config["spec"]["format"], + "cache_mode": arguments.pop("cache_mode", None), + "source_cache_mode": arguments.pop("source_cache_mode", None), + "unsafe": arguments.pop("unsafe", False), + "backing_format": backing_config["spec"]["format"], + } + + secret_objects = list() + obj_repr, options_repr, cmd_dict["image_filename"] = get_qemu_virt_image_repr(target_config, image_repr_format) + if obj_repr or image_repr_format in ["opts", "json"]: + secret_objects.append(obj_repr) + cmd_dict.pop("image_format") + if options_repr: + cmd_dict["options"] = options_repr + + obj_repr, _, cmd_dict["backing_file"] = get_qemu_virt_image_repr(backing_config, None) + if obj_repr: + secret_objects.append(obj_repr) + + # Add all backings' secret and access auth objects + for tag in list(image_config["meta"]["topology"].values())[0]: + if tag == backing: + break + config = image_config["spec"]["virt-images"][tag] + objs_repr, _, _ = get_qemu_virt_image_repr(config) + if objs_repr: + secret_objects.append(objs_repr) + + cmd_dict["secret_object"] = " ".join(secret_objects) + + qemu_img_cmd = ( + qemu_image_binary + + " " + + cmd_formatter.format(rebase_cmd, **cmd_dict) + ) + + LOG.info(f"Rebase {target} onto {backing} by command: {qemu_img_cmd}") + process.run( + qemu_img_cmd, shell=True, verbose=False, ignore_status=False + ) + + +def _commit(image_config, arguments): + pass + + +def _check(image_config, arguments): + check_cmd = ( + "check {secret_object} {quiet!b} {image_format} " + "{check_repair} {force_share!b} {output_format} " + "{source_cache_mode} {image_opts} {image_filename}" + ) + + qemu_image_binary = arguments.pop("qemu_img_binary", QEMU_IMG_BINARY) + image_repr_format = arguments.pop("repr", None) + target = arguments.pop("target", image_config["meta"]["name"]) + target_config = image_config["spec"]["virt-images"][target] + + cmd_dict = { + "quiet": arguments.pop("quiet", False), + "image_format": target_config["spec"]["format"], + "check_repair": arguments.pop("repair", None), + "force_share": arguments.pop("force", False), + "output_format": arguments.pop("output", "human"), + "source_cache_mode": arguments.pop("source_cache_mode", None), + } + + secret_objects = list() + obj_repr, _, cmd_dict["image_filename"] = get_qemu_virt_image_repr(target_config, image_repr_format) + if obj_repr: + secret_objects.append(obj_repr) + + image_list = list(image_config["meta"]["topology"].values())[0] + if target in image_list: + # Add all backings' secret and access auth objects + for tag in image_list: + if tag == target: + break + config = image_config["spec"]["virt-images"][tag] + objs_repr, _, _ = get_qemu_virt_image_repr(config) + if objs_repr: + secret_objects.append(objs_repr) + cmd_dict["secret_object"] = " ".join(secret_objects) + + if obj_repr or image_repr_format in ["opts", "json"]: + cmd_dict.pop("image_format") + if image_repr_format == "opts": + cmd_dict["image_opts"] = cmd_dict.pop("image_filename") + + qemu_img_cmd = ( + qemu_image_binary + + " " + + cmd_formatter.format(check_cmd, **cmd_dict) + ) + + LOG.info(f"Check {target} with command: {qemu_img_cmd}") + cmd_result = process.run( + qemu_img_cmd, shell=True, verbose=True, ignore_status=False + ) + return cmd_result.stdout_text + + +def _info(image_config, arguments): + info_cmd = ( + "info {secret_object} {image_format} {backing_chain!b} " + "{force_share!b} {output_format} {image_opts} {image_filename}" + ) + + qemu_image_binary = arguments.pop("qemu_img_binary", QEMU_IMG_BINARY) + image_repr_format = arguments.pop("repr", None) + target = arguments.pop("target", image_config["meta"]["name"]) + target_config = image_config["spec"]["virt-images"][target] + + cmd_dict = { + "image_format": target_config["spec"]["format"], + "backing_chain": arguments.pop("backing_chain", False), + "force_share": arguments.pop("force", False), + "output_format": arguments.pop("output", "human"), + } + + secret_objects = list() + obj_repr, _, cmd_dict["image_filename"] = get_qemu_virt_image_repr(target_config, image_repr_format) + if obj_repr: + secret_objects.append(obj_repr) + + image_list = list(image_config["meta"]["topology"].values())[0] + if target in image_list: + # Add all backings' secret and access auth objects + for tag in image_list: + if tag == target: + break + config = image_config["spec"]["virt-images"][tag] + objs_repr, _, _ = get_qemu_virt_image_repr(config) + if objs_repr: + secret_objects.append(objs_repr) + cmd_dict["secret_object"] = " ".join(secret_objects) + + if obj_repr or image_repr_format in ["opts", "json"]: + cmd_dict.pop("image_format") + + if image_repr_format == "opts": + cmd_dict["image_opts"] = cmd_dict.pop("image_filename") + + qemu_img_cmd = ( + qemu_image_binary + + " " + + cmd_formatter.format(info_cmd, **cmd_dict) + ) + + LOG.info(f"Query info for {target} with command: {qemu_img_cmd}") + cmd_result = process.run( + qemu_img_cmd, shell=True, verbose=True, ignore_status=False + ) + return cmd_result.stdout_text + + +_qemu_image_handlers = { + "create": _create, + "rebase": _rebase, + "snapshot": _snapshot, + "commit": _commit, + "check": _check, + "info": _info, +} + +def get_qemu_image_handler(cmd): + return _qemu_image_handlers.get(cmd) diff --git a/virttest/vt_agent/managers/resource_backing.py b/virttest/vt_agent/managers/resource_backing.py new file mode 100644 index 0000000000..825aa383ea --- /dev/null +++ b/virttest/vt_agent/managers/resource_backing.py @@ -0,0 +1,120 @@ +import logging +import os +import pickle + +from .resource_backings import ( + get_resource_backing_class, + get_pool_connection_class, +) + +from vt_agent.core import data_dir + + +LOG = logging.getLogger("avocado.agents." + __name__) + + +class ResourceBackingManager(object): + + def __init__(self): + if os.path.isfile(data_dir.BACKING_MGR_ENV_FILENAME): + self._pool_connections = self._load() + else: + self._pool_connections = dict() + self._backings = dict() + + def _load(self): + with open(data_dir.BACKING_MGR_ENV_FILENAME, "rb") as f: + return pickle.load(f) + + def _dump(self): + with open(data_dir.BACKING_MGR_ENV_FILENAME, "wb") as f: + pickle.dump(self._pool_connections, f) + + def create_pool_connection(self, pool_id, pool_config): + r, o = 0, dict() + try: + pool_type = pool_config["meta"]["type"] + pool_conn_class = get_pool_connection_class(pool_type) + pool_conn = pool_conn_class(pool_config) + pool_conn.startup() + self._pool_connections[pool_id] = pool_conn + except Exception as e: + r, o["out"] = 1, str(e) + LOG.debug(f"Failed to connect to pool({pool_id}): {str(e)}") + + if r == 0: + self._dump() + + return r, o + + def destroy_pool_connection(self, pool_id): + r, o = 0, dict() + try: + pool_conn = self._pool_connections.pop(pool_id) + pool_conn.shutdown() + except Exception as e: + r, o["out"] = 1, str(e) + LOG.debug(f"Failed to disconnect pool({pool_id}): {str(e)}") + + if r == 0: + self._dump() + + return r, o + + def create_backing_object(self, backing_config): + r, o = 0, dict() + try: + pool_id = backing_config["meta"]["pool"]["meta"]["uuid"] + pool_conn = self._pool_connections[pool_id] + pool_type = pool_conn.get_pool_type() + res_type = backing_config["meta"]["type"] + backing_class = get_resource_backing_class(pool_type, res_type) + backing = backing_class(backing_config) + backing.create(pool_conn) + self._backings[backing.backing_id] = backing + o["out"] = backing.backing_id + except Exception as e: + r, o["out"] = 1, str(e) + LOG.debug( + "Failed to create backing object for resource %s: %s", + backing_config["meta"]["uuid"], + str(e), + ) + return r, o + + def destroy_backing_object(self, backing_id): + r, o = 0, dict() + try: + backing = self._backings.pop(backing_id) + pool_conn = self._pool_connections[backing.source_pool_id] + backing.destroy(pool_conn) + except Exception as e: + r, o["out"] = 1, str(e) + LOG.debug(f"Failed to destroy backing object({backing_id}): {str(e)}") + return r, o + + def update_backing(self, backing_id, new_config): + r, o = 0, dict() + try: + backing = self._backings[backing_id] + pool_conn = self._pool_connections[backing.source_pool_id] + cmd, arguments = new_config.popitem() + handler = backing.get_update_handler(cmd) + ret = handler(pool_conn, arguments) + if ret: + o["out"] = ret + except Exception as e: + r, o["out"] = 1, str(e) + LOG.debug(f"Failed to update resource by backing ({backing_id}): {str(e)}") + return r, o + + def get_backing_info(self, backing_id): + r, o = 0, dict() + try: + backing = self._backings[backing_id] + pool_conn = self._pool_connections[backing.source_pool_id] + o["out"] = backing.get_resource_info(pool_conn) + except Exception as e: + r, o["out"] = 1, str(e) + LOG.debug(f"Failed to info resource by backing ({backing_id}): {str(e)}") + return r, o diff --git a/virttest/vt_agent/managers/resource_backings/__init__.py b/virttest/vt_agent/managers/resource_backings/__init__.py new file mode 100644 index 0000000000..cc60fe6c34 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/__init__.py @@ -0,0 +1,29 @@ +from .storage import ( + _DirPoolConnection, + _DirVolumeBacking, + _NfsPoolConnection, + _NfsVolumeBacking, +) + + +_pool_conn_classes = dict() +_pool_conn_classes[_DirPoolConnection.get_pool_type()] = _DirPoolConnection +_pool_conn_classes[_NfsPoolConnection.get_pool_type()] = _NfsPoolConnection + +_backing_classes = dict() +_backing_classes[_DirVolumeBacking.get_pool_type()] = { + _DirVolumeBacking.get_resource_type(): _DirVolumeBacking, + _NfsVolumeBacking.get_resource_type(): _NfsVolumeBacking, +} + + +def get_resource_backing_class(pool_type, resource_type): + backing_classes = _backing_classes.get(pool_type, {}) + return backing_classes.get(resource_type) + + +def get_pool_connection_class(pool_type): + return _pool_conn_classes.get(pool_type) + + +__all__ = ["get_pool_connection_class", "get_resource_backing_class"] diff --git a/virttest/vt_agent/managers/resource_backings/backing.py b/virttest/vt_agent/managers/resource_backings/backing.py new file mode 100644 index 0000000000..ce2e62fe3c --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/backing.py @@ -0,0 +1,63 @@ +import uuid +from abc import ABC, abstractmethod + + +class _ResourceBacking(ABC): + _BINDING_RESOURCE_TYPE = None + _SOURCE_POOL_TYPE = None + + def __init__(self, backing_config): + self._uuid = uuid.uuid4().hex + self._source_pool_id = backing_config["meta"]["pool"]["meta"]["uuid"] + self._resource_id = backing_config["meta"]["uuid"] + self._handlers = { + "allocate": self.allocate_resource, + "release": self.release_resource, + "sync": self.sync_resource, + } + + def create(self, pool_conn): + pass + + def destroy(self, pool_conn): + self._uuid = None + self._resource_id = None + + @classmethod + def get_pool_type(cls): + return cls._SOURCE_POOL_TYPE + + @classmethod + def get_resource_type(cls): + return cls._BINDING_RESOURCE_TYPE + + @property + def binding_resource_id(self): + return self._resource_id + + @property + def source_pool_id(self): + return self._source_pool_id + + @property + def backing_id(self): + return self._uuid + + def get_update_handler(self, cmd): + return self._handlers[cmd] + + @abstractmethod + def allocate_resource(self, pool_connection, arguments): + raise NotImplemented + + @abstractmethod + def release_resource(self, pool_connection, arguments): + raise NotImplemented + + @abstractmethod + def get_resource_info(self, pool_connection): + raise NotImplemented + + @abstractmethod + def sync_resource(self, pool_connection, arguments): + raise NotImplemented diff --git a/virttest/vt_agent/managers/resource_backings/cvm/__init__.py b/virttest/vt_agent/managers/resource_backings/cvm/__init__.py new file mode 100644 index 0000000000..d31c959cc0 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/cvm/__init__.py @@ -0,0 +1,27 @@ +from .. import _CVMResBackingMgr +from .. import _all_subclasses + + +class LaunchSecurity(object): + _instance = None + + @classmethod + def dispatch(cls): + return cls._instance + + @classmethod + def startup(cls, config): + if cls._instance is not None: + return cls._instance + + for mgr_cls in _all_subclasses(_CVMResBackingMgr): + if mgr_cls.get_platform_flags() is not None: + cls._instance = mgr_cls(config) + cls._instance.startup() + return cls._instance + + raise + + @classmethod + def teardown(cls): + cls._instance.teardown() diff --git a/virttest/vt_agent/managers/resource_backings/cvm/_sev_resmgr.py b/virttest/vt_agent/managers/resource_backings/cvm/_sev_resmgr.py new file mode 100644 index 0000000000..fcb2982cd8 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/cvm/_sev_resmgr.py @@ -0,0 +1,98 @@ +from .. import _ResBacking +from .. import _ResBackingCaps +from .. import _CVMResBackingMgr + + +class _SEVCommResBacking(_ResBacking): + + def __init__(self, requests): + super().__init__(requests) + self._cbitpos = None + self._reduced_phys_bits = None + # self._sev_device = '/dev/sev' + # self._kernel_hashes = None + + def to_specs(self): + return {"cbitpos": self._cbitpos, "reduced-phys-bits": self._reduced_phys_bits} + + +class _SEVResBacking(_SEVCommResBacking): + RESOURCE_TYPE = "sev" + + def __init__(self): + super().__init__() + self._dh_cert = None + self._session = None + + def allocate(self, requests): + pass + + def free(self): + pass + + def to_specs(self): + pass + + +class _SNPResBacking(_SEVCommResBacking): + RESOURCE_TYPE = "snp" + + def __init__(self): + super().__init__() + + def allocate(self, requests): + pass + + def free(self): + pass + + def to_specs(self): + pass + + +class _SEVResBackingCaps(_ResBackingCaps): + + def __init__(self, params): + self._cbitpos = None + self._reduced_phys_bits = None + self._sev_device = None + self._max_sev_guests = None + self._max_snp_guests = None + self._pdh = None + self._cert_chain = None + self._cpu0_id = None + + def load(self): + pass + + def is_capable(self, requests): + pass + + def increase(self, backing): + pass + + def decrease(self, backing): + pass + + @property + def max_sev_guests(self): + return self._max_sev_guests + + @property + def max_snp_guests(self): + return self._max_snp_guests + + +class _SEVResBackingMgr(_CVMResBackingMgr): + + def __init__(self, config): + super().__init__(config) + self._caps = _SEVResBackingCaps(config) + _SEVResBackingMgr._platform_flags = config + + def startup(self): + reset_sev_platform() + super().startup() + + def teardown(self): + reset_sev_platform() diff --git a/virttest/vt_agent/managers/resource_backings/pool_connection.py b/virttest/vt_agent/managers/resource_backings/pool_connection.py new file mode 100644 index 0000000000..cc0df8d0d3 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/pool_connection.py @@ -0,0 +1,32 @@ +from abc import ABC, abstractmethod + + +class _ResourcePoolAccess(ABC): + + @abstractmethod + def __init__(self, pool_access_config): + pass + + +class _ResourcePoolConnection(ABC): + _CONNECT_POOL_TYPE = None + + def __init__(self, pool_config): + self._pool_id = pool_config["meta"]["uuid"] + + @classmethod + def get_pool_type(cls): + return cls._CONNECT_POOL_TYPE + + @abstractmethod + def startup(self): + pass + + @abstractmethod + def shutdown(self): + pass + + @property + @abstractmethod + def connected(self): + return False diff --git a/virttest/vt_agent/managers/resource_backings/storage/__init__.py b/virttest/vt_agent/managers/resource_backings/storage/__init__.py new file mode 100644 index 0000000000..934cb0885b --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/storage/__init__.py @@ -0,0 +1,4 @@ +from .dir import _DirPoolConnection +from .dir import _DirVolumeBacking +from .nfs import _NfsPoolConnection +from .nfs import _NfsVolumeBacking diff --git a/virttest/vt_agent/managers/resource_backings/storage/dir/__init__.py b/virttest/vt_agent/managers/resource_backings/storage/dir/__init__.py new file mode 100644 index 0000000000..dd0d5847c5 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/storage/dir/__init__.py @@ -0,0 +1,2 @@ +from .dir_backing import _DirVolumeBacking +from .dir_pool_connection import _DirPoolConnection diff --git a/virttest/vt_agent/managers/resource_backings/storage/dir/dir_backing.py b/virttest/vt_agent/managers/resource_backings/storage/dir/dir_backing.py new file mode 100644 index 0000000000..4f1fd61c02 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/storage/dir/dir_backing.py @@ -0,0 +1,76 @@ +import logging +import os + +from avocado.utils import process + +from ...backing import _ResourceBacking + + +LOG = logging.getLogger("avocado.agents.resource_backings.storage.dir." + __name__) + + +class _DirVolumeBacking(_ResourceBacking): + _SOURCE_POOL_TYPE = "filesystem" + _BINDING_RESOURCE_TYPE = "volume" + + def __init__(self, backing_config): + super().__init__(backing_config) + self._size = backing_config["spec"]["size"] + self._filename = backing_config["spec"]["filename"] + self._uri = backing_config["spec"].get("uri") + self._handlers.update( + { + "resize": self.resize_volume, + } + ) + + def create(self, pool_connection): + if not self._uri: + self._uri = os.path.join(pool_connection.root_dir, self._filename) + + def destroy(self, pool_connection): + super().destroy(pool_connection) + self._uri = None + + def allocate_resource(self, pool_connection, arguments): + dirname = os.path.dirname(self._uri) + if not os.path.exists(dirname): + os.makedirs(dirname) + + process.run( + f"fallocate -l {self._size} {self._uri}", + shell=True, + verbose=False, + ignore_status=False, + ) + + return self.get_resource_info(pool_connection) + + def release_resource(self, pool_connection, arguments): + if os.path.exists(self._uri): + os.unlink(self._uri) + + def resize_volume(self, pool_connection, arguments): + pass + + def get_resource_info(self, pool_connection): + allocated, allocation = True, 0 + + try: + s = os.stat(self._uri) + allocation = str(s.st_size) + except FileNotFoundError: + allocated = False + + return { + "meta": { + "allocated": allocated, + }, + "spec": { + "uri": self._uri, + "allocation": allocation, + }, + } + + def sync_resource(self, pool_connection, arguments): + return self.get_resource_info(pool_connection) diff --git a/virttest/vt_agent/managers/resource_backings/storage/dir/dir_pool_connection.py b/virttest/vt_agent/managers/resource_backings/storage/dir/dir_pool_connection.py new file mode 100644 index 0000000000..83739d0def --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/storage/dir/dir_pool_connection.py @@ -0,0 +1,33 @@ +import os +import logging + +from avocado.utils.path import init_dir + +from ...pool_connection import _ResourcePoolConnection + + +LOG = logging.getLogger("avocado.agents.resource_backings.storage.dir." + __name__) + + +class _DirPoolConnection(_ResourcePoolConnection): + + _CONNECT_POOL_TYPE = "filesystem" + + def __init__(self, pool_config): + super().__init__(pool_config) + self._root_dir = pool_config["spec"]["path"] + + def startup(self): + init_dir(self.root_dir) + + def shutdown(self): + if not os.listdir(self.root_dir): + os.removedirs(self.root_dir) + + @property + def connected(self): + return os.path.exists(self.root_dir) + + @property + def root_dir(self): + return self._root_dir diff --git a/virttest/vt_agent/managers/resource_backings/storage/nfs/__init__.py b/virttest/vt_agent/managers/resource_backings/storage/nfs/__init__.py new file mode 100644 index 0000000000..d2b50e200b --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/storage/nfs/__init__.py @@ -0,0 +1,2 @@ +from .nfs_backing import _NfsVolumeBacking +from .nfs_pool_connection import _NfsPoolConnection diff --git a/virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_backing.py b/virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_backing.py new file mode 100644 index 0000000000..efd1c7f42c --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_backing.py @@ -0,0 +1,75 @@ +import logging +import os + +from avocado.utils import process + +from ...backing import _ResourceBacking + + +LOG = logging.getLogger("avocado.agents.resource_backings.storage.nfs" + __name__) + + +class _NfsVolumeBacking(_ResourceBacking): + _SOURCE_POOL_TYPE = "nfs" + _BINDING_RESOURCE_TYPE = "volume" + + def __init__(self, backing_config): + super().__init__(backing_config) + self._size = backing_config["spec"]["size"] + self._filename = backing_config["spec"]["filename"] + self._uri = None + self._handlers.update( + { + "resize": self.resize_volume, + } + ) + + def create(self, pool_connection): + self._uri = os.path.join(pool_connection.mnt, self._filename) + + def destroy(self, pool_connection): + super().destroy(pool_connection) + self._uri = None + + def allocate_resource(self, pool_connection, arguments): + dirname = os.path.dirname(self._uri) + if not os.path.exists(dirname): + os.makedirs(dirname) + + process.run( + f"fallocate -l {self._size} {self._uri}", + shell=True, + verbose=False, + ignore_status=False, + ) + + return self.get_resource_info(pool_connection) + + def release_resource(self, pool_connection, arguments): + if os.path.exists(self._uri): + os.unlink(self._uri) + + def resize_volume(self, pool_connection, arguments): + pass + + def get_resource_info(self, pool_connection): + allocated, allocation = True, 0 + + try: + s = os.stat(self._uri) + allocation = str(s.st_size) + except FileNotFoundError: + allocated = False + + return { + "meta": { + "allocated": allocated, + }, + "spec": { + "uri": self._uri, + "allocation": allocation, + }, + } + + def sync_resource(self, pool_connection, arguments): + return self.get_resource_info(pool_connection) diff --git a/virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_pool_connection.py b/virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_pool_connection.py new file mode 100644 index 0000000000..846cd0aa9c --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/storage/nfs/nfs_pool_connection.py @@ -0,0 +1,59 @@ +import os +import logging + +from avocado.utils.path import init_dir + +from virttest import utils_misc + +from ...pool_connection import _ResourcePoolAccess +from ...pool_connection import _ResourcePoolConnection + + +LOG = logging.getLogger("avocado.agents.resource_backings.storage.nfs." + __name__) + + +class _NfsPoolAccess(_ResourcePoolAccess): + """ + Mount options + """ + + def __init__(self, pool_access_config): + self._options = pool_access_config.get("mount-options", "") + + def __str__(self): + return self._options if self._options else "" + + +class _NfsPoolConnection(_ResourcePoolConnection): + _CONNECT_POOL_TYPE = "nfs" + + def __init__(self, pool_config): + super().__init__(pool_config) + spec = pool_config["spec"] + self._nfs_server = spec["server"] + self._export_dir = spec["export"] + self._nfs_access = _NfsPoolAccess(spec) + self._mnt = spec["mount"] + + def startup(self): + src = f"{self._nfs_server}:{self._export_dir}" + dst = self.mnt + init_dir(dst) + options = str(self._nfs_access) + utils_misc.mount(src, dst, "nfs", options) + + def shutdown(self): + src = f"{self._nfs_server}:{self._export_dir}" + dst = self._mnt + utils_misc.umount(src, dst, "nfs") + if self._create_mnt: + os.removedirs(self.mnt) + + def connected(self): + src = f"{self._nfs_server}:{self._export_dir}" + dst = self.mnt + return utils_misc.is_mount(src, dst, fstype="nfs") + + @property + def mnt(self): + return self._mnt diff --git a/virttest/vt_agent/services/image.py b/virttest/vt_agent/services/image.py new file mode 100644 index 0000000000..eaf83f3561 --- /dev/null +++ b/virttest/vt_agent/services/image.py @@ -0,0 +1,15 @@ +import logging + +from managers import image_handler_mgr + + +LOG = logging.getLogger("avocado.service." + __name__) + + +def handle_image(image_config, config): + """ + Handle the upper-level image. + """ + + LOG.info(f"Handle image with command: {config}") + return image_handler_mgr.handle_image(image_config, config) diff --git a/virttest/vt_agent/services/resource.py b/virttest/vt_agent/services/resource.py new file mode 100644 index 0000000000..fd82348bd7 --- /dev/null +++ b/virttest/vt_agent/services/resource.py @@ -0,0 +1,115 @@ +import logging + +from managers import resbacking_mgr + + +LOG = logging.getLogger("avocado.service." + __name__) + + +def connect_pool(pool_id, pool_config): + """ + Connect to a specified resource pool. + + :param pool_id: The resource pool id + :type pool_id: string + :param pool_config: The resource pool configuration + :type pool_config: dict + :return: Succeeded: 0, {} + Failed: 1, {"out": error message} + :rtype: tuple + """ + LOG.info(f"Connect to pool {pool_id}") + return resbacking_mgr.create_pool_connection(pool_id, pool_config) + + +def disconnect_pool(pool_id): + """ + Disconnect from a specified resource pool. + + :param pool_id: The resource pool id + :type pool_id: string + :param pool_config: The resource pool configuration + :type pool_config: dict + :return: Succeeded: 0, {} + Failed: 1, {"out": error message} + :rtype: tuple + """ + LOG.info(f"Disconnect from pool {pool_id}") + return resbacking_mgr.destroy_pool_connection(pool_id) + + +def create_backing_object(backing_config): + """ + Create a resource backing object on the worker node, which is bound + to one resource only + + :param backing_config: The resource backing configuration, usually, + it's a snippet of the resource configuration, + required for allocating the resource + :type backing_config: dict + :return: Succeeded: 0, {"out": backing_id} + Failed: 1, {"out": error message} + :rtype: tuple + """ + LOG.info( + "Create the backing object for the resource %s", backing_config["meta"]["uuid"] + ) + return resbacking_mgr.create_backing_object(backing_config) + + +def destroy_backing_object(backing_id): + """ + Destroy the backing + + :param backing_id: The cluster resource id + :type backing_id: string + :return: Succeeded: 0, {} + Failed: 1, {"out": error message} + :rtype: tuple + """ + LOG.info(f"Destroy the backing object {backing_id}") + return resbacking_mgr.destroy_backing_object(backing_id) + + +def get_backing_info(backing_id): + """ + Get the information of a resource with a specified backing + + We need not get all the information of the resource, because we can + get the static information by the resource object from the master + node, e.g. size, here we only get the information that only can be + fetched from the worker nodes. + + :param backing_id: The backing id + :type backing_id: string + :return: Succeeded: 0, {"out": config} + Failed: 1, {"out": "error message"} + e.g. a dir resource's config + { + "meta": { + "allocated": True, + }, + "spec":{ + "allocation": "1234567890", + 'uri': '/p1/f1', + } + } + :rtype: tuple + """ + LOG.info(f"Info the resource by backing {backing_id}") + return resbacking_mgr.get_backing_info(backing_id) + + +def update_backing(backing_id, config): + """ + :param backing_id: The resource backing id + :type backing_id: string + :param config: The specified action and the snippet of + the resource's spec and meta info used for update + :type config: dict + :return: Succeeded: 0, {"out" depends on the command} + Failed: 1, {"out": error message} + :rtype: tuple + """ + LOG.info(f"Update the resource by backing {backing_id}") + return resbacking_mgr.update_backing(backing_id, config) diff --git a/virttest/vt_cluster/__init__.py b/virttest/vt_cluster/__init__.py index 2e67c2870a..d06ea40897 100644 --- a/virttest/vt_cluster/__init__.py +++ b/virttest/vt_cluster/__init__.py @@ -18,6 +18,7 @@ import os import pickle +import uuid from virttest import data_dir @@ -32,8 +33,18 @@ class _Partition(object): """The representation of the partition of the cluster.""" def __init__(self): + self._uuid = uuid.uuid4().hex + self._pools = dict() self._nodes = set() + @property + def pools(self): + return self._pools + + @property + def uuid(self): + return self._uuid + def add_node(self, node): """ Add the node into the partition. @@ -201,5 +212,17 @@ def free_nodes(self): nodes = nodes - partition.nodes return list(nodes) + @property + def partition(self): + """ + When the job starts a new process to run a case, the cluster object + will be re-constructed as a new one, it reads the dumped file to get + back all the information. Note the cluster here is a 'slice' because + this object only serves the current test case, when the process(test + case) is finished, the slice cluster is gone. So there is only one + partition object added in self._data["partition"] + """ + return self._data["partitions"][0] + cluster = _Cluster() diff --git a/virttest/vt_cluster/selector.py b/virttest/vt_cluster/selector.py index 0f2d404d23..6def9dad6c 100644 --- a/virttest/vt_cluster/selector.py +++ b/virttest/vt_cluster/selector.py @@ -21,6 +21,8 @@ import operator from . import ClusterError, cluster, node_metadata +from virttest.vt_resmgr import resmgr + LOG = logging.getLogger("avocado." + __name__) @@ -150,6 +152,71 @@ def match_node(self, free_nodes): return None +class _PoolSelector(object): + """ + nodes = node1 node2 + pools = p1 p2 + pool_selectors_p1 = [{"key": "type", "operator": "==", "values": "filesystem"}, + pool_selectors_p1 += {"key": "access.nodes", "operator": "contains", values": "node1"}, + pool_selectors_p2 = [{"key": "type", "operator": "==", "values": "filesystem"}, + pool_selectors_p2 += {"key": "access.nodes", "operator": "contains", values": "node2"}, + """ + + def __init__(self, pool_selectors): + self._pool_selectors = ast.literal_eval(pool_selectors) + self._match_expressions = [] + + for pool_selector in self._pool_selectors: + key, operator, values = self._convert(pool_selector) + self._match_expressions.append( + _MatchExpression(key, operator, values) + ) + + def _convert(self, pool_selector): + key = pool_selector.get("key") + operator = pool_selector.get("operator") + values = pool_selector.get("values") + if "access.nodes" in key: + if isinstance(values, str): + values = cluster.get_node_by_tag(values).name + elif isinstance(values, list): + values = [cluster.get_node_by_tag(tag).name for tag in values] + else: + raise ValueError(f"Unsupported values {values}") + return key, operator, values + + def _get_values(self, keys, config): + for key in keys: + if key in config: + config = config[key] + else: + raise ValueError + return config + + def match_pool(self, pools): + for pool_id in pools: + config = resmgr.query_pool(pool_id) + for match_expression in self._match_expressions: + keys = match_expression.key.split(".") + op = match_expression.operator + values = match_expression.values + config_values = None + + try: + config_values = self._get_values(keys, config["meta"]) + except ValueError: + try: + config_values = self._get_values(keys, config["spec"]) + except ValueError: + raise SelectorError(f"Cannot find {match_expression.key}") + + if not _Operator.operate(op, config_values, values): + break + else: + return pool_id + return None + + def select_node(candidates, selectors=None): """ Select the node according to the node selectors. @@ -164,3 +231,8 @@ def select_node(candidates, selectors=None): selector = _Selector(selectors) return selector.match_node(candidates) return candidates.pop() if candidates else None + + +def select_resource_pool(pools, pool_selectors): + selector = _PoolSelector(pool_selectors) + return selector.match_pool(pools) diff --git a/virttest/vt_imgr/__init__.py b/virttest/vt_imgr/__init__.py new file mode 100644 index 0000000000..abfd5e0b3e --- /dev/null +++ b/virttest/vt_imgr/__init__.py @@ -0,0 +1 @@ +from .vt_imgr import vt_imgr diff --git a/virttest/vt_imgr/images/__init__.py b/virttest/vt_imgr/images/__init__.py new file mode 100644 index 0000000000..17c41ba6ce --- /dev/null +++ b/virttest/vt_imgr/images/__init__.py @@ -0,0 +1,12 @@ +from .qemu import _QemuImage + + +_image_classes = dict() +_image_classes[_QemuImage.get_image_type()] = _QemuImage + + +def get_image_class(image_type): + return _image_classes.get(image_type) + + +__all__ = ["get_image_class"] diff --git a/virttest/vt_imgr/images/image.py b/virttest/vt_imgr/images/image.py new file mode 100644 index 0000000000..9427584932 --- /dev/null +++ b/virttest/vt_imgr/images/image.py @@ -0,0 +1,95 @@ +import collections +import uuid +from abc import ABC, abstractmethod + + +class _Image(ABC): + """ + This is the upper-level image, in the context of a VM, it's mapping + to the VM's disk. It can have one or more lower-level images, + e.g. A qemu image can have a lower-level image chain: + base ---> sn + in which "sn" is the top lower-level image name while "base" is the + backing lower-level image name of "sn" + """ + + # Supported image types: qemu + _IMAGE_TYPE = None + + def __init__(self, image_config): + self._config = image_config + self.image_meta["uuid"] = uuid.uuid4().hex + self._virt_images = collections.OrderedDict() + self._handlers = dict() + + @classmethod + def get_image_type(cls): + return cls._IMAGE_TYPE + + @property + def image_id(self): + return self.image_meta["uuid"] + + @property + def image_config(self): + return self._config + + @property + def image_meta(self): + return self.image_config["meta"] + + @property + def image_spec(self): + return self.image_config["spec"] + + @property + def image_name(self): + return self.image_meta["name"] + + @image_name.setter + def image_name(self, name): + self.image_meta["name"] = name + + def is_owner(self, vm_name): + return vm_name == self.image_meta["owner"] + + @classmethod + def _define_config_legacy(cls, image_name, params): + return { + "meta": { + "uuid": None, + "name": image_name, + "type": cls.get_image_type(), + "owner": None, + "topology": None, + }, + "spec": { + "virt-images": {}, + }, + } + + @classmethod + def define_config(cls, image_name, params): + """ + Define the image configuration by its cartesian params + """ + return cls._define_config_legacy(image_name, params) + + @abstractmethod + def create_object(self): + raise NotImplemented + + @abstractmethod + def destroy_object(self): + raise NotImplemented + + @abstractmethod + def get_info(self, request): + raise NotImplemented + + @abstractmethod + def backup(self): + raise NotImplemented + + def get_image_handler(self, cmd): + return self._handlers.get(cmd) diff --git a/virttest/vt_imgr/images/qemu/__init__.py b/virttest/vt_imgr/images/qemu/__init__.py new file mode 100644 index 0000000000..a9808db67e --- /dev/null +++ b/virttest/vt_imgr/images/qemu/__init__.py @@ -0,0 +1 @@ +from .qemu_image import _QemuImage diff --git a/virttest/vt_imgr/images/qemu/qemu_image.py b/virttest/vt_imgr/images/qemu/qemu_image.py new file mode 100644 index 0000000000..f16294b2ab --- /dev/null +++ b/virttest/vt_imgr/images/qemu/qemu_image.py @@ -0,0 +1,367 @@ +import logging +import copy + +from virttest.vt_cluster import cluster + +from ..image import _Image +from .qemu_virt_image import get_virt_image_class + + +LOG = logging.getLogger("avocado." + __name__) + + +class _QemuImage(_Image): + + # The upper-level image type + _IMAGE_TYPE = "qemu" + + def __init__(self, image_config): + super().__init__(image_config) + # Store images with the same order as tags defined in image_chain + self._handlers.update( + { + "create": self.qemu_img_create, + "destroy": self.qemu_img_destroy, + "rebase": self.qemu_img_rebase, + "commit": self.qemu_img_commit, + "snapshot": self.qemu_img_snapshot, + "add": self.add_virt_image_object, + "remove": self.remove_virt_image_object, + "info": self.qemu_img_info, + "check": self.qemu_img_check, + "backup": self.backup, + "config": self.config, + } + ) + + @classmethod + def define_virt_image_config(cls, image_name, image_params): + image_format = image_params.get("image_format", "qcow2") + virt_image_class = get_virt_image_class(image_format) + return virt_image_class.define_config(image_name, image_params) + + @classmethod + def _define_config_legacy(cls, image_name, params): + def _define_topo_chain_config(): + backing = None + for image_tag in image_chain: + image_params = params.object_params(image_tag) + virt_images[image_tag] = cls.define_virt_image_config( + image_tag, image_params + ) + if backing is not None: + virt_images[image_tag]["spec"]["backing"] = backing + backing = image_tag + + def _define_topo_none_config(): + image_params = params.object_params(image_name) + virt_images[image_name] = cls.define_virt_image_config( + image_name, image_params + ) + + config = super()._define_config_legacy(image_name, params) + virt_images = config["spec"]["virt-images"] + + owner = params.object_params(image_name).get("image_owner") + if owner: + config["meta"]["owner"] = owner + + # image_chain should be the upper-level image param + image_chain = params.object_params(image_name).objects("image_chain") + if image_chain: + # config["meta"]["topology"] = {"type": "chain", "value": image_chain} + config["meta"]["topology"] = {"chain": image_chain} + _define_topo_chain_config() + else: + # config["meta"]["topology"] = {"type": "flat", "value": [image_name]} + config["meta"]["topology"] = {"none": [image_name]} + _define_topo_none_config() + + return config + + @property + def image_access_nodes(self): + node_set = set() + for virt_image in self.virt_images.values(): + node_set.update(virt_image.virt_image_access_nodes) + return list(node_set) + + @property + def virt_images(self): + return self._virt_images + + @property + def virt_image_names(self): + if "none" in self.image_meta["topology"]: + names = self.image_meta["topology"]["none"] + elif "chain" in self.image_meta["topology"]: + names = self.image_meta["topology"]["chain"] + else: + raise ValueError("Unknown topology %s" % self.image_meta["topology"]) + return names + + def create_virt_image_object(self, virt_image_name): + config = self.image_spec["virt-images"][virt_image_name] + image_format = config["spec"]["format"] + virt_image_class = get_virt_image_class(image_format) + virt_image = virt_image_class(config) + virt_image.create_object() + return virt_image + + def create_object(self): + """ + Create the qemu image object. + All its lower-level virt image objects and their volume + objects will be created + """ + LOG.debug("Created the image object for qemu image %s", + self.image_meta["name"]) + for virt_image_name in self.virt_image_names: + self.virt_images[virt_image_name] = self.create_virt_image_object(virt_image_name) + + def destroy_virt_image_object(self, virt_image_name): + virt_image = self.virt_images.pop(virt_image_name) + virt_image.destroy_object() + + def destroy_object(self): + """ + Destroy the image object, all its lower-level image objects + will be destroyed. + """ + for virt_image_name in self.virt_image_names[::-1]: + self.destroy_virt_image_object(virt_image_name) + for virt_image_name in self.virt_images: + self.destroy_virt_image_object(virt_image_name) + + def get_info(self, request): + for virt_image in self.virt_images.values(): + virt_image.sync_volume(dict()) + + config = self.image_config + if request is not None: + for item in request.split("."): + if item in config: + config = config[item] + else: + raise ValueError(request) + else: + config = {item: config} + + return config + + + def add_virt_image_object(self, arguments): + """ + Add a lower-level virt image into the qemu image + + Create the virt image object + Update the qemu image's topology + + Note: If the virt image has a backing, then its backing must be + the topest virt image, e.g. base <-- top, add top1, top1's backing + must be top, setting top1's backing to base will lead to error. + """ + target = arguments["target"] + target_image_params = arguments['target_params'] + backing_chain = arguments.get("backing_chain", False) + node_names = arguments.get("nodes") or self.image_access_nodes + + if target in self.virt_images: + raise ValueError(f"{target} already existed") + + if not set(node_names).issubset(set(self.image_access_nodes)): + raise ValueError(f"{node_names} should be a subset of {self.image_access_nodes}") + + config = self.define_virt_image_config( + target, target_image_params + ) + + if backing_chain: + config["spec"]["backing"] = self.virt_image_names[-1] + self.virt_image_names.append(target) + self.image_meta["name"] = target + if "none" in self.image_meta["topology"]: + self.image_meta["topology"]["chain"] = self.image_meta["topology"].pop("none") + + LOG.info("Qemu image changed: name=%s, topology=%s", + self.image_meta["name"], self.image_meta["topology"]) + + self.image_spec["virt-images"][target] = config + self.virt_images[target] = self.create_virt_image_object(target) + + def remove_virt_image_object(self, arguments): + """ + Remove the lower-level virt image + + Destroy the virt image object + Update the qemu image's topology + """ + target = arguments.pop('target') + + if target not in self.virt_images: + raise ValueError(f"{target} does not exist") + + if len(self.virt_images) == 1: + raise ValueError(f"Cannot remove {target} for a qemu image " + "must have at least one lower-level image") + + if target in self.virt_image_names: + if ("chain" in self.image_meta["topology"] and + target != self.virt_image_names[-1]): + raise ValueError("Only the top virt image in topology(%s) " + "can be removed" % self.virt_image_names) + elif "none" in self.image_meta["topology"]: + raise ValueError("Removing %s in topology(%s) can cause an " + "unknown state of the image" % (target, self.virt_image_names)) + + virt_image = self.virt_images.pop(target) + if virt_image.volume_allocated: + raise RuntimeError(f"The resource of {target} isn't released yet") + + virt_image.destroy_object() + + if target in self.virt_image_names: + self.virt_image_names.remove(target) + self.image_meta["name"] = self.virt_image_names[-1] + + if len(self.virt_image_names) < 2: + self.image_meta["topology"]["none"] = self.image_meta["topology"].pop("chain") + + LOG.info("Qemu image changed: name=%s, topology=%s", + self.image_meta["name"], self.image_meta["topology"]) + + def config(self, arguments): + pass + + def backup(self, arguments): + """ + Backup the image data + + Backup all lower-level images, or backup a specified one + """ + target = arguments.pop("target", None) + image_tags = [target] if target else self.virt_image_names + + for image_tag in image_tags: + virt_image = self.virt_images[image_tag] + + def qemu_img_create(self, arguments): + """ + qemu-img create + + Allocate storage + Create lower-level virt images with qemu-img + """ + node_name = self.image_access_nodes[0] + node = cluster.get_node(node_name) + + target = arguments.get("target") + if target in self.virt_image_names: + if target != self.virt_image_names[-1]: + raise ValueError("Only the top virt image in topology(%s) " + "can be created" % self.virt_image_names) + + image_tags = [target] if target else self.virt_image_names + LOG.info("Create the qemu image %s, targets: %s", + self.image_meta["name"], image_tags) + + for image_tag in image_tags: + virt_image = self.virt_images[image_tag] + virt_image.allocate_volume(arguments) + + r, o = node.proxy.image.handle_image(self.image_config, + {"create": arguments}) + if r != 0: + raise Exception(o["out"]) + + def qemu_img_destroy(self, arguments): + """ + Release the storage + + Note all the lower-level image objects and their volume objects + will not be destroyed. + """ + target = arguments.pop("target", None) + if target in self.virt_image_names: + if target != self.virt_image_names[-1]: + raise ValueError("Only the top virt image in topology(%s) " + "can be destroyed" % self.virt_image_names) + + image_tags = [target] if target else list(self.virt_images.keys()) + LOG.info("Destroy the qemu image %s, targets: %s", + self.image_meta["name"], image_tags) + + for image_tag in image_tags: + self.virt_images[image_tag].release_volume(arguments) + + def qemu_img_rebase(self, arguments): + """ + Rebase target to the top of the qemu image + """ + target = arguments.get("target") + backing = self.virt_image_names[-1] + arguments["source"] = backing + + LOG.info(f"Rebase lower-level image {target} onto {backing}") + add_args = { + "target": arguments["target"], + "target_params": arguments.pop("target_params"), + "nodes": arguments.pop("nodes", None), + } + self.add_virt_image_object(add_args) + + create_args = { + "target": target, + } + self.qemu_img_create(create_args) + + node_name = self.image_access_nodes[0] + node = cluster.get_node(node_name) + r, o = node.proxy.image.handle_image(self.image_config, + {"rebase": arguments}) + if r != 0: + raise Exception(o["out"]) + + self.image_meta["name"] = target + self.virt_image_names.append(target) + if "none" in self.image_meta["topology"]: + self.image_meta["topology"]["chain"] = self.image_meta["topology"].pop("none") + config = self.image_spec["virt-images"][target] + config["spec"]["backing"] = backing + + LOG.info("Qemu image changed: name=%s, topology=%s", + self.image_meta["name"], self.image_meta["topology"]) + + def qemu_img_commit(self, arguments): + node_name = self.image_access_nodes[0] + node = cluster.get_node(node_name) + r, o = node.proxy.image.handle_image(self.image_config, + {"commit": arguments}) + if r != 0: + raise Exception(o["out"]) + + def qemu_img_snapshot(self, arguments): + node_name = self.image_access_nodes[0] + node = cluster.get_node(node_name) + r, o = node.proxy.image.handle_image(self.image_config, + {"snapshot": arguments}) + if r != 0: + raise Exception(o["out"]) + + def qemu_img_info(self, arguments): + node_name = self.image_access_nodes[0] + node = cluster.get_node(node_name) + r, o = node.proxy.image.handle_image(self.image_config, + {"info": arguments}) + if r != 0: + raise Exception(o["out"]) + return o["out"] + + def qemu_img_check(self, arguments): + node_name = self.image_access_nodes[0] + node = cluster.get_node(node_name) + r, o = node.proxy.image.handle_image(self.image_config, + {"check": arguments}) + if r != 0: + raise Exception(o["out"]) + return o["out"] diff --git a/virttest/vt_imgr/images/qemu/qemu_virt_image/__init__.py b/virttest/vt_imgr/images/qemu/qemu_virt_image/__init__.py new file mode 100644 index 0000000000..085c06048a --- /dev/null +++ b/virttest/vt_imgr/images/qemu/qemu_virt_image/__init__.py @@ -0,0 +1,16 @@ +from .raw_qemu_virt_image import _RawQemuVirtImage +from .qcow2_qemu_virt_image import _Qcow2QemuVirtImage +from .luks_qemu_virt_image import _LuksQemuVirtImage + + +_image_classes= dict() +_image_classes[_RawQemuVirtImage.get_virt_image_format()] = _RawQemuVirtImage +_image_classes[_Qcow2QemuVirtImage.get_virt_image_format()] = _Qcow2QemuVirtImage +_image_classes[_LuksQemuVirtImage.get_virt_image_format()] = _LuksQemuVirtImage + + +def get_virt_image_class(virt_image_format): + return _image_classes.get(virt_image_format) + + +__all__ = ['get_virt_image_class'] diff --git a/virttest/vt_imgr/images/qemu/qemu_virt_image/luks_qemu_virt_image.py b/virttest/vt_imgr/images/qemu/qemu_virt_image/luks_qemu_virt_image.py new file mode 100644 index 0000000000..79f468152a --- /dev/null +++ b/virttest/vt_imgr/images/qemu/qemu_virt_image/luks_qemu_virt_image.py @@ -0,0 +1,31 @@ +import os + +from virttest.utils_misc import generate_random_string +from virttest.data_dir import get_tmp_dir + +from .qemu_virt_image import _QemuVirtImage + + +class _LuksQemuVirtImage(_QemuVirtImage): + _VIRT_IMAGE_FORMAT = "luks" + + @classmethod + def _define_config_legacy(cls, image_name, image_params): + config = super()._define_config_legacy(image_name, image_params) + spec = config["spec"] + spec.update({ + "preallocation": image_params.get("preallocated"), + "extent_size_hint": image_params.get("image_extent_size_hint"), + }) + + name = "secret_{s}".format(s=generate_random_string(6)) + spec["encryption"] = { + "name": name, + "data": image_params.get("image_secret", "redhat"), + "format": image_params.get("image_secret_format", "raw"), + } + + if image_params.get("image_secret_storage", "data") == "file": + spec["encryption"]["file"] = os.path.join(get_tmp_dir(), name) + + return config diff --git a/virttest/vt_imgr/images/qemu/qemu_virt_image/qcow2_qemu_virt_image.py b/virttest/vt_imgr/images/qemu/qemu_virt_image/qcow2_qemu_virt_image.py new file mode 100644 index 0000000000..d4bd19e831 --- /dev/null +++ b/virttest/vt_imgr/images/qemu/qemu_virt_image/qcow2_qemu_virt_image.py @@ -0,0 +1,40 @@ +import os + +from virttest.utils_misc import generate_random_string +from virttest.data_dir import get_tmp_dir + +from .qemu_virt_image import _QemuVirtImage + + +class _Qcow2QemuVirtImage(_QemuVirtImage): + + _VIRT_IMAGE_FORMAT = "qcow2" + + @classmethod + def _define_config_legacy(cls, image_name, image_params): + config = super()._define_config_legacy(image_name, image_params) + spec = config["spec"] + spec.update({ + "cluster-size": image_params.get("image_cluster_size"), + "lazy-refcounts": image_params.get("lazy_refcounts"), + "compat": image_params.get("qcow2_compatible"), + "preallocation": image_params.get("preallocated"), + "extent_size_hint": image_params.get("image_extent_size_hint"), + "compression_type": image_params.get("image_compression_type"), + }) + + name = "secret_{s}".format(s=generate_random_string(6)) + if image_params.get("image_encryption"): + spec["encryption"] = { + "name": name, + "data": image_params.get("image_secret", "redhat"), + "format": image_params.get("image_secret_format", "raw"), + "encrypt": { + "format": image_params.get("image_encryption", "luks"), + }, + } + + if image_params.get("image_secret_storage", "data") == "file": + spec["encryption"]["file"] = os.path.join(get_tmp_dir(), name) + + return config diff --git a/virttest/vt_imgr/images/qemu/qemu_virt_image/qemu_virt_image.py b/virttest/vt_imgr/images/qemu/qemu_virt_image/qemu_virt_image.py new file mode 100644 index 0000000000..3c398d6f1c --- /dev/null +++ b/virttest/vt_imgr/images/qemu/qemu_virt_image/qemu_virt_image.py @@ -0,0 +1,58 @@ +import logging +from abc import abstractmethod + +from ...virt_image import _VirtImage +from virttest.vt_resmgr import resmgr + + +LOG = logging.getLogger("avocado." + __name__) + + +class _QemuVirtImage(_VirtImage): + """ + A virt image has one storage resource(volume), take qemu virt image + as an example, the cartesian params beginning with 'image_', e.g. + 'image_size' describe this object + """ + + @classmethod + def _define_config_legacy(cls, image_name, image_params): + config = super()._define_config_legacy(image_name, + image_params) + config["spec"].update({ + "backing": None, + "volume": resmgr.define_resource_config(image_name, + "volume", + image_params), + }) + + return config + + def info(self): + pass + + def keep(self): + pass + + def create_object(self): + LOG.debug(f"Create the virt image object for '{self.virt_image_name}'") + volume_config = self.virt_image_spec["volume"] + volume_id = resmgr.create_resource_object(volume_config) + resmgr.update_resource(volume_id, {"bind": dict()}) + + def destroy_object(self): + LOG.debug(f"Destroy the virt image object for '{self.virt_image_name}'") + resmgr.update_resource(self.volume_id, {"unbind": dict()}) + resmgr.destroy_resource_object(self.volume_id) + + def sync_volume(self, arguments): + LOG.debug(f"Sync up the volume conf for '{self.virt_image_name}'") + resmgr.update_resource(self.volume_id, {"sync": arguments}) + + def allocate_volume(self, arguments): + LOG.debug(f"Allocate the volume for '{self.virt_image_name}'") + resmgr.update_resource(self.volume_id, {"allocate": arguments}) + + def release_volume(self, arguments): + LOG.debug(f"Release the volume for '{self.virt_image_name}'") + resmgr.update_resource(self.volume_id, {"release": arguments}) diff --git a/virttest/vt_imgr/images/qemu/qemu_virt_image/raw_qemu_virt_image.py b/virttest/vt_imgr/images/qemu/qemu_virt_image/raw_qemu_virt_image.py new file mode 100644 index 0000000000..b6fb55deae --- /dev/null +++ b/virttest/vt_imgr/images/qemu/qemu_virt_image/raw_qemu_virt_image.py @@ -0,0 +1,17 @@ +from .qemu_virt_image import _QemuVirtImage + + +class _RawQemuVirtImage(_QemuVirtImage): + + _VIRT_IMAGE_FORMAT = "raw" + + @classmethod + def _define_config_legacy(cls, image_name, image_params): + config = super()._define_config_legacy(image_name, image_params) + spec = config["spec"] + spec.update({ + "preallocation": image_params.get("preallocated"), + "extent_size_hint": image_params.get("image_extent_size_hint"), + }) + + return config diff --git a/virttest/vt_imgr/images/virt_image.py b/virttest/vt_imgr/images/virt_image.py new file mode 100644 index 0000000000..f1e745533b --- /dev/null +++ b/virttest/vt_imgr/images/virt_image.py @@ -0,0 +1,96 @@ +from abc import ABC, abstractmethod + + +class _VirtImage(ABC): + """ + The lower-level image, which has a storage resource(volume), is + defined by the cartesian params beginning with 'image_'. One or + more lower-level images can represent a upper-level image. + """ + + _VIRT_IMAGE_FORMAT = None + + def __init__(self, config): + self._config = config + self._backup_volumes = dict() + + @classmethod + def get_virt_image_format(cls): + return cls._VIRT_IMAGE_FORMAT + + @classmethod + def _define_config_legacy(cls, image_name, image_params): + return { + "meta": { + "name": image_name, + }, + "spec": { + "format": cls.get_virt_image_format(), + "volume": {}, + }, + } + + @classmethod + def define_config(cls, image_name, image_params): + """ + Define the virt image configuration by its cartesian params. + Currently use the existing image params, in future, we'll + design a new set of params to describe a lower-level image. + """ + return cls._define_config_legacy(image_name, image_params) + + @property + def volume_id(self): + return self.virt_image_spec["volume"]["meta"]["uuid"] + + @property + def virt_image_access_nodes(self): + volume_config = self.virt_image_spec["volume"] + bindings = volume_config["meta"]["bindings"] + return list(bindings.keys()) + + @property + def virt_image_name(self): + return self.virt_image_meta["name"] + + @property + def virt_image_config(self): + return self._config + + @property + def virt_image_spec(self): + return self.virt_image_config["spec"] + + @property + def virt_image_meta(self): + return self.virt_image_config["meta"] + + @property + @abstractmethod + def keep(self): + raise NotImplemented + + @abstractmethod + def create_object(self): + raise NotImplemented + + @abstractmethod + def destroy_object(self): + raise NotImplemented + + @abstractmethod + def info(self): + raise NotImplemented + + @abstractmethod + def allocate_volume(self, arguments): + raise NotImplemented + + @abstractmethod + def release_volume(self, arguments): + raise NotImplemented + + @property + def volume_allocated(self): + volume_config = self.virt_image_spec["volume"] + return volume_config["meta"]["allocated"] diff --git a/virttest/vt_imgr/vt_imgr.py b/virttest/vt_imgr/vt_imgr.py new file mode 100644 index 0000000000..745be0fc46 --- /dev/null +++ b/virttest/vt_imgr/vt_imgr.py @@ -0,0 +1,240 @@ +""" +The upper-level image manager. + +from virttest.vt_imgr import vt_imgr + +# Define the image configuration +image_config = vt_imgr.define_image_config(image_name, params) + +# Create the upper-level image object +image_id = vt_imgr.create_image_object(image_config) + +# Create the upper-level image +vt_imgr.handle_image(image_id, {"create":{}}) + +# Create only one lower-level image +vt_imgr.handle_image(image_id, {"create":{"target": "top"}}) + +# Destroy one lower-level image +vt_imgr.handle_image(image_id, {"destroy":{"target": "top"}}) + +# Get the configuration of the upper-level image +out = vt_imgr.get_image_info(image_id, request=None) +out: +{ + "meta": { + "uuid": "uuid-sn" + "name": "sn", + "type": "qemu", + "topology": {"chain": ["base", "sn"]} + }, + "spec": { + "virt-images": { + "base": { + "meta": {}, + "spec": { + "format": "raw", + "volume": {"meta": {}, "spec": {}}} + }, + "sn": { + "meta": {}, + "spec": { + "format": "qcow2", + "volume": {"meta": {}, "spec": {}}} + } + } + } +} + +# Destroy the upper-level image +vt_imgr.handle_image(image_id, {"destroy":{}}) + +# Destroy the upper-level image object +vt_imgr.destroy_image_object(image_id) +""" +import logging + +from .images import get_image_class +from virttest.vt_cluster import cluster + +LOG = logging.getLogger("avocado." + __name__) + + +# TODO: +# Add drivers for diff handlers +# Add access permission for images +# serialize +class _VTImageManager(object): + + def __init__(self): + self._images = dict() + + def startup(self): + LOG.info(f"Start the image manager") + + def teardown(self): + LOG.info(f"Stop the image manager") + + def define_image_config(self, image_name, params): + """ + Define the upper-level image(e.g. in the context of a VM, it's + mapping to a VM's disk) configuration by its cartesian params. + E.g. An upper-level qemu image has an lower-level image chain + base ---> sn + | | + resource resource + :param image_name: The image tag defined in cartesian params, + e.g. for a qemu image, the tag should be the + top image("sn" in the example above) if the + "image_chain" is defined, usually it is + defined in the "images" param, e.g. "image1" + :type image_name: string + :param params: The params for all the lower-level images + Note it's *NOT* an image-specific params like + params.object_params("sn") + *BUT* the params for both "sn" and "base" + Examples: + 1. images_vm1 = "image1 sn" + image_chain_sn = "base sn" + image_name = "sn" + params = the_case_params.object_params('vm1') + 2. images = "image1 stg" + image_name = "image1" + params = the_case_params + :type params: Params + :return: The image configuration + :rtype: dict + """ + image_params = params.object_params(image_name) + image_type = image_params.get("image_type", "qemu") + image_class = get_image_class(image_type) + + LOG.debug(f"Define the {image_type} image configuration for {image_name}") + return image_class.define_config(image_name, params) + + def create_image_object(self, image_config): + """ + Create an upper-level image(e.g. in the context of a VM, it's + mapping to a VM's disk) object by its configuration without + any storage allocation. All its lower-level images and their + mapping storage resource objects will be created. + :param image_config: The image configuration. + Call define_image_config to get it. + :type image_config: dict + :return: The image object id + :rtype: string + """ + image_type = image_config["meta"]["type"] + image_class = get_image_class(image_type) + image = image_class(image_config) + image.create_object() + self._images[image.image_id] = image + + LOG.debug("Created the image object %s for %s", + image.image_id, image.image_name) + return image.image_id + + def destroy_image_object(self, image_id): + """ + Destroy a specified image. All its storage allocation should + be released. + + :param image_id: The image id + :type image_id: string + """ + LOG.debug(f"Destroy the image object {image_id}") + image = self._images.pop(image_id) + image.destroy_object() + + + def handle_image(self, image_id, config): + """ + Update a specified upper-level image + + config format: + {command: arguments} + + Supported commands for a qemu image: + create: qemu-img create + destroy: Destroy the specified lower-level images + resize: qemu-img resize + map: qemu-img map + convert: qemu-img convert + commit: qemu-img commit + snapshot: qemu-img snapshot + rebase: qemu-img rebase + info: qemu-img info + check: qemu-img check + add: Add a lower-level image object + delete: Delete a lower-level image object + backup: Backup a qemu image + compare: Comare two qemu images + config: Update the static configurations + + Note: Not all images support the above operations + The arguments is a dict object which contains all related settings + for a specific command + :param image_id: The image id + :type image_id: string + """ + cmd, arguments = config.popitem() + image = self._images.get(image_id) + image_handler = image.get_image_handler(cmd) + + node_tags = arguments.pop("nodes", list()) + node_names = [cluster.get_node_by_tag(tag).name for tag in node_tags] + if node_names: + arguments["nodes"] = node_names + + LOG.debug(f"Handle the image object {image_id} with cmd {cmd}") + return image_handler(arguments) + + def get_image_info(self, image_id, request=None): + """ + Get the configuration of a specified upper-level image + + :param request: The query content, format: + None + meta[.] + spec[.virt-images.[.meta[.]]] + spec[.virt-images.[.spec[.]]] + Examples: + 1. Get the image's configuration + request=None + 2. Get the lower-level images' configurations + request=spec.virt-images + 3. Get sn's volume configuration + request=spec.virt-images.sn.spec.volume + :type request: string + :return: The configuration + :rtype: dict + """ + LOG.debug(f"Get the image object {image_id} with request {request}") + image = self._images.get(image_id) + return image.get_info(request) + + def query_image(self, image_name, vm_name=None): + """ + Get the image object id + + Note: The partition id is not required because only one + partition is created when running a test case + + :param image_name: The image tag defined in 'images' + :type image_name: string + :param vm_name: The vm tag defined in 'vms' + :type vm_name: string + :return: The image object id + :rtype: string + """ + for image in self._images.values(): + if image_name == image.image_name: + if vm_name is not None: + if image.is_owner(vm_name): + return image.image_id + else: + return image.image_id + return None + + +vt_imgr = _VTImageManager() diff --git a/virttest/vt_resmgr/__init__.py b/virttest/vt_resmgr/__init__.py new file mode 100644 index 0000000000..bcfbc1478b --- /dev/null +++ b/virttest/vt_resmgr/__init__.py @@ -0,0 +1 @@ +from .vt_resmgr import resmgr diff --git a/virttest/vt_resmgr/resources/__init__.py b/virttest/vt_resmgr/resources/__init__.py new file mode 100644 index 0000000000..7455113694 --- /dev/null +++ b/virttest/vt_resmgr/resources/__init__.py @@ -0,0 +1,19 @@ +#from .cvm import _SnpPool +#from .cvm import _TdxPool +#from .storage import _CephPool +from .storage import _DirPool +from .storage import _NfsPool + +_pool_classes = dict() +#_pool_classes[_SnpPool.get_pool_type()] = _SnpPool +#_pool_classes[_TdxPool.get_pool_type()] = _TdxPool +#_pool_classes[_CephPool.get_pool_type()] = _CephPool +_pool_classes[_DirPool.get_pool_type()] = _DirPool +_pool_classes[_NfsPool.get_pool_type()] = _NfsPool + + +def get_resource_pool_class(pool_type): + return _pool_classes.get(pool_type) + + +__all__ = ["get_resource_pool_class"] diff --git a/virttest/vt_resmgr/resources/cvm/__init__.py b/virttest/vt_resmgr/resources/cvm/__init__.py new file mode 100644 index 0000000000..0a0e47b0b0 --- /dev/null +++ b/virttest/vt_resmgr/resources/cvm/__init__.py @@ -0,0 +1 @@ +from .api import * diff --git a/virttest/vt_resmgr/resources/pool.py b/virttest/vt_resmgr/resources/pool.py new file mode 100644 index 0000000000..c39346075a --- /dev/null +++ b/virttest/vt_resmgr/resources/pool.py @@ -0,0 +1,178 @@ +import uuid +from copy import deepcopy +from abc import ABC, abstractmethod + +from virttest.vt_cluster import cluster + + +class _ResourcePool(ABC): + """ + A resource pool is used to manage resources. A resource must be + allocated from a specific pool, and a pool can hold many resources + """ + + _POOL_TYPE = None + + def __init__(self, pool_config): + self._config = pool_config + self.pool_meta["uuid"] = uuid.uuid4().hex + self._resources = dict() # {resource id: resource object} + self._caps = dict() + + if not set(self.attaching_nodes).difference(set(["*"])): + self.attaching_nodes = [n.name for n in cluster.get_all_nodes()] + + @property + def pool_name(self): + return self.pool_meta["name"] + + @property + def pool_id(self): + return self.pool_meta["uuid"] + + @property + def pool_config(self): + return self._config + + @property + def pool_meta(self): + return self._config["meta"] + + @property + def pool_spec(self): + return self._config["spec"] + + @property + def resources(self): + return self._resources + + @classmethod + def define_config(cls, pool_name, pool_params): + access = pool_params.get("access", {}) + return { + "meta": { + "name": pool_name, + "uuid": None, + "type": pool_params["type"], + "access": access, + }, + "spec": {}, + } + + def update_config(self, pool_config): + pass + + def get_info(self, request): + config = self.pool_config + if request is not None: + for item in request.split("."): + if item in config: + config = config[item] + else: + raise ValueError(request) + else: + config = {item: config} + + return deepcopy(config) + + @abstractmethod + def meet_resource_request(self, resource_type, resource_params): + """ + Check if the pool can support a resource's allocation + """ + raise NotImplementedError + + def define_resource_config(self, resource_name, resource_type, resource_params): + """ + Define the resource configuration, format: + {"meta": {...}, "spec": {...}} + It depends on the specific resource. + """ + res_cls = self.get_resource_class(resource_type) + config = res_cls.define_config(resource_name, resource_params) + + node_tags = resource_params.objects("vm_node") or resource_params.objects("nodes") + node_names = [cluster.get_node_by_tag(tag).name for tag in node_tags] + config["meta"].update( + { + "pool": self.pool_config, + "bindings": {node: None for node in node_names}, + } + ) + + return config + + @classmethod + @abstractmethod + def get_resource_class(cls, resource_type): + raise NotImplementedError + + def create(self): + pass + + def destroy(self): + pass + + def create_resource_object(self, resource_config): + """ + Create a resource object, no real resource allocated + """ + meta = resource_config["meta"] + res_cls = self.get_resource_class(meta["type"]) + res = res_cls(resource_config) + res.create() + self.resources[res.resource_id] = res + return res.resource_id + + def destroy_resource_object(self, resource_id): + """ + Destroy the resource object, all its backings should be released + """ + res = self.resources[resource_id] + res.destroy() + del(self.resources[resource_id]) + + def update_resource(self, resource_id, config): + resource = self.resources.get(resource_id) + cmd, arguments = config.popitem() + + # For the user specified nodes, we need to check if the pool + # can be accessed from these nodes + node_tags = arguments.pop("nodes") + if node_tags: + node_names = [cluster.get_node_by_tag(tag).name for tag in node_tags] + if not set(node_names).issubset(set(self.attaching_nodes)): + raise ValueError(f"Not all nodes({node_names}) can access the pool {self.pool_id}") + arguments["nodes"] = node_names + + handler = resource.get_update_handler(cmd) + handler(arguments) + + def get_resource_info(self, resource_id, request): + """ + Get the reference of a specified resource + """ + res = self.resources.get(resource_id) + return res.get_info(request) + + @property + def attaching_nodes(self): + return self.pool_meta["access"].get("nodes") + + @attaching_nodes.setter + def attaching_nodes(self, nodes): + self.pool_meta["access"]["nodes"] = nodes + + """ + @property + def pool_capability(self): + node_name = self.attaching_nodes[0] + node = cluster.get_node(node_name) + r, o = node.proxy.resource.get_pool_capability() + if r != 0: + raise Exception(o["out"]) + """ + + @classmethod + def get_pool_type(cls): + return cls._POOL_TYPE diff --git a/virttest/vt_resmgr/resources/resource.py b/virttest/vt_resmgr/resources/resource.py new file mode 100644 index 0000000000..7d58cc69e2 --- /dev/null +++ b/virttest/vt_resmgr/resources/resource.py @@ -0,0 +1,135 @@ +import uuid +from copy import deepcopy + +from abc import ABC, abstractmethod + + +class _Resource(ABC): + """ + A resource defines what users request, it's independent of a VM, + users can request kinds of resources for any purpose. The resource + can be bound to several backings on different worker nodes. + + Note: A resource can bind to only one backing on a worker node. + """ + + _RESOURCE_TYPE = None + + def __init__(self, resource_config): + self._config = resource_config + self.resource_meta["uuid"] = uuid.uuid4().hex + self._handlers = { + "bind": self.bind, + "unbind": self.unbind, + "allocate": self.allocate, + "release": self.release, + "sync": self.sync, + } + + @classmethod + def resource_type(cls): + raise cls._RESOURCE_TYPE + + @property + def resource_config(self): + return self._config + + @property + def resource_spec(self): + return self.resource_config["spec"] + + @property + def resource_meta(self): + return self.resource_config["meta"] + + @property + def resource_id(self): + return self.resource_meta["uuid"] + + @property + def resource_pool(self): + return self.resource_meta["pool"]["meta"]["uuid"] + + @property + def resource_bindings(self): + return self.resource_meta["bindings"] + + @classmethod + def _define_config_legacy(cls, resource_name, resource_params): + return { + "meta": { + "name": resource_name, + "uuid": None, + "type": None, + "pool": None, + "allocated": False, + "bindings": dict(), + }, + "spec": {}, + } + + @classmethod + def define_config(cls, resource_name, resource_params): + return cls._define_config_legacy(resource_name, resource_params) + + @property + def backing_config(self): + """ + Define the required information of the resource, used + for allocating the resource on the worker nodes + """ + return self.resource_config + #config = dict() + #config["uuid"] = self.resource_id + #config["pool"] = self.resource_pool + #config["type"] = self.resource_type + #return config + + def get_update_handler(self, command): + return self._handlers.get(command) + + @abstractmethod + def bind(self, arguments): + """ + Bind the resource to one or more worker nodes + """ + raise NotImplemented + + @abstractmethod + def unbind(self, arguments): + raise NotImplemented + + @abstractmethod + def allocate(self, arguments): + raise NotImplemented + + @abstractmethod + def release(self, arguments): + raise NotImplemented + + def get_info(self, request): + r, o = self.sync(dict()) + if r != 0: + raise Exception(o["out"]) + + config = self.resource_config + if request is not None: + for item in request.split("."): + if item in config: + config = config[item] + else: + raise ValueError(request) + else: + config = {item: config} + + return deepcopy(config) + + @abstractmethod + def sync(self, arguments): + raise NotImplemented + + def create(self): + pass + + def destroy(self): + pass diff --git a/virttest/vt_resmgr/resources/storage/__init__.py b/virttest/vt_resmgr/resources/storage/__init__.py new file mode 100644 index 0000000000..3f20ff6f5d --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/__init__.py @@ -0,0 +1,14 @@ +from .dir import _DirPool +from .nfs import _NfsPool +#from .ceph import _CephPool +#from .nbd import _NbdPool +#from .iscsi_direct import _IscsiDirectPool + + +__all__ = ( +# _CephPool, + _DirPool, + _NfsPool, +# _NbdPool, +# _IscsiDirectPool, +) diff --git a/virttest/vt_resmgr/resources/storage/ceph/__init__.py b/virttest/vt_resmgr/resources/storage/ceph/__init__.py new file mode 100644 index 0000000000..8ec3b25a7a --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/ceph/__init__.py @@ -0,0 +1 @@ +from .ceph_pool import _CephPool diff --git a/virttest/vt_resmgr/resources/storage/dir/__init__.py b/virttest/vt_resmgr/resources/storage/dir/__init__.py new file mode 100644 index 0000000000..c09faaf942 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/dir/__init__.py @@ -0,0 +1 @@ +from .dir_pool import _DirPool diff --git a/virttest/vt_resmgr/resources/storage/dir/dir_pool.py b/virttest/vt_resmgr/resources/storage/dir/dir_pool.py new file mode 100644 index 0000000000..e7b654319a --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/dir/dir_pool.py @@ -0,0 +1,75 @@ +import logging +import os + +from ...pool import _ResourcePool +from .dir_resources import get_dir_resource_class + +from virttest.data_dir import get_data_dir +from virttest.vt_cluster import cluster + + +LOG = logging.getLogger("avocado." + __name__) + + +class _DirPool(_ResourcePool): + _POOL_TYPE = "filesystem" + _POOL_DEFAULT_DIR = "/home/kvm_autotest_root" + + @classmethod + def define_default_config(cls): + """ + We'll define a default filesystem pool if it is not defined by user + """ + pool_name = "dir_pool_default" + pool_params = { + "type": cls._POOL_TYPE, + "path": cls._POOL_DEFAULT_DIR, + "access": { + "nodes": list(), + } + } + return cls.define_config(pool_name, pool_params) + + @classmethod + def define_config(cls, pool_name, pool_params): + config = super().define_config(pool_name, pool_params) + path = pool_params.get("path") or os.path.join(get_data_dir(), "images") + config["spec"]["path"] = path + return config + + @classmethod + def get_resource_class(cls, resource_type): + return get_dir_resource_class(resource_type) + + def meet_resource_request(self, resource_type, resource_params): + # Specify a pool + pool_tag = resource_params.get("image_pool_name") + if pool_tag: + pool_id = cluster.partition.pools.get(pool_tag) + return True if pool_id == self.pool_id else False + + # Check if this is the pool with the specified type + if resource_params.get("storage_type", "filesystem") != self.get_pool_type(): + return False + + # Note if you want the image is created from a specific pool or + # the image is handled on a specific worker node, you should + # specify its image_pool_name + vm_node_tag = resource_params.get("vm_node") + if vm_node_tag: + # Check if the pool can be accessed by the vm nodes + vm_node_name = cluster.get_node_by_tag(vm_node_tag) + if vm_node_name not in self.attaching_nodes: + return False + else: + # Check if the pool can be accessed by one of the partition nodes + node_names = [node.name for node in cluster.partition.nodes] + if not set(self.attaching_nodes).intersection(set(node_names)): + return False + + # Check if the pool can support a specific resource + if not self.get_resource_class(resource_type): + return False + + # TODO: Check if the pool has capacity to allocate the resource + return True diff --git a/virttest/vt_resmgr/resources/storage/dir/dir_resources.py b/virttest/vt_resmgr/resources/storage/dir/dir_resources.py new file mode 100644 index 0000000000..8513de2b14 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/dir/dir_resources.py @@ -0,0 +1,109 @@ +import logging + +from virttest.utils_numeric import normalize_data_size +from virttest.vt_cluster import cluster + +from ..volume import _FileVolume + + +LOG = logging.getLogger("avocado." + __name__) + + +class _DirFileVolume(_FileVolume): + """ + The directory file-based volume + """ + + def bind(self, arguments): + """ + Bind the resource to a backing on a worker node. + Note: A local dir resource has one and only one binding in the cluster + """ + node_name, backing_id = list(self.resource_bindings.items())[0] + if backing_id: + LOG.warning(f"The dir volume {self.resource_id} has already bound to {node_name}") + else: + nodes = arguments.pop("nodes", [node_name]) + LOG.info(f"Bind the dir volume {self.resource_id} to {nodes[0]}") + node = cluster.get_node(nodes[0]) + r, o = node.proxy.resource.create_backing_object(self.resource_config) + if r != 0: + raise Exception(o["out"]) + self.resource_bindings[nodes[0]] = o["out"] + + def unbind(self, arguments): + """ + Unbind the resource from a worker node. + Note: A dir resource must be released before unbinding + because it has only one binding + """ + node_name, backing_id = list(self.resource_bindings.items())[0] + LOG.info(f"Unbind the dir volume {self.resource_id} from {node_name}") + node = cluster.get_node(node_name) + r, o = node.proxy.resource.destroy_backing_object(backing_id) + if r != 0: + raise Exception(o["out"]) + self.resource_bindings[node_name] = None + + def sync(self, arguments): + LOG.debug(f"Sync up the configuration of the dir volume {self.resource_id}") + node_name, backing_id = list(self.resource_bindings.items())[0] + node = cluster.get_node(node_name) + r, o = node.proxy.resource.update_backing(backing_id, + {"sync": arguments}) + if r != 0: + raise Exception(o["out"]) + + config = o["out"] + self.resource_meta["allocated"] = config["meta"]["allocated"] + self.resource_spec["uri"] = config["spec"]["uri"] + self.resource_spec["allocation"] = config["spec"]["allocation"] + + def allocate(self, arguments): + node_name, backing_id = list(self.resource_bindings.items())[0] + LOG.debug(f"Allocate the dir volume {self.resource_id} from {node_name}.") + node = cluster.get_node(node_name) + r, o = node.proxy.resource.update_backing(backing_id, + {"allocate": arguments}) + if r != 0: + raise Exception(o["out"]) + + config = o["out"] + self.resource_meta["allocated"] = config["meta"]["allocated"] + self.resource_spec["uri"] = config["spec"]["uri"] + self.resource_spec["allocation"] = config["spec"]["allocation"] + + def release(self, arguments): + node_name, backing_id = list(self.resource_bindings.items())[0] + node = cluster.get_node(node_name) + LOG.debug(f"Release the dir volume {self.resource_id} from {node_name}") + r, o = node.proxy.resource.update_backing(backing_id, + {"release": arguments}) + if r != 0: + raise Exception(o["error"]) + self.resource_meta["allocated"] = False + self.resource_spec["allocation"] = 0 + + def resize(self, arguments): + """ + Resize the local dir volume resource + """ + new = int(normalize_data_size(arguments["size"], "B")) + if new != self.resource_spec["size"]: + node_name, backing_id = list(self.resource_bindings.items())[0] + LOG.debug(f"Resize the dir volume {self.resource_id} from {node_name}") + node = cluster.get_node(node_name) + r, o = node.proxy.resource.update_backing(backing_id, {"resize": arguments}) + if r != 0: + raise Exception(o["error"]) + self.resource_spec["size"] = new + else: + LOG.debug(f"New size {new} is the same with the original") + + +def get_dir_resource_class(resource_type): + mapping = { + "volume": _DirFileVolume, + } + + return mapping.get(resource_type) diff --git a/virttest/vt_resmgr/resources/storage/iscsi_direct/__init__.py b/virttest/vt_resmgr/resources/storage/iscsi_direct/__init__.py new file mode 100644 index 0000000000..4631b968fa --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/iscsi_direct/__init__.py @@ -0,0 +1 @@ +from .iscsi_direct_pool import _IscsiDirectPool diff --git a/virttest/vt_resmgr/resources/storage/iscsi_direct/iscsi_direct_pool.py b/virttest/vt_resmgr/resources/storage/iscsi_direct/iscsi_direct_pool.py new file mode 100644 index 0000000000..33738d1af9 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/iscsi_direct/iscsi_direct_pool.py @@ -0,0 +1,20 @@ +import logging + +from ...resource import _Resource +from ...pool import _ResourcePool + + +LOG = logging.getLogger("avocado." + __name__) + + +class _IscsiDirectResource(_Resource): + """ + The iscsi-direct pool resource + """ + + def _initialize(self, config): + self._lun = config["lun"] + + +class _IscsiDirectPool(_ResourcePool): + POOL_TYPE = "iscsi-direct" diff --git a/virttest/vt_resmgr/resources/storage/nbd/__init__.py b/virttest/vt_resmgr/resources/storage/nbd/__init__.py new file mode 100644 index 0000000000..8a29e248f3 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/nbd/__init__.py @@ -0,0 +1 @@ +from .nbd_pool import _NbdPool diff --git a/virttest/vt_resmgr/resources/storage/nfs/__init__.py b/virttest/vt_resmgr/resources/storage/nfs/__init__.py new file mode 100644 index 0000000000..a0e90ec573 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/nfs/__init__.py @@ -0,0 +1 @@ +from .nfs_pool import _NfsPool diff --git a/virttest/vt_resmgr/resources/storage/nfs/nfs_pool.py b/virttest/vt_resmgr/resources/storage/nfs/nfs_pool.py new file mode 100644 index 0000000000..ae1da90c44 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/nfs/nfs_pool.py @@ -0,0 +1,67 @@ +import logging +import os + +from ...pool import _ResourcePool +from .nfs_resources import get_nfs_resource_class + +from virttest.data_dir import get_shared_dir +from virttest.utils_misc import generate_random_string +from virttest.vt_cluster import cluster + + +LOG = logging.getLogger("avocado." + __name__) + + +class _NfsPool(_ResourcePool): + _POOL_TYPE = "nfs" + + @classmethod + def define_config(cls, pool_name, pool_params): + config = super().define_config(pool_name, pool_params) + config["spec"].update( + { + "server": pool_params["nfs_server_ip"], + "export": pool_params["nfs_mount_src"], + "mount-options": pool_params.get("nfs_mount_options"), + "mount": pool_params.get("nfs_mount_dir", + os.path.join(get_shared_dir(), generate_random_string(6))) + } + ) + return config + + @classmethod + def get_resource_class(cls, resource_type): + return get_nfs_resource_class(resource_type) + + def meet_resource_request(self, resource_type, resource_params): + # Specify a pool + pool_tag = resource_params.get("image_pool_name") + if pool_tag: + pool_id = cluster.partition.pools.get(pool_tag) + return True if pool_id == self.pool_id else False + + # Check if this is the pool with the specified type + if resource_params.get("storage_type") != self.get_pool_type(): + return False + + # Note if you want the image is created from a specific pool or + # the image is handled on a specific worker node, you should + # specify its image_pool_name + vm_node_tag = resource_params.get("vm_node") + if vm_node_tag: + # Check if the pool can be accessed by the vm nodes + vm_node_name = cluster.get_node_by_tag(vm_node_tag) + if vm_node_name not in self.attaching_nodes: + return False + else: + # Check if the pool can be accessed by one of the partition nodes + node_names = [node.name for node in cluster.partition.nodes] + if not set(self.attaching_nodes).intersection(set(node_names)): + return False + + # Check if the pool can support a specific resource + if not self.get_resource_class(resource_type): + return False + + # TODO: Check if the pool has capacity to allocate the resource + return True diff --git a/virttest/vt_resmgr/resources/storage/nfs/nfs_resources.py b/virttest/vt_resmgr/resources/storage/nfs/nfs_resources.py new file mode 100644 index 0000000000..5f885be155 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/nfs/nfs_resources.py @@ -0,0 +1,113 @@ +import logging + +from virttest.utils_numeric import normalize_data_size +from virttest.vt_cluster import cluster + +from ..volume import _FileVolume + + +LOG = logging.getLogger("avocado." + __name__) + + +class _NfsFileVolume(_FileVolume): + """ + The nfs file-based volume + """ + + def bind(self, arguments): + """ + Bind the resource to a backing on a worker node. + Note: A nfs volume resource can have many bindings + """ + nodes = arguments.pop("nodes", list(self.resource_bindings.keys())) + for node_name in nodes: + if not self.resource_bindings.get(node_name): + LOG.info(f"Bind the nfs volume {self.resource_id} to node {node_name}") + node = cluster.get_node(node_name) + r, o = node.proxy.resource.create_backing_object(self.resource_config) + if r != 0: + raise Exception(o["out"]) + self.resource_bindings[node_name] = o["out"] + else: + LOG.info(f"The nfs volume {self.resource_id} has already bound to {node_name}") + + def unbind(self, arguments): + """ + Unbind the nfs volume from a worker node + """ + nodes = arguments.pop("nodes", list(self.resource_bindings.keys())) + for node_name in nodes: + backing_id = self.resource_bindings.get(node_name) + if backing_id: + LOG.info(f"Unbind the nfs volume {self.resource_id} from node {node_name}") + node = cluster.get_node(node_name) + r, o = node.proxy.resource.destroy_backing_object(backing_id) + if r != 0: + raise Exception(o["out"]) + self.resource_bindings[node_name] = None + else: + LOG.info(f"The nfs volume {self.resource_id} has already unbound from {node_name}") + + def sync(self, arguments): + LOG.debug(f"Sync up the configuration of the nfs volume {self.resource_id}") + node_name, backing_id = list(self.resource_bindings.items())[0] + node = cluster.get_node(node_name) + r, o = node.proxy.resource.update_backing(backing_id, + {"sync": arguments}) + if r != 0: + raise Exception(o["out"]) + + config = o["out"] + self.resource_meta["allocated"] = config["meta"]["allocated"] + self.resource_spec["uri"] = config["spec"]["uri"] + self.resource_spec["allocation"] = config["spec"]["allocation"] + + def allocate(self, arguments): + LOG.debug(f"Allocate the nfs volume {self.resource_id} from {node_name}.") + node_name, backing_id = list(self.resource_bindings.items())[0] + node = cluster.get_node(node_name) + r, o = node.proxy.resource.update_backing(backing_id, + {"allocate": arguments}) + if r != 0: + raise Exception(o["out"]) + + config = o["out"] + self.resource_meta["allocated"] = config["meta"]["allocated"] + self.resource_spec["uri"] = config["spec"]["uri"] + self.resource_spec["allocation"] = config["spec"]["allocation"] + + def release(self, arguments): + LOG.debug(f"Release the nfs volume {self.resource_id} from {node_name}") + node_name, backing_id = list(self.resource_bindings.items())[0] + node = cluster.get_node(node_name) + r, o = node.proxy.resource.update_backing(backing_id, + {"release": arguments}) + if r != 0: + raise Exception(o["error"]) + self.resource_meta["allocated"] = False + self.resource_spec["allocation"] = 0 + self.resource_spec["uri"] = None + + def resize(self, arguments): + """ + Resize the nfs volume + """ + new = int(normalize_data_size(arguments["size"], "B")) + if new != self.resource_spec["size"]: + LOG.debug(f"Resize the nfs volume {self.resource_id} from {node_name}") + node_name, backing_id = list(self.resource_bindings.items())[0] + node = cluster.get_node(node_name) + r, o = node.proxy.resource.update_backing(backing_id, {"resize": arguments}) + if r != 0: + raise Exception(o["error"]) + self.resource_spec["size"] = new + else: + LOG.debug(f"New size {new} is the same with the original") + + +def get_nfs_resource_class(resource_type): + mapping = { + "volume": _NfsFileVolume, + } + + return mapping.get(resource_type) diff --git a/virttest/vt_resmgr/resources/storage/volume.py b/virttest/vt_resmgr/resources/storage/volume.py new file mode 100644 index 0000000000..ac696322e1 --- /dev/null +++ b/virttest/vt_resmgr/resources/storage/volume.py @@ -0,0 +1,81 @@ +import os + +from virttest import utils_numeric + +from ..resource import _Resource + + +class _Volume(_Resource): + """ + Storage volumes are abstractions of physical partitions, + LVM logical volumes, file-based disk images + """ + + _RESOURCE_TYPE = "volume" + _VOLUME_TYPE = None + + @classmethod + def get_volume_type(cls): + return cls._VOLUME_TYPE + + @classmethod + def _define_config_legacy(cls, resource_name, resource_params): + size = utils_numeric.normalize_data_size( + resource_params.get("image_size", "20G"), order_magnitude="B" + ) + + config = super()._define_config_legacy(resource_name, resource_params) + config["meta"].update({ + "type": cls._RESOURCE_TYPE, + "volume-type": cls.get_volume_type(), + "raw": resource_params.get_boolean("image_raw_device"), + }) + config["spec"].update({ + "size": size, + "allocation": None, + "uri": None, + }) + + return config + + +class _FileVolume(_Volume): + """For file based volumes""" + + _VOLUME_TYPE = "file" + + def __init__(self, resource_config): + super().__init__(resource_config) + self._handlers.update({ + "resize": self.resize, + }) + + @classmethod + def _define_config_legacy(cls, resource_name, resource_params): + config = super()._define_config_legacy(resource_name, resource_params) + + image_name = resource_params.get("image_name", "image") + if os.path.isabs(image_name): + config["spec"]["uri"] = image_name + config["spec"]["filename"] = os.path.basename(image_name) + else: + image_format = resource_params.get("image_format", "qcow2") + config["spec"]["filename"] = "%s.%s" % (image_name, image_format) + config["spec"]["uri"] = None + + return config + + def resize(self, arguments): + raise NotImplemented + + +class _BlockVolume(_Volume): + """For disk, lvm, iscsi based volumes""" + + _VOLUME_TYPE = "block" + + +class _NetworkVolume(_Volume): + """For rbd, iscsi-direct based volumes""" + + _VOLUME_TYPE = "network" diff --git a/virttest/vt_resmgr/vt_resmgr.py b/virttest/vt_resmgr/vt_resmgr.py new file mode 100644 index 0000000000..35e9162251 --- /dev/null +++ b/virttest/vt_resmgr/vt_resmgr.py @@ -0,0 +1,438 @@ +import ast +import logging +import os +import pickle + +from .resources import get_resource_pool_class + +from virttest.vt_cluster import cluster +from virttest.data_dir import get_data_dir + + +LOG = logging.getLogger("avocado." + __name__) +RESMGR_ENV_FILENAME = os.path.join(get_data_dir(), "vt_resmgr.env") + + +class PoolNotFound(Exception): + def __init__(self, pool_id): + self._pool_id = pool_id + + def __str__(self): + pool_id = self._pool_id + return f"Cannot find the pool by id={pool_id}" + + +class UnknownPoolType(Exception): + def __init__(self, pool_type): + self._pool_type = pool_type + + def __str__(self): + pool_type = self._pool_type + return f"Unknown pool type {pool_type}" + + +class PoolNotAvailable(Exception): + pass + + +class ResourceNotFound(Exception): + pass + + +class ResourceBusy(Exception): + pass + + +class ResourceNotAvailable(Exception): + pass + + +class UnknownResourceType(Exception): + pass + + +class _VTResourceManager(object): + + def __init__(self): + """ + When the job starts a new process to run a case, the resource manager + will be re-constructed as a new object, it reads the dumped file to get + back all the information. Note the resmgr here is a 'slice' because + this resmgr only serves the current test case, when the process(test + case) is finished, the slice resmgr is gone + """ + self._pools = dict() + if os.path.isfile(RESMGR_ENV_FILENAME): + self._load() + + @property + def _dump_data(self): + return { + "pools": self.pools, + } + + @_dump_data.setter + def _dump_data(self, data): + self.pools = data.get("pools") + + def _load(self): + with open(RESMGR_ENV_FILENAME, "rb") as f: + self._dump_data = pickle.load(f) + + def _dump(self): + with open(RESMGR_ENV_FILENAME, "wb") as f: + pickle.dump(self._dump_data, f) + + @property + def pools(self): + return self._pools + + @pools.setter + def pools(self, pools): + self._pools = pools + + def initialize(self, resource_pools_params): + """ + Register all the resource pools configured in cluster.json + Note: This function will be called only once during the VT bootstrap + + :param resource_pools_params: User defined resource pools' params + :type resource_pools_params: dict + """ + LOG.info(f"Initialize the resource manager") + + if os.path.exists(RESMGR_ENV_FILENAME): + LOG.info(f"Remove the old resource manager settings") + os.unlink(RESMGR_ENV_FILENAME) + + # Register a default pool on a node where no pool is defined + # e.g. if no filesystem pool is defined we need to register + # a default one + default_pools_nodes = { + "filesystem": set(), + # "switch": set(), + } + + # Register the resource pools + for category, params in resource_pools_params.items(): + for pool_name, pool_params in params.items(): + pool_config = self.define_pool_config(pool_name, pool_params) + pool_id = self.create_pool_object(pool_config) + + # Record the nodes of the pools with default type, i.e + # we've pools with default type attached to these nodes + pool = self.get_pool_by_id(pool_id) + pool_type = pool.get_pool_type() + if pool_type in default_pools_nodes: + default_pools_nodes[pool_type].update( + set(pool.attaching_nodes) + ) + + # Register the default pools if they are not defined + all_nodes = set([n.name for n in cluster.get_all_nodes()]) + for pool_type, node_set in default_pools_nodes.items(): + for node_name in all_nodes.difference(node_set): + LOG.debug(f"Register a default {pool_type} pool " + "with access nodes {node_name}") + pool_class = get_resource_pool_class(pool_type) + pool_config = pool_class.define_default_config() + pool_config["meta"]["access"]["nodes"] = [node_name] + self.create_pool_object(pool_config) + + # Dump all the information for the job process + self._dump() + + def startup(self): + """ + Attach all configured resource pools + Note: This function is called only once in job's pre_tests + """ + LOG.info(f"Startup the resource manager") + for pool_id in self.pools: + self.attach_pool(pool_id) + + def teardown(self): + """ + Detach all configured resource pools + Note: This function is called only once in job's post_tests + """ + LOG.info(f"Teardown the resource manager") + for pool_id in list(self.pools.keys()): + self.detach_pool(pool_id) + + def get_pool_by_name(self, pool_name): + pools = [p for p in self.pools.values() if p.pool_name == pool_name] + return pools[0] if pools else None + + def get_pool_by_id(self, pool_id): + return self.pools.get(pool_id) + + def get_pool_by_resource(self, resource_id): + pools = [p for p in self.pools.values() if resource_id in p.resources] + return pools[0] if pools else None + + def select_pool(self, resource_type, resource_params): + """ + Select the resource pool by its cartesian params + + :param resource_type: The resource's type, supported: + "volume" + :type resource_type: string + :param resource_params: The resource's specific params, e.g. + params.object_params('image1') + :type resource_params: dict or Param + :return: The resource pool id + :rtype: string + """ + LOG.info(f"Select a pool for the {resource_type} resource") + for pool_id, pool in self.pools.items(): + if pool.meet_resource_request(resource_type, resource_params): + return pool_id + return None + + def define_pool_config(self, pool_name, pool_params): + """ + Define a resource pool's configuration by its cartesian params. + + :param pool_name: The uniq resource pool name + :type pool_name: string + :param pool_params: The resource pool's specific params + :type pool_params: Param + :return: The resource pool's configuration, + format: {"meta":{...}, "spec":{...}} + The specific attributes depend on the specific pool + :rtype: dict + """ + pool_class = get_resource_pool_class(pool_params["type"]) + if pool_class is None: + raise UnknownPoolType(pool_type) + + return pool_class.define_config(pool_name, pool_params) + + def create_pool_object(self, pool_config): + """ + Create a resource pool object + Note: Currently the users need to setup the pool before testing + + :param pool_config: The pool's configuration, generated by + define_pool_config function + :type pool_config: dict + :return: The resource pool id + :rtype: string + """ + pool_type = pool_config["meta"]["type"] + pool_class = get_resource_pool_class(pool_type) + if pool_class is None: + raise UnknownPoolType(pool_type) + + pool = pool_class(pool_config) + pool.create() + self.pools[pool.pool_id] = pool + + LOG.info(f"Created the pool object {pool.pool_id} for {pool.pool_name}") + return pool.pool_id + + def destroy_pool_object(self, pool_id): + """ + The pool should be detached from all worker nodes before destroying it + + :param pool_id: The id of the pool + :type pool_id: string + """ + LOG.info(f"Destroy the pool object {pool_id}") + pool = self.pools.pop(pool_id) + pool.destroy() + + def _attach_pool_to(self, pool, node): + """ + Attach a pool to a specific node + """ + LOG.info(f"Attach resource pool ({pool.pool_name}) to {node.name}") + r, o = node.proxy.resource.connect_pool(pool.pool_id, pool.pool_config) + if r != 0: + raise Exception(o["out"]) + + def attach_pool(self, pool_id): + """ + Attach the resource pool to the worker nodes, where the pool can be + accessed. The accessiable worker nodes are defined by the pool's meta + + :param pool_id: The id of the pool to attach + :type pool_id: string + """ + pool = self.get_pool_by_id(pool_id) + for node_name in pool.attaching_nodes: + node = cluster.get_node(node_name) + self._attach_pool_to(pool, node) + + def _detach_pool_from(self, pool, node): + """ + Detach a pool from a specific node + """ + LOG.info(f"Detach resource pool({pool.pool_name}) from {node.name}") + r, o = node.proxy.resource.disconnect_pool(pool.pool_id) + if r != 0: + raise Exception(o["out"]) + + def detach_pool(self, pool_id): + """ + Detach the pool from its accessiable worker nodes + + :param pool_id: The id of the pool to detach + :type pool_id: string + """ + pool = self.get_pool_by_id(pool_id) + for node_name in pool.attaching_nodes: + node = cluster.get_node(node_name) + self._detach_pool_from(pool, node) + + def get_pool_info(self, pool_id, request=None): + """ + Get the configuration of a specified resource pool + + :param pool_id: The resource pool id + :type pool_id: string + :param request: The query content, format: + None + meta[.] + spec[.] + Note return the whole configuration if request=None + :type request: string + :return: The pool's configuration, e.g request=meta.type, it + returns: {"type": "filesystem"} + :rtype: dict + """ + pool = self.get_pool_by_id(pool_id) + return pool.get_info(request) + + def get_all_pools(self): + """ + Get all resource pools' uuid list + + :return: The pools' uuid list + :rtype: list + """ + return list(self.pools.keys()) + + def pool_capability(self, pool_id): + pool = self.get_pool_by_id(pool_id) + return pool.capability + + def define_resource_config(self, resource_name, resource_type, resource_params): + """ + Define a resource's configuration by its cartesian params + + :param resource_type: The resource type, it's usually implied, e.g. + the image's storage resource is a "volume", + supported: "volume" + :type resource_type: string + :param resource_params: The resource's specific params, usually + defined by an upper-level object, e.g. + "image1" has a storage resource, so + resource_params = image1's params + i.e. use image1's params to define its + storage resource's configuration + :type resource_params: Param + :return: The resource's configuration, + format: {"meta":{...}, "spec":{...}} + The specific attributes depend on the specific resource + :rtype: dict + """ + pool_id = self.select_pool(resource_type, resource_params) + if pool_id is None: + raise PoolNotAvailable() + pool = self.get_pool_by_id(pool_id) + return pool.define_resource_config(resource_name, + resource_type, + resource_params) + + def create_resource_object(self, resource_config): + """ + Create a resource object without any specific resource allocation. + + :param resource_config: The resource configuration, generated by + define_resource_config function + :type resource_config: dict + :return: The resource id + :rtype: string + """ + pool_config = resource_config["meta"]["pool"] + pool_id = pool_config["meta"]["uuid"] + pool = self.get_pool_by_id(pool_id) + if pool is None: + raise PoolNotFound(pool_id) + return pool.create_resource_object(resource_config) + + def destroy_resource_object(self, resource_id): + """ + Destroy the resource object, the specific resource allocation + will be released + + :param resource_id: The resource id + :type resource_id: string + """ + pool = self.get_pool_by_resource(resource_id) + pool.destroy_resource_object(resource_id) + + def get_resource_info(self, resource_id, request=None): + """ + Get the configuration of a specified resource + + :param resource_id: The resource id + :type resource_id: string + :param request: The query content, format: + None + meta[.] + spec[.] + Examples: + meta + spec.size + :type request: string + :return: The resource's configuration, e.g request=spec.size, it + returns: {"size": "123456"} + :rtype: dict + """ + pool = self.get_pool_by_resource(resource_id) + return pool.get_resource_info(resource_id, request) + + def update_resource(self, resource_id, config): + """ + Update a resource, the config format: + {'command': arguments} + Supported commands: + 'bind': Bind a specified resource to one or more worker nodes in order + to access the specific resource allocation, note the resource + is *NOT* allocated with the bind command + 'unbind': Unbind a specified resource from one or more worker nodes, + the specific resource will be released only when all bindings + are gone + 'allocate': Allocate the resource + 'release': Release the resource + 'sync': Sync up the resource configuration. Some items of the + configuration can change and only be fetched on the worker + nodes, e.g. allocation, use sync to sync-up these items + The arguments is a dict object which contains all related settings for a + specific action + + Examples: + Bind a resource to one or more nodes + {'bind': {'nodes': ['node1']}} + {'bind': {'nodes': ['node1', 'node2']}} + Unbind a resource from one or more nodes + {'unbind': {'nodes': []}} + {'unbind': {'nodes': ['node1', 'node2']}} + Allocate the resource + {'allocate': {}} + Release the resource + {'release': {}} + + :param resource_id: The resource id + :type resource_id: string + :param config: The specified action and its arguments + :type config: dict + """ + pool = self.get_pool_by_resource(resource_id) + return pool.update_resource(resource_id, config) + + +resmgr = _VTResourceManager() diff --git a/virttest/vt_utils/image/qemu.py b/virttest/vt_utils/image/qemu.py new file mode 100644 index 0000000000..1bab194dd2 --- /dev/null +++ b/virttest/vt_utils/image/qemu.py @@ -0,0 +1,177 @@ +import collections +import logging +import json +import os +import re +import string + +from avocado.core import exceptions +from avocado.utils import path as utils_path +from avocado.utils import process + +from virttest import utils_numeric + + +LOG = logging.getLogger("avocado.service." + __name__) + + +def _get_dir_volume_opts(volume_config): + return { + "driver": "file", + "filename": volume_config["spec"]["uri"], + } + + +def _get_nfs_volume_opts(volume_config): + return _get_dir_volume_opts(volume_config) + + +def _get_ceph_volume_opts(volume_config): + volume_spec = volume_config["spec"] + pool_config = volume_config["meta"]["pool"] + pool_meta = pool_config["meta"] + pool_spec = pool_config["spec"] + + volume_opts = { + "driver": "rbd", + "pool": pool_spec["pool"], + "image": volume_spec["filename"], + } + + if pool_spec.get("conf") is not None: + volume_opts["conf"] = pool_spec["conf"] + if pool_spec.get("namespace") is not None: + volume_opts["namespace"] = pool_spec["namespace"] + + return volume_opts + + +def _get_iscsi_direct_volume_opts(volume_config): + pool_config = volume_config["meta"]["pool"] + pool_meta = pool_config["meta"] + pool_spec = pool_config["spec"] + + # required options for iscsi + volume_opts = { + "driver": "iscsi", + "transport": pool_spec["transport"], + "portal": pool_spec["portal"], + "target": pool_spec["target"], + } + + # optional option + if pool_spec["user"] is not None: + volume_opts["user"] = pool_spec["user"] + + return volume_opts + + +def _get_nbd_volume_opts(volume_config): + volume_meta = volume_config["meta"] + volume_spec = volume_config["spec"] + pool_config = volume_meta["pool"] + pool_meta = pool_config["meta"] + pool_spec = pool_config["spec"] + + volume_opts = {"driver": "nbd"} + if pool_spec.get("host"): + volume_opts.update({ + "server.type": "inet", + "server.host": pool_spec["host"], + "server.port": volume_spec.get("port", 10809), + }) + elif pool_spec.get("path"): + volume_opts.update({ + "server.type": "unix", + "server.path": pool_spec["path"], + }) + else: + raise + + if volume_spec.get("export"): + volume_opts["export"] = volume_spec["export"] + + return volume_opts + + +def get_ceph_pool_access_opts(pool_config): + auth = dict() + return auth + + +def get_iscsi_direct_pool_access_opts(pool_config): + auth = dict() + return auth + + +def get_nbd_pool_access_opts(pool_config): + auth = dict() + return auth + + +def get_qemu_virt_image_volume_access_auth_opts(pool_config): + access_opts_getters = { + "filesystem": lambda i: dict(), + "nfs": lambda i: dict(), + "ceph": get_ceph_pool_access_opts, + "iscsi-direct": get_iscsi_direct_pool_access_opts, + "nbd": get_nbd_pool_access_opts, + } + + pool_type = pool_config["meta"]["type"] + access_opts_getter = access_opts_getters[pool_type] + + return access_opts_getter(pool_config) + + +def get_volume_opts(volume_config): + volume_opts_getters = { + "filesystem": _get_dir_volume_opts, + "nfs": _get_nfs_volume_opts, + "ceph": _get_ceph_volume_opts, + "iscsi-direct": _get_iscsi_direct_volume_opts, + "nbd": _get_nbd_volume_opts, + } + + pool_config = volume_config["meta"]["pool"] + pool_type = pool_config["meta"]["type"] + volume_opts_getter = volume_opts_getters[pool_type] + + return volume_opts_getter(volume_config) + + +def get_image_opts(virt_image_config): + """ + Get lower-level qemu virt image options + + Return a tuple of (access_auth_opts, encryption_opts, virt_image_opts) + """ + volume_config = virt_image_config["spec"]["volume"] + virt_image_format = virt_image_config["spec"]["format"] + + virt_image_opts = collections.OrderedDict() + virt_image_opts["file"] = collections.OrderedDict() + virt_image_opts["driver"] = virt_image_format + virt_image_opts["file"].update(get_volume_opts(volume_config)) + + # lower-level virt image encryption options + encryption_opts = virt_image_config["spec"].get("encryption", dict()) + if virt_image_format == "luks": + key = "password-secret" if "file" in encryption_opts else "key-secret" + virt_image_opts[key] = encryption_opts["name"] + elif virt_image_format == "qcow2" and encryption_opts: + encrypt_format = encryption_opts["encrypt"]["format"] + if encrypt_format == "luks": + virt_image_opts["encrypt.key-secret"] = encryption_opts["name"] + virt_image_opts.update( + {f"encrypt.{k}": v for k, v in encryption_opts["encrypt"]} + ) + else: + raise ValueError(f"Unknown encrypt format: {encrypt_format}") + + # volume pool access auth options + pool_config = volume_config["meta"]["pool"] + access_auth_opts = get_qemu_virt_image_volume_access_auth_opts(pool_config) + + # TODO: Add filters here + return access_auth_opts, encryption_opts, virt_image_opts From fbecc86cb4942013f68fbebbb2d62c13ccc956bd Mon Sep 17 00:00:00 2001 From: "Houqi (Nick) Zuo" Date: Thu, 29 Aug 2024 16:15:16 +0800 Subject: [PATCH 3/3] add network system of multi-host migration add support for network subsystem. Signed-off-by: Houqi (Nick) Zuo --- avocado_vt/plugins/vt_cluster.py | 3 + .../resource_backings/net/__init__.py | 0 .../resource_backings/net/network/__init__.py | 0 .../net/network/network_backing.py | 25 +++ .../net/network/network_pool_connection.py | 26 +++ .../resource_backings/net/port/__init__.py | 0 .../net/port/port_backing.py | 25 +++ .../net/port/port_pool_connection.py | 26 +++ virttest/vt_netmgr/__init__.py | 1 + virttest/vt_netmgr/vt_netmgr.py | 197 ++++++++++++++++++ .../vt_resmgr/resources/network/__init__.py | 0 .../vt_resmgr/resources/network/network.py | 28 +++ virttest/vt_resmgr/resources/network/port.py | 38 ++++ 13 files changed, 369 insertions(+) create mode 100644 virttest/vt_agent/managers/resource_backings/net/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/net/network/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/net/network/network_backing.py create mode 100644 virttest/vt_agent/managers/resource_backings/net/network/network_pool_connection.py create mode 100644 virttest/vt_agent/managers/resource_backings/net/port/__init__.py create mode 100644 virttest/vt_agent/managers/resource_backings/net/port/port_backing.py create mode 100644 virttest/vt_agent/managers/resource_backings/net/port/port_pool_connection.py create mode 100644 virttest/vt_netmgr/__init__.py create mode 100644 virttest/vt_netmgr/vt_netmgr.py create mode 100644 virttest/vt_resmgr/resources/network/__init__.py create mode 100644 virttest/vt_resmgr/resources/network/network.py create mode 100644 virttest/vt_resmgr/resources/network/port.py diff --git a/avocado_vt/plugins/vt_cluster.py b/avocado_vt/plugins/vt_cluster.py index 1c77daa80d..72678dfa6b 100644 --- a/avocado_vt/plugins/vt_cluster.py +++ b/avocado_vt/plugins/vt_cluster.py @@ -9,6 +9,7 @@ from virttest.vt_cluster import cluster, node_metadata from virttest.vt_imgr import vt_imgr from virttest.vt_resmgr import resmgr +from virttest.vt_netmgr import vt_netmgr class ClusterSetupError(Exception): @@ -54,6 +55,7 @@ def _pre_mgr_setup(): # Pre-setup the cluster manager resmgr.startup() vt_imgr.startup() + vt_netmgr.startup() except Exception as err: raise ClusterManagerSetupError(err) @@ -61,6 +63,7 @@ def _pre_mgr_setup(): def _post_mgr_cleanup(): try: # Post-cleanup the cluster manager + vt_netmgr.teardown() vt_imgr.teardown() resmgr.teardown() except Exception as err: diff --git a/virttest/vt_agent/managers/resource_backings/net/__init__.py b/virttest/vt_agent/managers/resource_backings/net/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/virttest/vt_agent/managers/resource_backings/net/network/__init__.py b/virttest/vt_agent/managers/resource_backings/net/network/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/virttest/vt_agent/managers/resource_backings/net/network/network_backing.py b/virttest/vt_agent/managers/resource_backings/net/network/network_backing.py new file mode 100644 index 0000000000..b887b19810 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/net/network/network_backing.py @@ -0,0 +1,25 @@ +import logging +import os + +from avocado.utils import process + +from ...backing import _ResourceBacking + + +LOG = logging.getLogger("avocado.agents.resource_backings.net.network" + __name__) + + +class _NetworkBacking(_ResourceBacking): + _SOURCE_POOL_TYPE = "network" + _BINDING_RESOURCE_TYPE = "" # todo + + def __init__(self, backing_config): + super().__init__(backing_config) + pass + + def create(self, pool_connection): + pass + + def destroy(self, pool_connection): + super().destroy(pool_connection) + pass diff --git a/virttest/vt_agent/managers/resource_backings/net/network/network_pool_connection.py b/virttest/vt_agent/managers/resource_backings/net/network/network_pool_connection.py new file mode 100644 index 0000000000..ba2802470b --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/net/network/network_pool_connection.py @@ -0,0 +1,26 @@ +import os +import logging + +from avocado.utils.path import init_dir + +from virttest import utils_misc + +from ...pool_connection import _ResourcePoolAccess +from ...pool_connection import _ResourcePoolConnection + + +LOG = logging.getLogger("avocado.agents.resource_backings.net.network." + __name__) + + +class _NetworkPoolConnection(_ResourcePoolConnection): + _CONNECT_POOL_TYPE = "network" + + def __init__(self, pool_config): + super().__init__(pool_config) + pass + + def startup(self): + pass + + def shutdown(self): + pass diff --git a/virttest/vt_agent/managers/resource_backings/net/port/__init__.py b/virttest/vt_agent/managers/resource_backings/net/port/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/virttest/vt_agent/managers/resource_backings/net/port/port_backing.py b/virttest/vt_agent/managers/resource_backings/net/port/port_backing.py new file mode 100644 index 0000000000..eadbb29a1b --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/net/port/port_backing.py @@ -0,0 +1,25 @@ +import logging +import os + +from avocado.utils import process + +from ...backing import _ResourceBacking + + +LOG = logging.getLogger("avocado.agents.resource_backings.net.port" + __name__) + + +class _PortBacking(_ResourceBacking): + _SOURCE_POOL_TYPE = "port" + _BINDING_RESOURCE_TYPE = "" # todo + + def __init__(self, backing_config): + super().__init__(backing_config) + pass + + def create(self, pool_connection): + pass + + def destroy(self, pool_connection): + super().destroy(pool_connection) + pass diff --git a/virttest/vt_agent/managers/resource_backings/net/port/port_pool_connection.py b/virttest/vt_agent/managers/resource_backings/net/port/port_pool_connection.py new file mode 100644 index 0000000000..38b0af3914 --- /dev/null +++ b/virttest/vt_agent/managers/resource_backings/net/port/port_pool_connection.py @@ -0,0 +1,26 @@ +import os +import logging + +from avocado.utils.path import init_dir + +from virttest import utils_misc + +from ...pool_connection import _ResourcePoolAccess +from ...pool_connection import _ResourcePoolConnection + + +LOG = logging.getLogger("avocado.agents.resource_backings.net.port." + __name__) + + +class _PortPoolConnection(_ResourcePoolConnection): + _CONNECT_POOL_TYPE = "port" + + def __init__(self, pool_config): + super().__init__(pool_config) + pass + + def startup(self): + pass + + def shutdown(self): + pass diff --git a/virttest/vt_netmgr/__init__.py b/virttest/vt_netmgr/__init__.py new file mode 100644 index 0000000000..058862d824 --- /dev/null +++ b/virttest/vt_netmgr/__init__.py @@ -0,0 +1 @@ +from .vt_netmgr import vt_netmgr diff --git a/virttest/vt_netmgr/vt_netmgr.py b/virttest/vt_netmgr/vt_netmgr.py new file mode 100644 index 0000000000..6b8e980d57 --- /dev/null +++ b/virttest/vt_netmgr/vt_netmgr.py @@ -0,0 +1,197 @@ +""" +The upper-level network manager. + +from virttest.vt_netgr import vt_netmgr +""" + +import logging + +from virttest.vt_cluster import cluster +from virttest.vt_resmgr.resources.network import network as nt +from virttest.vt_resmgr.resources.network import port + +LOG = logging.getLogger("avocado." + __name__) + + +class _VTNetworkManager(object): + """ + The Network Manager. + """ + + def __init__(self): + self._networks = list() + self._ports = list() + + def startup(self): + LOG.info(f"Start the network manager!") + + def teardown(self): + LOG.info(f"Stop the network manager!") + + def define_network_config(self, params): + """ + Translate the parameters of user layer to parameters of vt framework + layer. + + :param params: The parameters of user level. + :type params: dict. + + :return: The parsed parameters in vt framework layer. + :rtype: dict. + """ + pass + + def create_network_object(self, network_params, name): + """ + TODO + Create the network by its cartesian params. + + :param network_params: The network tag defined in cartesian params. + :type network_params: String. + :param name: The name. + :type name: String. + + :return: The uuid of created network. + :rtype: String. + """ + # network_obj = nt.Network(network_params, name) + # network_obj.create() + # self._networks.append(network_obj) + # return network_obj.uuid + pass + + def delete_network_object(self, descriptor): + """ + TODO + Delete the networks by its descriptor. + + :param descriptor: The network name or the uuid. + :type descriptor: String. + """ + be_deleted = [] + for obj in self._networks: + if descriptor in ( + obj.uuid, + obj.name, + ): + obj.delete() + be_deleted.append(obj) + + for obj in be_deleted: + self._networks.remove(obj) + + def setup_network(self): + pass + + def clean_up_network(self): + pass + + def get_network_info(self, network_name): + """ + Filter the network based on the network name. + + :param network_name: The network name. + :type network_name: String. + + :return: The config of network or None if nothing found. + :rtype: dict. + """ + for obj in self._networks: + if network_name in (obj.name,): + return {"uuid": obj.uuid, + "name": obj.name, + "type": obj.type, + "spec": obj.spec, + } + return None + + def query_network(self, filter): + """ + Get the network by a filter. + Note: filter may be as following: + network uuid, + network name, + + :param filter: The filter. + :type filter: String. + + :return: A list of network configuration or [] if nothing found. + :rtype: list. + e.g.: [{"uuid": uuid, "name": name, "type": type, "spec": spec}, + {"uuid": uuid, "name": name, "type": type, "spec": spec}, + ....] + """ + res = [] + for obj in self._networks: + if filter in (obj.uuid,) or filter in (obj.name,): + res.append(obj) + return res + + def create_port_object(self, name, network_uuid, vm_name, mac_nic, net_type): + """ + TODO + Create the port by its params. + + :param name: The port name. + :type name: String. + :param network_uuid: The network uuid which this port belongs to. + :type network_uuid: String. + :param vm_name: The vm name. + :type vm_name: String. + :param mac_nic: The mac address. + :type mac_nic: String. + :param net_type: The net type. + :type net_type: String. + """ + port_obj = port.Port(name, network_uuid, vm_name, mac_nic, net_type) + port_obj.create() + self._networks.append(port_obj) + + def delete_port_object(self): + pass + + def setup_port(self): + pass + + def clean_up_port(self): + pass + + def get_port_info(self, filter): + """ + Filter the port. + Note: the filter may be as following: + port uuid, + port name + + :param filter: The network name or the uuid. + :type filter: String. + + :return: The port config or None If not found. + :rtype: dict. + """ + for obj in self._ports: + if filter in (obj.name, obj.uuid, ): + return filter.to_dict() + return None + + def query_port(self, filter): + """ + Get the port configuration. + Note: the filter may be as following: + port uuid, + port name + + :param filter: The filter. + :type filter: String. + + :return: The port configuration. + :rtype: dict. + """ + res = [] + for obj in self._ports: + if filter in (obj.uuid, obj.name): + res.append(filter.to_dict()) + return res + + +vt_netmgr = _VTNetworkManager() diff --git a/virttest/vt_resmgr/resources/network/__init__.py b/virttest/vt_resmgr/resources/network/__init__.py new file mode 100644 index 0000000000..e69de29bb2 diff --git a/virttest/vt_resmgr/resources/network/network.py b/virttest/vt_resmgr/resources/network/network.py new file mode 100644 index 0000000000..e355cff9d0 --- /dev/null +++ b/virttest/vt_resmgr/resources/network/network.py @@ -0,0 +1,28 @@ +from abc import ABC +import uuid + + +class Network(ABC): + def __init__(self, name, network_params): + self.uuid = uuid.uuid4().hex + self.name = name + self._type = network_params["type"] + self._spec = network_params["spec"] + + @property + def type(self): + return self._type + + @property + def spec(self): + return self._spec + + def create(self): + # TODO + # create the port for the self._spec + pass + + def delete(self): + # TODO + # delete the port for the self._spec + pass diff --git a/virttest/vt_resmgr/resources/network/port.py b/virttest/vt_resmgr/resources/network/port.py new file mode 100644 index 0000000000..d5d8e0cfdd --- /dev/null +++ b/virttest/vt_resmgr/resources/network/port.py @@ -0,0 +1,38 @@ +from abc import ABC +import uuid + +# from virttest.vt_resmgr.resources.network import PortType + + +class Port(ABC): + def __init__(self, name, network_uuid, vm_name, mac_nic, net_type): + self.uuid = uuid.uuid4().hex + self.name = name + self.network_uuid = network_uuid + self.vm_name = vm_name + self.mac_nic = mac_nic + # if dev_type not in PortType: + # raise NotImplementedError("This type is NOT supported!") + self.net_type = net_type + self.created_by_vt = None + + def to_dict(self): + return { + "uuid": self.uuid, + "name": self.name, + "network_uuid": self.network_uuid, + "vm_name": self.vm_name, + "mac_nic": self.mac_nic, + "net_type": self.net_type, + "created_by_vt": self.created_by_vt, + } + + def create(self): + # TODO + # create the port + pass + + def delete(self): + # TODO + # delete the port + pass