示例#1
0
    def _TestLoadingConfigFile(self):
        # test loading the config file
        all_ok = True
        if not (self.opts.dry_run or self.opts.no_verify):
            logging.info("Testing the new config file...")
            cfg = config.ConfigWriter(cfg_file=self.opts.CONFIG_DATA_PATH,
                                      accept_foreign=self.opts.ignore_hostname,
                                      offline=True)
            # if we reached this, it's all fine
            vrfy = cfg.VerifyConfig()
            if vrfy:
                logging.error("Errors after conversion:")
                for item in vrfy:
                    logging.error(" - %s", item)
                all_ok = False
            else:
                logging.info("File loaded successfully after upgrading")
            del cfg

        if self.opts.downgrade:
            action = "downgraded"
            out_ver = "%s.%s" % (DOWNGRADE_MAJOR, DOWNGRADE_MINOR)
        else:
            action = "upgraded"
            out_ver = constants.RELEASE_VERSION
        if all_ok:
            cli.ToStderr("Configuration successfully %s to version %s.",
                         action, out_ver)
        else:
            cli.ToStderr(
                "Configuration %s to version %s, but there are errors."
                "\nPlease review the file.", action, out_ver)
示例#2
0
文件: bootstrap.py 项目: badp/ganeti
def FinalizeClusterDestroy(master_uuid):
    """Execute the last steps of cluster destroy

  This function shuts down all the daemons, completing the destroy
  begun in cmdlib.LUDestroyOpcode.

  """
    cfg = config.ConfigWriter()
    modify_ssh_setup = cfg.GetClusterInfo().modify_ssh_setup
    runner = rpc.BootstrapRunner()

    master_name = cfg.GetNodeName(master_uuid)

    master_params = cfg.GetMasterNetworkParameters()
    master_params.uuid = master_uuid
    ems = cfg.GetUseExternalMipScript()
    result = runner.call_node_deactivate_master_ip(master_name, master_params,
                                                   ems)

    msg = result.fail_msg
    if msg:
        logging.warning("Could not disable the master IP: %s", msg)

    result = runner.call_node_stop_master(master_name)
    msg = result.fail_msg
    if msg:
        logging.warning("Could not disable the master role: %s", msg)

    result = runner.call_node_leave_cluster(master_name, modify_ssh_setup)
    msg = result.fail_msg
    if msg:
        logging.warning(
            "Could not shutdown the node daemon and cleanup"
            " the node: %s", msg)
示例#3
0
文件: masterd.py 项目: badp/ganeti
def CheckAgreement():
    """Check the agreement on who is the master.

  The function uses a very simple algorithm: we must get more positive
  than negative answers. Since in most of the cases we are the master,
  we'll use our own config file for getting the node list. In the
  future we could collect the current node list from our (possibly
  obsolete) known nodes.

  In order to account for cold-start of all nodes, we retry for up to
  a minute until we get a real answer as the top-voted one. If the
  nodes are more out-of-sync, for now manual startup of the master
  should be attempted.

  Note that for a even number of nodes cluster, we need at least half
  of the nodes (beside ourselves) to vote for us. This creates a
  problem on two-node clusters, since in this case we require the
  other node to be up too to confirm our status.

  """
    myself = netutils.Hostname.GetSysName()
    #temp instantiation of a config writer, used only to get the node list
    cfg = config.ConfigWriter()
    node_names = cfg.GetNodeNames(cfg.GetNodeList())
    del cfg
    retries = 6
    while retries > 0:
        votes = bootstrap.GatherMasterVotes(node_names)
        if not votes:
            # empty node list, this is a one node cluster
            return True
        if votes[0][0] is None:
            retries -= 1
            time.sleep(10)
            continue
        break
    if retries == 0:
        logging.critical(
            "Cluster inconsistent, most of the nodes didn't answer"
            " after multiple retries. Aborting startup")
        logging.critical("Use the --no-voting option if you understand what"
                         " effects it has on the cluster state")
        return False
    # here a real node is at the top of the list
    all_votes = sum(item[1] for item in votes)
    top_node, top_votes = votes[0]

    result = False
    if top_node != myself:
        logging.critical(
            "It seems we are not the master (top-voted node"
            " is %s with %d out of %d votes)", top_node, top_votes, all_votes)
    elif top_votes < all_votes - top_votes:
        logging.critical(
            "It seems we are not the master (%d votes for,"
            " %d votes against)", top_votes, all_votes - top_votes)
    else:
        result = True

    return result
