123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527 |
- // Copyright 2015 CoreOS, Inc.
- // Copyright 2015 Rancher Labs, Inc.
- //
- // Licensed under the Apache License, Version 2.0 (the "License");
- // you may not use this file except in compliance with the License.
- // You may obtain a copy of the License at
- //
- // http://www.apache.org/licenses/LICENSE-2.0
- //
- // Unless required by applicable law or agreed to in writing, software
- // distributed under the License is distributed on an "AS IS" BASIS,
- // WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- // See the License for the specific language governing permissions and
- // limitations under the License.
- package cloudinit
- import (
- "flag"
- "io/ioutil"
- "os"
- "path"
- "strings"
- "sync"
- "time"
- "gopkg.in/yaml.v2"
- log "github.com/Sirupsen/logrus"
- "github.com/coreos/coreos-cloudinit/config"
- "github.com/coreos/coreos-cloudinit/datasource"
- "github.com/coreos/coreos-cloudinit/datasource/configdrive"
- "github.com/coreos/coreos-cloudinit/datasource/file"
- "github.com/coreos/coreos-cloudinit/datasource/metadata/digitalocean"
- "github.com/coreos/coreos-cloudinit/datasource/metadata/ec2"
- "github.com/coreos/coreos-cloudinit/datasource/proc_cmdline"
- "github.com/coreos/coreos-cloudinit/datasource/url"
- "github.com/coreos/coreos-cloudinit/initialize"
- "github.com/coreos/coreos-cloudinit/pkg"
- "github.com/coreos/coreos-cloudinit/system"
- "github.com/rancherio/os/cmd/cloudinit/hostname"
- rancherNetwork "github.com/rancherio/os/cmd/network"
- rancherConfig "github.com/rancherio/os/config"
- "github.com/rancherio/os/util"
- )
- const (
- datasourceInterval = 100 * time.Millisecond
- datasourceMaxInterval = 30 * time.Second
- datasourceTimeout = 5 * time.Minute
- )
- var (
- baseConfigDir string
- outputDir string
- outputFile string
- metaDataFile string
- scriptFile string
- rancherYml string
- save bool
- execute bool
- network bool
- sshKeyName string
- flags *flag.FlagSet
- )
- func init() {
- flags = flag.NewFlagSet(os.Args[0], flag.ContinueOnError)
- flags.StringVar(&baseConfigDir, "base-config-dir", "/var/lib/rancher/conf/cloud-config.d", "base cloud config")
- flags.StringVar(&outputDir, "dir", "/var/lib/rancher/conf", "working directory")
- flags.StringVar(&outputFile, "file", "cloud-config-processed.yml", "output cloud config file name")
- flags.StringVar(&metaDataFile, "metadata", "metadata", "output metdata file name")
- flags.StringVar(&scriptFile, "script-file", "cloud-config-script", "output cloud config script file name")
- flags.StringVar(&rancherYml, "rancher", "cloud-config-rancher.yml", "output cloud config rancher file name")
- flags.StringVar(&sshKeyName, "ssh-key-name", "rancheros-cloud-config", "SSH key name")
- flags.BoolVar(&network, "network", true, "use network based datasources")
- flags.BoolVar(&save, "save", false, "save cloud config and exit")
- flags.BoolVar(&execute, "execute", false, "execute saved cloud config")
- }
- func saveFiles(cloudConfigBytes, scriptBytes []byte, metadata datasource.Metadata) error {
- scriptOutput := path.Join(outputDir, scriptFile)
- cloudConfigOutput := path.Join(outputDir, outputFile)
- rancherYmlOutput := path.Join(outputDir, rancherYml)
- metaDataOutput := path.Join(outputDir, metaDataFile)
- os.Remove(scriptOutput)
- os.Remove(cloudConfigOutput)
- os.Remove(rancherYmlOutput)
- os.Remove(metaDataOutput)
- if len(scriptBytes) > 0 {
- log.Infof("Writing to %s", scriptOutput)
- if err := ioutil.WriteFile(scriptOutput, scriptBytes, 500); err != nil {
- log.Errorf("Error while writing file %s: %v", scriptOutput, err)
- return err
- }
- }
- cloudConfigBytes = append([]byte("#cloud-config\n"), cloudConfigBytes...)
- log.Infof("Writing to %s", cloudConfigOutput)
- if err := ioutil.WriteFile(cloudConfigOutput, cloudConfigBytes, 500); err != nil {
- log.Errorf("Error while writing file %s: %v", cloudConfigOutput, err)
- return err
- }
- ccData := make(map[string]interface{})
- if err := yaml.Unmarshal(cloudConfigBytes, ccData); err != nil {
- return err
- }
- if rancher, ok := ccData["rancher"]; ok {
- bytes, err := yaml.Marshal(rancher)
- if err != nil {
- return err
- }
- if err = ioutil.WriteFile(rancherYmlOutput, bytes, 400); err != nil {
- return err
- }
- }
- metaDataBytes, err := yaml.Marshal(metadata)
- if err != nil {
- return err
- }
- if err = ioutil.WriteFile(metaDataOutput, metaDataBytes, 400); err != nil {
- return err
- }
- return nil
- }
- func currentDatasource() (datasource.Datasource, error) {
- cfg, err := rancherConfig.LoadConfig()
- if err != nil {
- log.Fatalf("Failed to read rancher config %v", err)
- }
- dss := getDatasources(cfg)
- if len(dss) == 0 {
- return nil, nil
- }
- ds := selectDatasource(dss)
- return ds, nil
- }
- func mergeBaseConfig(current, currentScript []byte) ([]byte, []byte, error) {
- files, err := ioutil.ReadDir(baseConfigDir)
- if err != nil {
- if os.IsNotExist(err) {
- log.Infof("%s does not exist, not merging", baseConfigDir)
- return current, currentScript, nil
- }
- log.Errorf("Failed to read %s: %v", baseConfigDir, err)
- return nil, nil, err
- }
- scriptResult := currentScript
- result := []byte{}
- for _, file := range files {
- if file.IsDir() || strings.HasPrefix(file.Name(), ".") {
- continue
- }
- input := path.Join(baseConfigDir, file.Name())
- content, err := ioutil.ReadFile(input)
- if err != nil {
- log.Errorf("Failed to read %s: %v", input, err)
- // ignore error
- continue
- }
- if config.IsScript(string(content)) {
- scriptResult = content
- continue
- }
- log.Infof("Merging %s", input)
- if isCompose(string(content)) {
- content, err = toCompose(content)
- if err != nil {
- log.Errorf("Failed to convert %s to cloud-config syntax: %v", input, err)
- }
- }
- result, err = util.MergeBytes(result, content)
- if err != nil {
- log.Errorf("Failed to merge bytes: %v", err)
- return nil, nil, err
- }
- }
- if len(result) == 0 {
- return current, scriptResult, nil
- } else {
- result, err := util.MergeBytes(result, current)
- return result, scriptResult, err
- }
- }
- func saveCloudConfig() error {
- var userDataBytes []byte
- var metadata datasource.Metadata
- ds, err := currentDatasource()
- if err != nil {
- log.Errorf("Failed to select datasource: %v", err)
- return err
- }
- if ds != nil {
- log.Infof("Fetching user-data from datasource %v", ds.Type())
- userDataBytes, err = ds.FetchUserdata()
- if err != nil {
- log.Errorf("Failed fetching user-data from datasource: %v", err)
- return err
- }
- log.Infof("Fetching meta-data from datasource of type %v", ds.Type())
- metadata, err = ds.FetchMetadata()
- if err != nil {
- log.Errorf("Failed fetching meta-data from datasource: %v", err)
- return err
- }
- }
- userDataBytes = substituteUserDataVars(userDataBytes, metadata)
- userData := string(userDataBytes)
- scriptBytes := []byte{}
- if config.IsScript(userData) {
- scriptBytes = userDataBytes
- userDataBytes = []byte{}
- } else if isCompose(userData) {
- if userDataBytes, err = toCompose(userDataBytes); err != nil {
- log.Errorf("Failed to convert to compose syntax: %v", err)
- return err
- }
- } else if config.IsCloudConfig(userData) {
- // nothing to do
- } else {
- log.Errorf("Unrecognized cloud-init\n%s", userData)
- userDataBytes = []byte{}
- }
- if userDataBytes, scriptBytes, err = mergeBaseConfig(userDataBytes, scriptBytes); err != nil {
- log.Errorf("Failed to merge base config: %v", err)
- return err
- }
- return saveFiles(userDataBytes, scriptBytes, metadata)
- }
- func getSaveCloudConfig() (*config.CloudConfig, error) {
- cloudConfig := path.Join(outputDir, outputFile)
- ds := file.NewDatasource(cloudConfig)
- if !ds.IsAvailable() {
- log.Infof("%s does not exist", cloudConfig)
- return nil, nil
- }
- ccBytes, err := ds.FetchUserdata()
- if err != nil {
- log.Errorf("Failed to read user-data from %s: %v", cloudConfig, err)
- return nil, err
- }
- var cc config.CloudConfig
- err = yaml.Unmarshal(ccBytes, &cc)
- if err != nil {
- log.Errorf("Failed to unmarshall user-data from %s: %v", cloudConfig, err)
- return nil, err
- }
- return &cc, err
- }
- func executeCloudConfig() error {
- ccu, err := getSaveCloudConfig()
- if err != nil {
- return err
- }
- var metadata datasource.Metadata
- metaDataBytes, err := ioutil.ReadFile(path.Join(outputDir, metaDataFile))
- if err != nil {
- return err
- }
- if err = yaml.Unmarshal(metaDataBytes, &metadata); err != nil {
- return err
- }
- log.Info("Merging cloud-config from meta-data and user-data")
- cc := mergeConfigs(ccu, metadata)
- if cc.Hostname != "" {
- //set hostname
- if err := hostname.SetHostname(cc.Hostname); err != nil {
- log.Fatal(err)
- }
- }
- if len(cc.SSHAuthorizedKeys) > 0 {
- authorizeSSHKeys("rancher", cc.SSHAuthorizedKeys, sshKeyName)
- authorizeSSHKeys("docker", cc.SSHAuthorizedKeys, sshKeyName)
- }
- for _, user := range cc.Users {
- if user.Name == "" {
- continue
- }
- if len(user.SSHAuthorizedKeys) > 0 {
- authorizeSSHKeys(user.Name, user.SSHAuthorizedKeys, sshKeyName)
- }
- }
- for _, file := range cc.WriteFiles {
- f := system.File{File: file}
- fullPath, err := system.WriteFile(&f, "/")
- if err != nil {
- log.Fatal(err)
- }
- log.Printf("Wrote file %s to filesystem", fullPath)
- }
- return nil
- }
- func Main() {
- flags.Parse(rancherConfig.FilterGlobalConfig(os.Args[1:]))
- if save {
- err := saveCloudConfig()
- if err != nil {
- log.Fatalf("Failed to save cloud config: %v", err)
- }
- }
- if execute {
- err := executeCloudConfig()
- if err != nil {
- log.Fatalf("Failed to save cloud config: %v", err)
- }
- }
- }
- // mergeConfigs merges certain options from md (meta-data from the datasource)
- // onto cc (a CloudConfig derived from user-data), if they are not already set
- // on cc (i.e. user-data always takes precedence)
- func mergeConfigs(cc *config.CloudConfig, md datasource.Metadata) (out config.CloudConfig) {
- if cc != nil {
- out = *cc
- }
- if md.Hostname != "" {
- if out.Hostname != "" {
- log.Infof("Warning: user-data hostname (%s) overrides metadata hostname (%s)\n", out.Hostname, md.Hostname)
- } else {
- out.Hostname = md.Hostname
- }
- }
- for _, key := range md.SSHPublicKeys {
- out.SSHAuthorizedKeys = append(out.SSHAuthorizedKeys, key)
- }
- return
- }
- // getDatasources creates a slice of possible Datasources for cloudinit based
- // on the different source command-line flags.
- func getDatasources(cfg *rancherConfig.Config) []datasource.Datasource {
- dss := make([]datasource.Datasource, 0, 5)
- for _, ds := range cfg.CloudInit.Datasources {
- parts := strings.SplitN(ds, ":", 2)
- switch parts[0] {
- case "ec2":
- if network {
- if len(parts) == 1 {
- dss = append(dss, ec2.NewDatasource(ec2.DefaultAddress))
- } else {
- dss = append(dss, ec2.NewDatasource(parts[1]))
- }
- }
- case "file":
- if len(parts) == 2 {
- dss = append(dss, file.NewDatasource(parts[1]))
- }
- case "url":
- if network {
- if len(parts) == 2 {
- dss = append(dss, url.NewDatasource(parts[1]))
- }
- }
- case "cmdline":
- if network {
- if len(parts) == 1 {
- dss = append(dss, proc_cmdline.NewDatasource())
- }
- }
- case "configdrive":
- if len(parts) == 2 {
- dss = append(dss, configdrive.NewDatasource(parts[1]))
- }
- case "digitalocean":
- if network {
- if len(parts) == 1 {
- dss = append(dss, digitalocean.NewDatasource(digitalocean.DefaultAddress))
- } else {
- dss = append(dss, digitalocean.NewDatasource(parts[1]))
- }
- } else {
- enableDoLinkLocal()
- }
- case "gce":
- if network {
- gceCloudConfigFile, err := GetAndCreateGceDataSourceFilename()
- if err != nil {
- log.Errorf("Could not retrieve GCE CloudConfig %s", err)
- continue
- }
- dss = append(dss, file.NewDatasource(gceCloudConfigFile))
- }
- }
- }
- return dss
- }
- func enableDoLinkLocal() {
- err := rancherNetwork.ApplyNetworkConfigs(&rancherConfig.NetworkConfig{
- Interfaces: map[string]rancherConfig.InterfaceConfig{
- "eth0": {
- IPV4LL: true,
- },
- },
- })
- if err != nil {
- log.Errorf("Failed to apply link local on eth0: %v", err)
- }
- }
- // selectDatasource attempts to choose a valid Datasource to use based on its
- // current availability. The first Datasource to report to be available is
- // returned. Datasources will be retried if possible if they are not
- // immediately available. If all Datasources are permanently unavailable or
- // datasourceTimeout is reached before one becomes available, nil is returned.
- func selectDatasource(sources []datasource.Datasource) datasource.Datasource {
- ds := make(chan datasource.Datasource)
- stop := make(chan struct{})
- var wg sync.WaitGroup
- for _, s := range sources {
- wg.Add(1)
- go func(s datasource.Datasource) {
- defer wg.Done()
- duration := datasourceInterval
- for {
- log.Infof("Checking availability of %q\n", s.Type())
- if s.IsAvailable() {
- ds <- s
- return
- } else if !s.AvailabilityChanges() {
- return
- }
- select {
- case <-stop:
- return
- case <-time.After(duration):
- duration = pkg.ExpBackoff(duration, datasourceMaxInterval)
- }
- }
- }(s)
- }
- done := make(chan struct{})
- go func() {
- wg.Wait()
- close(done)
- }()
- var s datasource.Datasource
- select {
- case s = <-ds:
- case <-done:
- case <-time.After(datasourceTimeout):
- }
- close(stop)
- return s
- }
- func isCompose(content string) bool {
- return strings.HasPrefix(content, "#compose\n")
- }
- func toCompose(bytes []byte) ([]byte, error) {
- compose := make(map[interface{}]interface{})
- err := yaml.Unmarshal(bytes, &compose)
- if err != nil {
- return nil, err
- }
- return yaml.Marshal(map[interface{}]interface{}{
- "rancher": map[interface{}]interface{}{
- "services": compose,
- },
- })
- }
- func substituteUserDataVars(userDataBytes []byte, metadata datasource.Metadata) []byte {
- env := initialize.NewEnvironment("", "", "", "", metadata)
- userData := env.Apply(string(userDataBytes))
- return []byte(userData)
- }
|