示例#4
0
文件: masterd.py 项目: badp/ganeti
    def __init__(self):
        """Constructs a new GanetiContext object.

    There should be only a GanetiContext object at any time, so this
    function raises an error if this is not the case.

    """
        assert self.__class__._instance is None, "double GanetiContext instance"

        # Create global configuration object
        self.cfg = config.ConfigWriter()

        # Locking manager
        self.glm = locking.GanetiLockManager(
            self.cfg.GetNodeList(), self.cfg.GetNodeGroupList(),
            [inst.name for inst in self.cfg.GetAllInstancesInfo().values()],
            self.cfg.GetNetworkList())

        self.cfg.SetContext(self)

        # RPC runner
        self.rpc = rpc.RpcRunner(self.cfg, self.glm.AddToLockMonitor)

        # Job queue
        self.jobqueue = jqueue.JobQueue(self)

        # setting this also locks the class against attribute modifications
        self.__class__._instance = self
示例#5
0
文件: masterd.py 项目: badp/ganeti
def ActivateMasterIP():
    # activate ip
    cfg = config.ConfigWriter()
    master_params = cfg.GetMasterNetworkParameters()
    ems = cfg.GetUseExternalMipScript()
    runner = rpc.BootstrapRunner()
    # we use the node name, as the configuration is only available here yet
    result = runner.call_node_activate_master_ip(
        cfg.GetNodeName(master_params.uuid), master_params, ems)

    msg = result.fail_msg
    if msg:
        logging.error("Can't activate master IP address: %s", msg)
示例#6
0
文件: masterd.py 项目: badp/ganeti
def CheckMasterd(options, args):
    """Initial checks whether to run or exit with a failure.

  """
    if args:  # masterd doesn't take any arguments
        print >> sys.stderr, ("Usage: %s [-f] [-d]" % sys.argv[0])
        sys.exit(constants.EXIT_FAILURE)

    ssconf.CheckMaster(options.debug)

    try:
        options.uid = pwd.getpwnam(constants.MASTERD_USER).pw_uid
        options.gid = grp.getgrnam(constants.DAEMONS_GROUP).gr_gid
    except KeyError:
        print >> sys.stderr, (
            "User or group not existing on system: %s:%s" %
            (constants.MASTERD_USER, constants.DAEMONS_GROUP))
        sys.exit(constants.EXIT_FAILURE)

    # Determine static runtime architecture information
    runtime.InitArchInfo()

    # Check the configuration is sane before anything else
    try:
        config.ConfigWriter()
    except errors.ConfigVersionMismatch, err:
        v1 = "%s.%s.%s" % version.SplitVersion(err.args[0])
        v2 = "%s.%s.%s" % version.SplitVersion(err.args[1])
        print >> sys.stderr,  \
            ("Configuration version mismatch. The current Ganeti software"
             " expects version %s, but the on-disk configuration file has"
             " version %s. This is likely the result of upgrading the"
             " software without running the upgrade procedure. Please contact"
             " your cluster administrator or complete the upgrade using the"
             " cfgupgrade utility, after reading the upgrade notes." %
             (v1, v2))
        sys.exit(constants.EXIT_FAILURE)
 def _get_object(self):
     """Returns an instance of ConfigWriter"""
     cfg = config.ConfigWriter(cfg_file=self.cfg_file,
                               offline=True,
                               _getents=_StubGetEntResolver)
     return cfg
        compression_tools=compression_tools,
        enabled_user_shutdown=enabled_user_shutdown,
    )
    master_node_config = objects.Node(
        name=hostname.name,
        primary_ip=hostname.ip,
        secondary_ip=secondary_ip,
        serial_no=1,
        master_candidate=True,
        offline=False,
        drained=False,
        ctime=now,
        mtime=now,
    )
    InitConfig(constants.CONFIG_VERSION, cluster_config, master_node_config)
    cfg = config.ConfigWriter(offline=True)
    ssh.WriteKnownHostsFile(cfg, pathutils.SSH_KNOWN_HOSTS_FILE)
    cfg.Update(cfg.GetClusterInfo(), logging.error)
    ssconf.WriteSsconfFiles(cfg.GetSsconfValues())

    master_uuid = cfg.GetMasterNode()
    if modify_ssh_setup:
        ssh.InitPubKeyFile(master_uuid)
    # set up the inter-node password and certificate
    _InitGanetiServerSetup(hostname.name, cfg)

    logging.debug("Starting daemons")
    result = utils.RunCmd([pathutils.DAEMON_UTIL, "start-all"])
    if result.failed:
        raise errors.OpExecError("Could not start daemons, command %s"
                                 " had exitcode %s and error %s" %
示例#9
0
文件: bootstrap.py 项目: badp/ganeti
def MasterFailover(no_voting=False):
    """Failover the master node.

  This checks that we are not already the master, and will cause the
  current master to cease being master, and the non-master to become
  new master.

  @type no_voting: boolean
  @param no_voting: force the operation without remote nodes agreement
                      (dangerous)

  """
    sstore = ssconf.SimpleStore()

    old_master, new_master = ssconf.GetMasterAndMyself(sstore)
    node_names = sstore.GetNodeList()
    mc_list = sstore.GetMasterCandidates()

    if old_master == new_master:
        raise errors.OpPrereqError(
            "This commands must be run on the node"
            " where you want the new master to be."
            " %s is already the master" % old_master, errors.ECODE_INVAL)

    if new_master not in mc_list:
        mc_no_master = [name for name in mc_list if name != old_master]
        raise errors.OpPrereqError(
            "This node is not among the nodes marked"
            " as master candidates. Only these nodes"
            " can become masters. Current list of"
            " master candidates is:\n"
            "%s" % ("\n".join(mc_no_master)), errors.ECODE_STATE)

    if not no_voting:
        vote_list = GatherMasterVotes(node_names)

        if vote_list:
            voted_master = vote_list[0][0]
            if voted_master is None:
                raise errors.OpPrereqError(
                    "Cluster is inconsistent, most nodes did"
                    " not respond.", errors.ECODE_ENVIRON)
            elif voted_master != old_master:
                raise errors.OpPrereqError(
                    "I have a wrong configuration, I believe"
                    " the master is %s but the other nodes"
                    " voted %s. Please resync the configuration"
                    " of this node." % (old_master, voted_master),
                    errors.ECODE_STATE)
    # end checks

    rcode = 0

    logging.info("Setting master to %s, old master: %s", new_master,
                 old_master)

    try:
        # instantiate a real config writer, as we now know we have the
        # configuration data
        cfg = config.ConfigWriter(accept_foreign=True)

        old_master_node = cfg.GetNodeInfoByName(old_master)
        if old_master_node is None:
            raise errors.OpPrereqError(
                "Could not find old master node '%s' in"
                " cluster configuration." % old_master, errors.ECODE_NOENT)

        cluster_info = cfg.GetClusterInfo()
        new_master_node = cfg.GetNodeInfoByName(new_master)
        if new_master_node is None:
            raise errors.OpPrereqError(
                "Could not find new master node '%s' in"
                " cluster configuration." % new_master, errors.ECODE_NOENT)

        cluster_info.master_node = new_master_node.uuid
        # this will also regenerate the ssconf files, since we updated the
        # cluster info
        cfg.Update(cluster_info, logging.error)
    except errors.ConfigurationError, err:
        logging.error("Error while trying to set the new master: %s", str(err))
        return 1
示例#10
0
def InitCluster(
        cluster_name,
        mac_prefix,  # pylint: disable=R0913, R0914
        master_netmask,
        master_netdev,
        file_storage_dir,
        shared_file_storage_dir,
        gluster_storage_dir,
        candidate_pool_size,
        ssh_key_type,
        ssh_key_bits,
        secondary_ip=None,
        vg_name=None,
        beparams=None,
        nicparams=None,
        ndparams=None,
        hvparams=None,
        diskparams=None,
        enabled_hypervisors=None,
        modify_etc_hosts=True,
        modify_ssh_setup=True,
        maintain_node_health=False,
        drbd_helper=None,
        uid_pool=None,
        default_iallocator=None,
        default_iallocator_params=None,
        primary_ip_version=None,
        ipolicy=None,
        prealloc_wipe_disks=False,
        use_external_mip_script=False,
        hv_state=None,
        disk_state=None,
        enabled_disk_templates=None,
        install_image=None,
        zeroing_image=None,
        compression_tools=None,
        enabled_user_shutdown=False):
    """Initialise the cluster.

  @type candidate_pool_size: int
  @param candidate_pool_size: master candidate pool size

  @type enabled_disk_templates: list of string
  @param enabled_disk_templates: list of disk_templates to be used in this
    cluster

  @type enabled_user_shutdown: bool
  @param enabled_user_shutdown: whether user shutdown is enabled cluster
                                wide

  """
    # TODO: complete the docstring
    if config.ConfigWriter.IsCluster():
        raise errors.OpPrereqError("Cluster is already initialised",
                                   errors.ECODE_STATE)

    data_dir = vcluster.AddNodePrefix(pathutils.DATA_DIR)
    queue_dir = vcluster.AddNodePrefix(pathutils.QUEUE_DIR)
    archive_dir = vcluster.AddNodePrefix(pathutils.JOB_QUEUE_ARCHIVE_DIR)
    for ddir in [queue_dir, data_dir, archive_dir]:
        if os.path.isdir(ddir):
            for entry in os.listdir(ddir):
                if not os.path.isdir(os.path.join(ddir, entry)):
                    raise errors.OpPrereqError(
                        "%s contains non-directory entries like %s. Remove left-overs of an"
                        " old cluster before initialising a new one" %
                        (ddir, entry), errors.ECODE_STATE)

    if not enabled_hypervisors:
        raise errors.OpPrereqError(
            "Enabled hypervisors list must contain at"
            " least one member", errors.ECODE_INVAL)
    invalid_hvs = set(enabled_hypervisors) - constants.HYPER_TYPES
    if invalid_hvs:
        raise errors.OpPrereqError(
            "Enabled hypervisors contains invalid"
            " entries: %s" % invalid_hvs, errors.ECODE_INVAL)

    _InitCheckEnabledDiskTemplates(enabled_disk_templates)

    try:
        ipcls = netutils.IPAddress.GetClassFromIpVersion(primary_ip_version)
    except errors.ProgrammerError:
        raise errors.OpPrereqError(
            "Invalid primary ip version: %d." % primary_ip_version,
            errors.ECODE_INVAL)

    hostname = netutils.GetHostname(family=ipcls.family)
    if not ipcls.IsValid(hostname.ip):
        raise errors.OpPrereqError(
            "This host's IP (%s) is not a valid IPv%d"
            " address." % (hostname.ip, primary_ip_version),
            errors.ECODE_INVAL)

    if ipcls.IsLoopback(hostname.ip):
        raise errors.OpPrereqError(
            "This host's IP (%s) resolves to a loopback"
            " address. Please fix DNS or %s." %
            (hostname.ip, pathutils.ETC_HOSTS), errors.ECODE_ENVIRON)

    if not ipcls.Own(hostname.ip):
        raise errors.OpPrereqError(
            "Inconsistency: this host's name resolves"
            " to %s,\nbut this ip address does not"
            " belong to this host" % hostname.ip, errors.ECODE_ENVIRON)

    clustername = netutils.GetHostname(name=cluster_name, family=ipcls.family)

    if netutils.TcpPing(clustername.ip,
                        constants.DEFAULT_NODED_PORT,
                        timeout=5):
        raise errors.OpPrereqError("Cluster IP already active",
                                   errors.ECODE_NOTUNIQUE)

    if not secondary_ip:
        if primary_ip_version == constants.IP6_VERSION:
            raise errors.OpPrereqError(
                "When using a IPv6 primary address, a valid"
                " IPv4 address must be given as secondary", errors.ECODE_INVAL)
        secondary_ip = hostname.ip

    if not netutils.IP4Address.IsValid(secondary_ip):
        raise errors.OpPrereqError(
            "Secondary IP address (%s) has to be a valid"
            " IPv4 address." % secondary_ip, errors.ECODE_INVAL)

    if not netutils.IP4Address.Own(secondary_ip):
        raise errors.OpPrereqError(
            "You gave %s as secondary IP,"
            " but it does not belong to this host." % secondary_ip,
            errors.ECODE_ENVIRON)

    if master_netmask is not None:
        if not ipcls.ValidateNetmask(master_netmask):
            raise errors.OpPrereqError(
                "CIDR netmask (%s) not valid for IPv%s " %
                (master_netmask, primary_ip_version), errors.ECODE_INVAL)
    else:
        master_netmask = ipcls.iplen

    if vg_name:
        # Check if volume group is valid
        vgstatus = utils.CheckVolumeGroupSize(utils.ListVolumeGroups(),
                                              vg_name, constants.MIN_VG_SIZE)
        if vgstatus:
            raise errors.OpPrereqError("Error: %s" % vgstatus,
                                       errors.ECODE_INVAL)

    drbd_enabled = constants.DT_DRBD8 in enabled_disk_templates
    _InitCheckDrbdHelper(drbd_helper, drbd_enabled)

    logging.debug("Stopping daemons (if any are running)")
    result = utils.RunCmd([pathutils.DAEMON_UTIL, "stop-all"])
    if result.failed:
        raise errors.OpExecError("Could not stop daemons, command %s"
                                 " had exitcode %s and error '%s'" %
                                 (result.cmd, result.exit_code, result.output))

    file_storage_dir = _PrepareFileStorage(enabled_disk_templates,
                                           file_storage_dir)
    shared_file_storage_dir = _PrepareSharedFileStorage(
        enabled_disk_templates, shared_file_storage_dir)
    gluster_storage_dir = _PrepareGlusterStorage(enabled_disk_templates,
                                                 gluster_storage_dir)

    if not re.match("^[0-9a-z]{2}:[0-9a-z]{2}:[0-9a-z]{2}$", mac_prefix):
        raise errors.OpPrereqError(
            "Invalid mac prefix given '%s'" % mac_prefix, errors.ECODE_INVAL)

    if not nicparams.get('mode', None) == constants.NIC_MODE_OVS:
        # Do not do this check if mode=openvswitch, since the openvswitch is not
        # created yet
        result = utils.RunCmd(["ip", "link", "show", "dev", master_netdev])
        if result.failed:
            raise errors.OpPrereqError(
                "Invalid master netdev given (%s): '%s'" %
                (master_netdev, result.output.strip()), errors.ECODE_INVAL)

    dirs = [(pathutils.RUN_DIR, constants.RUN_DIRS_MODE)]
    utils.EnsureDirs(dirs)

    objects.UpgradeBeParams(beparams)
    utils.ForceDictType(beparams, constants.BES_PARAMETER_TYPES)
    utils.ForceDictType(nicparams, constants.NICS_PARAMETER_TYPES)

    objects.NIC.CheckParameterSyntax(nicparams)

    full_ipolicy = objects.FillIPolicy(constants.IPOLICY_DEFAULTS, ipolicy)
    _RestrictIpolicyToEnabledDiskTemplates(full_ipolicy,
                                           enabled_disk_templates)

    if ndparams is not None:
        utils.ForceDictType(ndparams, constants.NDS_PARAMETER_TYPES)
    else:
        ndparams = dict(constants.NDC_DEFAULTS)

    # This is ugly, as we modify the dict itself
    # FIXME: Make utils.ForceDictType pure functional or write a wrapper
    # around it
    if hv_state:
        for hvname, hvs_data in hv_state.items():
            utils.ForceDictType(hvs_data, constants.HVSTS_PARAMETER_TYPES)
            hv_state[hvname] = objects.Cluster.SimpleFillHvState(hvs_data)
    else:
        hv_state = dict((hvname, constants.HVST_DEFAULTS)
                        for hvname in enabled_hypervisors)

    # FIXME: disk_state has no default values yet
    if disk_state:
        for storage, ds_data in disk_state.items():
            if storage not in constants.DS_VALID_TYPES:
                raise errors.OpPrereqError(
                    "Invalid storage type in disk state: %s" % storage,
                    errors.ECODE_INVAL)
            for ds_name, state in ds_data.items():
                utils.ForceDictType(state, constants.DSS_PARAMETER_TYPES)
                ds_data[ds_name] = objects.Cluster.SimpleFillDiskState(state)

    # hvparams is a mapping of hypervisor->hvparams dict
    for hv_name, hv_params in hvparams.items():
        utils.ForceDictType(hv_params, constants.HVS_PARAMETER_TYPES)
        hv_class = hypervisor.GetHypervisor(hv_name)
        hv_class.CheckParameterSyntax(hv_params)

    # diskparams is a mapping of disk-template->diskparams dict
    for template, dt_params in diskparams.items():
        param_keys = set(dt_params.keys())
        default_param_keys = set(constants.DISK_DT_DEFAULTS[template].keys())
        if param_keys > default_param_keys:
            unknown_params = param_keys - default_param_keys
            raise errors.OpPrereqError(
                "Invalid parameters for disk template %s:"
                " %s" % (template, utils.CommaJoin(unknown_params)),
                errors.ECODE_INVAL)
        utils.ForceDictType(dt_params, constants.DISK_DT_TYPES)
        if template == constants.DT_DRBD8 and vg_name is not None:
            # The default METAVG value is equal to the VG name set at init time,
            # if provided
            dt_params[constants.DRBD_DEFAULT_METAVG] = vg_name

    try:
        utils.VerifyDictOptions(diskparams, constants.DISK_DT_DEFAULTS)
    except errors.OpPrereqError as err:
        raise errors.OpPrereqError("While verify diskparam options: %s" % err,
                                   errors.ECODE_INVAL)

    # set up ssh config and /etc/hosts
    rsa_sshkey = ""
    dsa_sshkey = ""
    if os.path.isfile(pathutils.SSH_HOST_RSA_PUB):
        sshline = utils.ReadFile(pathutils.SSH_HOST_RSA_PUB)
        rsa_sshkey = sshline.split(" ")[1]
    if os.path.isfile(pathutils.SSH_HOST_DSA_PUB):
        sshline = utils.ReadFile(pathutils.SSH_HOST_DSA_PUB)
        dsa_sshkey = sshline.split(" ")[1]
    if not rsa_sshkey and not dsa_sshkey:
        raise errors.OpPrereqError("Failed to find SSH public keys",
                                   errors.ECODE_ENVIRON)

    if modify_etc_hosts:
        utils.AddHostToEtcHosts(hostname.name, hostname.ip)

    if modify_ssh_setup:
        ssh.InitSSHSetup(ssh_key_type, ssh_key_bits)

    if default_iallocator is not None:
        alloc_script = utils.FindFile(default_iallocator,
                                      constants.IALLOCATOR_SEARCH_PATH,
                                      os.path.isfile)
        if alloc_script is None:
            raise errors.OpPrereqError(
                "Invalid default iallocator script '%s'"
                " specified" % default_iallocator, errors.ECODE_INVAL)
    else:
        # default to htools
        if utils.FindFile(constants.IALLOC_HAIL,
                          constants.IALLOCATOR_SEARCH_PATH, os.path.isfile):
            default_iallocator = constants.IALLOC_HAIL

    # check if we have all the users we need
    try:
        runtime.GetEnts()
    except errors.ConfigurationError as err:
        raise errors.OpPrereqError(
            "Required system user/group missing: %s" % err,
            errors.ECODE_ENVIRON)

    candidate_certs = {}

    now = time.time()

    if compression_tools is not None:
        cluster.CheckCompressionTools(compression_tools)

    initial_dc_config = dict(active=True,
                             interval=int(constants.MOND_TIME_INTERVAL * 1e6))
    data_collectors = dict((name, initial_dc_config.copy())
                           for name in constants.DATA_COLLECTOR_NAMES)

    # init of cluster config file
    cluster_config = objects.Cluster(
        serial_no=1,
        rsahostkeypub=rsa_sshkey,
        dsahostkeypub=dsa_sshkey,
        highest_used_port=(constants.FIRST_DRBD_PORT - 1),
        mac_prefix=mac_prefix,
        volume_group_name=vg_name,
        tcpudp_port_pool=set(),
        master_ip=clustername.ip,
        master_netmask=master_netmask,
        master_netdev=master_netdev,
        cluster_name=clustername.name,
        file_storage_dir=file_storage_dir,
        shared_file_storage_dir=shared_file_storage_dir,
        gluster_storage_dir=gluster_storage_dir,
        enabled_hypervisors=enabled_hypervisors,
        beparams={constants.PP_DEFAULT: beparams},
        nicparams={constants.PP_DEFAULT: nicparams},
        ndparams=ndparams,
        hvparams=hvparams,
        diskparams=diskparams,
        candidate_pool_size=candidate_pool_size,
        modify_etc_hosts=modify_etc_hosts,
        modify_ssh_setup=modify_ssh_setup,
        uid_pool=uid_pool,
        ctime=now,
        mtime=now,
        maintain_node_health=maintain_node_health,
        data_collectors=data_collectors,
        drbd_usermode_helper=drbd_helper,
        default_iallocator=default_iallocator,
        default_iallocator_params=default_iallocator_params,
        primary_ip_family=ipcls.family,
        prealloc_wipe_disks=prealloc_wipe_disks,
        use_external_mip_script=use_external_mip_script,
        ipolicy=full_ipolicy,
        hv_state_static=hv_state,
        disk_state_static=disk_state,
        enabled_disk_templates=enabled_disk_templates,
        candidate_certs=candidate_certs,
        osparams={},
        osparams_private_cluster={},
        install_image=install_image,
        zeroing_image=zeroing_image,
        compression_tools=compression_tools,
        enabled_user_shutdown=enabled_user_shutdown,
        ssh_key_type=ssh_key_type,
        ssh_key_bits=ssh_key_bits,
    )
    master_node_config = objects.Node(
        name=hostname.name,
        primary_ip=hostname.ip,
        secondary_ip=secondary_ip,
        serial_no=1,
        master_candidate=True,
        offline=False,
        drained=False,
        ctime=now,
        mtime=now,
    )
    InitConfig(constants.CONFIG_VERSION, cluster_config, master_node_config)
    cfg = config.ConfigWriter(offline=True)
    ssh.WriteKnownHostsFile(cfg, pathutils.SSH_KNOWN_HOSTS_FILE)
    cfg.Update(cfg.GetClusterInfo(), logging.error)
    ssconf.WriteSsconfFiles(cfg.GetSsconfValues())

    master_uuid = cfg.GetMasterNode()
    if modify_ssh_setup:
        ssh.InitPubKeyFile(master_uuid, ssh_key_type)
    # set up the inter-node password and certificate
    _InitGanetiServerSetup(hostname.name, cfg)

    logging.debug("Starting daemons")
    result = utils.RunCmd([pathutils.DAEMON_UTIL, "start-all"])
    if result.failed:
        raise errors.OpExecError("Could not start daemons, command %s"
                                 " had exitcode %s and error %s" %
                                 (result.cmd, result.exit_code, result.output))

    _WaitForMasterDaemon()