daemon.go 25 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816
  1. package main
  2. import (
  3. "context"
  4. "crypto/tls"
  5. "fmt"
  6. "net"
  7. "os"
  8. "path/filepath"
  9. "runtime"
  10. "sort"
  11. "strings"
  12. "time"
  13. containerddefaults "github.com/containerd/containerd/defaults"
  14. "github.com/docker/docker/api"
  15. apiserver "github.com/docker/docker/api/server"
  16. buildbackend "github.com/docker/docker/api/server/backend/build"
  17. "github.com/docker/docker/api/server/middleware"
  18. "github.com/docker/docker/api/server/router"
  19. "github.com/docker/docker/api/server/router/build"
  20. checkpointrouter "github.com/docker/docker/api/server/router/checkpoint"
  21. "github.com/docker/docker/api/server/router/container"
  22. distributionrouter "github.com/docker/docker/api/server/router/distribution"
  23. grpcrouter "github.com/docker/docker/api/server/router/grpc"
  24. "github.com/docker/docker/api/server/router/image"
  25. "github.com/docker/docker/api/server/router/network"
  26. pluginrouter "github.com/docker/docker/api/server/router/plugin"
  27. sessionrouter "github.com/docker/docker/api/server/router/session"
  28. swarmrouter "github.com/docker/docker/api/server/router/swarm"
  29. systemrouter "github.com/docker/docker/api/server/router/system"
  30. "github.com/docker/docker/api/server/router/volume"
  31. buildkit "github.com/docker/docker/builder/builder-next"
  32. "github.com/docker/docker/builder/dockerfile"
  33. "github.com/docker/docker/cli/debug"
  34. "github.com/docker/docker/cmd/dockerd/trap"
  35. "github.com/docker/docker/daemon"
  36. "github.com/docker/docker/daemon/cluster"
  37. "github.com/docker/docker/daemon/config"
  38. "github.com/docker/docker/daemon/listeners"
  39. "github.com/docker/docker/dockerversion"
  40. "github.com/docker/docker/libcontainerd/supervisor"
  41. dopts "github.com/docker/docker/opts"
  42. "github.com/docker/docker/pkg/authorization"
  43. "github.com/docker/docker/pkg/homedir"
  44. "github.com/docker/docker/pkg/jsonmessage"
  45. "github.com/docker/docker/pkg/pidfile"
  46. "github.com/docker/docker/pkg/plugingetter"
  47. "github.com/docker/docker/pkg/rootless"
  48. "github.com/docker/docker/pkg/sysinfo"
  49. "github.com/docker/docker/pkg/system"
  50. "github.com/docker/docker/plugin"
  51. "github.com/docker/docker/runconfig"
  52. "github.com/docker/go-connections/tlsconfig"
  53. "github.com/moby/buildkit/session"
  54. swarmapi "github.com/moby/swarmkit/v2/api"
  55. "github.com/pkg/errors"
  56. "github.com/sirupsen/logrus"
  57. "github.com/spf13/pflag"
  58. )
  59. // DaemonCli represents the daemon CLI.
  60. type DaemonCli struct {
  61. *config.Config
  62. configFile *string
  63. flags *pflag.FlagSet
  64. api apiserver.Server
  65. d *daemon.Daemon
  66. authzMiddleware *authorization.Middleware // authzMiddleware enables to dynamically reload the authorization plugins
  67. }
  68. // NewDaemonCli returns a daemon CLI
  69. func NewDaemonCli() *DaemonCli {
  70. return &DaemonCli{}
  71. }
  72. func (cli *DaemonCli) start(opts *daemonOptions) (err error) {
  73. if cli.Config, err = loadDaemonCliConfig(opts); err != nil {
  74. return err
  75. }
  76. tlsConfig, err := newAPIServerTLSConfig(cli.Config)
  77. if err != nil {
  78. return err
  79. }
  80. if opts.Validate {
  81. // If config wasn't OK we wouldn't have made it this far.
  82. _, _ = fmt.Fprintln(os.Stderr, "configuration OK")
  83. return nil
  84. }
  85. configureProxyEnv(cli.Config)
  86. configureDaemonLogs(cli.Config)
  87. logrus.Info("Starting up")
  88. cli.configFile = &opts.configFile
  89. cli.flags = opts.flags
  90. if cli.Config.Debug {
  91. debug.Enable()
  92. }
  93. if cli.Config.Experimental {
  94. logrus.Warn("Running experimental build")
  95. }
  96. if cli.Config.IsRootless() {
  97. logrus.Warn("Running in rootless mode. This mode has feature limitations.")
  98. }
  99. if rootless.RunningWithRootlessKit() {
  100. logrus.Info("Running with RootlessKit integration")
  101. if !cli.Config.IsRootless() {
  102. return fmt.Errorf("rootless mode needs to be enabled for running with RootlessKit")
  103. }
  104. }
  105. // return human-friendly error before creating files
  106. if runtime.GOOS == "linux" && os.Geteuid() != 0 {
  107. return fmt.Errorf("dockerd needs to be started with root privileges. To run dockerd in rootless mode as an unprivileged user, see https://docs.docker.com/go/rootless/")
  108. }
  109. if err := setDefaultUmask(); err != nil {
  110. return err
  111. }
  112. // Create the daemon root before we create ANY other files (PID, or migrate keys)
  113. // to ensure the appropriate ACL is set (particularly relevant on Windows)
  114. if err := daemon.CreateDaemonRoot(cli.Config); err != nil {
  115. return err
  116. }
  117. if err := system.MkdirAll(cli.Config.ExecRoot, 0700); err != nil {
  118. return err
  119. }
  120. potentiallyUnderRuntimeDir := []string{cli.Config.ExecRoot}
  121. if cli.Pidfile != "" {
  122. if err = system.MkdirAll(filepath.Dir(cli.Pidfile), 0o755); err != nil {
  123. return errors.Wrap(err, "failed to create pidfile directory")
  124. }
  125. if err = pidfile.Write(cli.Pidfile, os.Getpid()); err != nil {
  126. return errors.Wrapf(err, "failed to start daemon, ensure docker is not running or delete %s", cli.Pidfile)
  127. }
  128. potentiallyUnderRuntimeDir = append(potentiallyUnderRuntimeDir, cli.Pidfile)
  129. defer func() {
  130. if err := os.Remove(cli.Pidfile); err != nil {
  131. logrus.Error(err)
  132. }
  133. }()
  134. }
  135. if cli.Config.IsRootless() {
  136. // Set sticky bit if XDG_RUNTIME_DIR is set && the file is actually under XDG_RUNTIME_DIR
  137. if _, err := homedir.StickRuntimeDirContents(potentiallyUnderRuntimeDir); err != nil {
  138. // StickRuntimeDirContents returns nil error if XDG_RUNTIME_DIR is just unset
  139. logrus.WithError(err).Warn("cannot set sticky bit on files under XDG_RUNTIME_DIR")
  140. }
  141. }
  142. hosts, err := loadListeners(cli, tlsConfig)
  143. if err != nil {
  144. return errors.Wrap(err, "failed to load listeners")
  145. }
  146. ctx, cancel := context.WithCancel(context.Background())
  147. waitForContainerDShutdown, err := cli.initContainerd(ctx)
  148. if waitForContainerDShutdown != nil {
  149. defer waitForContainerDShutdown(10 * time.Second)
  150. }
  151. if err != nil {
  152. cancel()
  153. return err
  154. }
  155. defer cancel()
  156. stopc := make(chan bool)
  157. defer close(stopc)
  158. trap.Trap(func() {
  159. cli.stop()
  160. <-stopc // wait for daemonCli.start() to return
  161. }, logrus.StandardLogger())
  162. // Notify that the API is active, but before daemon is set up.
  163. preNotifyReady()
  164. pluginStore := plugin.NewStore()
  165. cli.authzMiddleware = initMiddlewares(&cli.api, cli.Config, pluginStore)
  166. d, err := daemon.NewDaemon(ctx, cli.Config, pluginStore, cli.authzMiddleware)
  167. if err != nil {
  168. return errors.Wrap(err, "failed to start daemon")
  169. }
  170. d.StoreHosts(hosts)
  171. // validate after NewDaemon has restored enabled plugins. Don't change order.
  172. if err := validateAuthzPlugins(cli.Config.AuthorizationPlugins, pluginStore); err != nil {
  173. return errors.Wrap(err, "failed to validate authorization plugin")
  174. }
  175. cli.d = d
  176. if err := startMetricsServer(cli.Config.MetricsAddress); err != nil {
  177. return errors.Wrap(err, "failed to start metrics server")
  178. }
  179. c, err := createAndStartCluster(cli, d)
  180. if err != nil {
  181. logrus.Fatalf("Error starting cluster component: %v", err)
  182. }
  183. // Restart all autostart containers which has a swarm endpoint
  184. // and is not yet running now that we have successfully
  185. // initialized the cluster.
  186. d.RestartSwarmContainers()
  187. logrus.Info("Daemon has completed initialization")
  188. routerCtx, cancel := context.WithTimeout(context.Background(), 10*time.Second)
  189. defer cancel()
  190. routerOptions, err := newRouterOptions(routerCtx, cli.Config, d)
  191. if err != nil {
  192. return err
  193. }
  194. routerOptions.api = &cli.api
  195. routerOptions.cluster = c
  196. initRouter(routerOptions)
  197. go d.ProcessClusterNotifications(ctx, c.GetWatchStream())
  198. cli.setupConfigReloadTrap()
  199. // after the daemon is done setting up we can notify systemd api
  200. notifyReady()
  201. // Daemon is fully initialized. Start handling API traffic
  202. // and wait for serve API to complete.
  203. errAPI := cli.api.Serve()
  204. if errAPI != nil {
  205. logrus.WithError(errAPI).Error("ServeAPI error")
  206. }
  207. c.Cleanup()
  208. // notify systemd that we're shutting down
  209. notifyStopping()
  210. shutdownDaemon(ctx, d)
  211. // Stop notification processing and any background processes
  212. cancel()
  213. if errAPI != nil {
  214. return errors.Wrap(errAPI, "shutting down due to ServeAPI error")
  215. }
  216. logrus.Info("Daemon shutdown complete")
  217. return nil
  218. }
  219. type routerOptions struct {
  220. sessionManager *session.Manager
  221. buildBackend *buildbackend.Backend
  222. features *map[string]bool
  223. buildkit *buildkit.Builder
  224. daemon *daemon.Daemon
  225. api *apiserver.Server
  226. cluster *cluster.Cluster
  227. }
  228. func newRouterOptions(ctx context.Context, config *config.Config, d *daemon.Daemon) (routerOptions, error) {
  229. opts := routerOptions{}
  230. sm, err := session.NewManager()
  231. if err != nil {
  232. return opts, errors.Wrap(err, "failed to create sessionmanager")
  233. }
  234. manager, err := dockerfile.NewBuildManager(d.BuilderBackend(), d.IdentityMapping())
  235. if err != nil {
  236. return opts, err
  237. }
  238. cgroupParent := newCgroupParent(config)
  239. ro := routerOptions{
  240. sessionManager: sm,
  241. features: d.Features(),
  242. daemon: d,
  243. }
  244. bk, err := buildkit.New(ctx, buildkit.Opt{
  245. SessionManager: sm,
  246. Root: filepath.Join(config.Root, "buildkit"),
  247. Dist: d.DistributionServices(),
  248. NetworkController: d.NetworkController(),
  249. DefaultCgroupParent: cgroupParent,
  250. RegistryHosts: d.RegistryHosts(),
  251. BuilderConfig: config.Builder,
  252. Rootless: d.Rootless(),
  253. IdentityMapping: d.IdentityMapping(),
  254. DNSConfig: config.DNSConfig,
  255. ApparmorProfile: daemon.DefaultApparmorProfile(),
  256. UseSnapshotter: d.UsesSnapshotter(),
  257. Snapshotter: d.ImageService().StorageDriver(),
  258. ContainerdAddress: config.ContainerdAddr,
  259. ContainerdNamespace: config.ContainerdNamespace,
  260. })
  261. if err != nil {
  262. return opts, err
  263. }
  264. bb, err := buildbackend.NewBackend(d.ImageService(), manager, bk, d.EventsService)
  265. if err != nil {
  266. return opts, errors.Wrap(err, "failed to create buildmanager")
  267. }
  268. ro.buildBackend = bb
  269. ro.buildkit = bk
  270. return ro, nil
  271. }
  272. func (cli *DaemonCli) reloadConfig() {
  273. reload := func(c *config.Config) {
  274. // Revalidate and reload the authorization plugins
  275. if err := validateAuthzPlugins(c.AuthorizationPlugins, cli.d.PluginStore); err != nil {
  276. logrus.Fatalf("Error validating authorization plugin: %v", err)
  277. return
  278. }
  279. cli.authzMiddleware.SetPlugins(c.AuthorizationPlugins)
  280. if err := cli.d.Reload(c); err != nil {
  281. logrus.Errorf("Error reconfiguring the daemon: %v", err)
  282. return
  283. }
  284. if c.IsValueSet("debug") {
  285. debugEnabled := debug.IsEnabled()
  286. switch {
  287. case debugEnabled && !c.Debug: // disable debug
  288. debug.Disable()
  289. case c.Debug && !debugEnabled: // enable debug
  290. debug.Enable()
  291. }
  292. }
  293. }
  294. if err := config.Reload(*cli.configFile, cli.flags, reload); err != nil {
  295. logrus.Error(err)
  296. }
  297. }
  298. func (cli *DaemonCli) stop() {
  299. cli.api.Close()
  300. }
  301. // shutdownDaemon just wraps daemon.Shutdown() to handle a timeout in case
  302. // d.Shutdown() is waiting too long to kill container or worst it's
  303. // blocked there
  304. func shutdownDaemon(ctx context.Context, d *daemon.Daemon) {
  305. var cancel context.CancelFunc
  306. if timeout := d.ShutdownTimeout(); timeout >= 0 {
  307. ctx, cancel = context.WithTimeout(ctx, time.Duration(timeout)*time.Second)
  308. } else {
  309. ctx, cancel = context.WithCancel(ctx)
  310. }
  311. go func() {
  312. defer cancel()
  313. d.Shutdown(ctx)
  314. }()
  315. <-ctx.Done()
  316. if errors.Is(ctx.Err(), context.DeadlineExceeded) {
  317. logrus.Error("Force shutdown daemon")
  318. } else {
  319. logrus.Debug("Clean shutdown succeeded")
  320. }
  321. }
  322. func loadDaemonCliConfig(opts *daemonOptions) (*config.Config, error) {
  323. if !opts.flags.Parsed() {
  324. return nil, errors.New(`cannot load CLI config before flags are parsed`)
  325. }
  326. opts.setDefaultOptions()
  327. conf := opts.daemonConfig
  328. flags := opts.flags
  329. conf.Debug = opts.Debug
  330. conf.Hosts = opts.Hosts
  331. conf.LogLevel = opts.LogLevel
  332. if flags.Changed(FlagTLS) {
  333. conf.TLS = &opts.TLS
  334. }
  335. if flags.Changed(FlagTLSVerify) {
  336. conf.TLSVerify = &opts.TLSVerify
  337. v := true
  338. conf.TLS = &v
  339. }
  340. if opts.TLSOptions != nil {
  341. conf.TLSOptions = config.TLSOptions{
  342. CAFile: opts.TLSOptions.CAFile,
  343. CertFile: opts.TLSOptions.CertFile,
  344. KeyFile: opts.TLSOptions.KeyFile,
  345. }
  346. } else {
  347. conf.TLSOptions = config.TLSOptions{}
  348. }
  349. if opts.configFile != "" {
  350. c, err := config.MergeDaemonConfigurations(conf, flags, opts.configFile)
  351. if err != nil {
  352. if flags.Changed("config-file") || !os.IsNotExist(err) {
  353. return nil, errors.Wrapf(err, "unable to configure the Docker daemon with file %s", opts.configFile)
  354. }
  355. }
  356. // the merged configuration can be nil if the config file didn't exist.
  357. // leave the current configuration as it is if when that happens.
  358. if c != nil {
  359. conf = c
  360. }
  361. }
  362. if err := normalizeHosts(conf); err != nil {
  363. return nil, err
  364. }
  365. if err := config.Validate(conf); err != nil {
  366. return nil, err
  367. }
  368. // Check if duplicate label-keys with different values are found
  369. newLabels, err := config.GetConflictFreeLabels(conf.Labels)
  370. if err != nil {
  371. return nil, err
  372. }
  373. conf.Labels = newLabels
  374. // Regardless of whether the user sets it to true or false, if they
  375. // specify TLSVerify at all then we need to turn on TLS
  376. if conf.IsValueSet(FlagTLSVerify) {
  377. v := true
  378. conf.TLS = &v
  379. }
  380. if conf.TLSVerify == nil && conf.TLS != nil {
  381. conf.TLSVerify = conf.TLS
  382. }
  383. err = validateCPURealtimeOptions(conf)
  384. if err != nil {
  385. return nil, err
  386. }
  387. return conf, nil
  388. }
  389. // normalizeHosts normalizes the configured config.Hosts and remove duplicates.
  390. // It returns an error if it fails to parse a host.
  391. func normalizeHosts(config *config.Config) error {
  392. if len(config.Hosts) == 0 {
  393. // if no hosts are configured, create a single entry slice, so that the
  394. // default is used.
  395. //
  396. // TODO(thaJeztah) implement a cleaner way for this; this depends on a
  397. // side-effect of how we parse empty/partial hosts.
  398. config.Hosts = make([]string, 1)
  399. }
  400. hosts := make([]string, 0, len(config.Hosts))
  401. seen := make(map[string]struct{}, len(config.Hosts))
  402. useTLS := DefaultTLSValue
  403. if config.TLS != nil {
  404. useTLS = *config.TLS
  405. }
  406. for _, h := range config.Hosts {
  407. host, err := dopts.ParseHost(useTLS, honorXDG, h)
  408. if err != nil {
  409. return err
  410. }
  411. if _, ok := seen[host]; ok {
  412. continue
  413. }
  414. seen[host] = struct{}{}
  415. hosts = append(hosts, host)
  416. }
  417. sort.Strings(hosts)
  418. config.Hosts = hosts
  419. return nil
  420. }
  421. func initRouter(opts routerOptions) {
  422. decoder := runconfig.ContainerDecoder{
  423. GetSysInfo: func() *sysinfo.SysInfo {
  424. return opts.daemon.RawSysInfo()
  425. },
  426. }
  427. routers := []router.Router{
  428. // we need to add the checkpoint router before the container router or the DELETE gets masked
  429. checkpointrouter.NewRouter(opts.daemon, decoder),
  430. container.NewRouter(opts.daemon, decoder, opts.daemon.RawSysInfo().CgroupUnified),
  431. image.NewRouter(
  432. opts.daemon.ImageService(),
  433. opts.daemon.RegistryService(),
  434. opts.daemon.ReferenceStore,
  435. opts.daemon.ImageService().DistributionServices().ImageStore,
  436. opts.daemon.ImageService().DistributionServices().LayerStore,
  437. ),
  438. systemrouter.NewRouter(opts.daemon, opts.cluster, opts.buildkit, opts.features),
  439. volume.NewRouter(opts.daemon.VolumesService(), opts.cluster),
  440. build.NewRouter(opts.buildBackend, opts.daemon, opts.features),
  441. sessionrouter.NewRouter(opts.sessionManager),
  442. swarmrouter.NewRouter(opts.cluster),
  443. pluginrouter.NewRouter(opts.daemon.PluginManager()),
  444. distributionrouter.NewRouter(opts.daemon.ImageBackend()),
  445. }
  446. if opts.buildBackend != nil {
  447. routers = append(routers, grpcrouter.NewRouter(opts.buildBackend))
  448. }
  449. if opts.daemon.NetworkControllerEnabled() {
  450. routers = append(routers, network.NewRouter(opts.daemon, opts.cluster))
  451. }
  452. if opts.daemon.HasExperimental() {
  453. for _, r := range routers {
  454. for _, route := range r.Routes() {
  455. if experimental, ok := route.(router.ExperimentalRoute); ok {
  456. experimental.Enable()
  457. }
  458. }
  459. }
  460. }
  461. opts.api.InitRouter(routers...)
  462. }
  463. func initMiddlewares(s *apiserver.Server, cfg *config.Config, pluginStore plugingetter.PluginGetter) *authorization.Middleware {
  464. v := dockerversion.Version
  465. exp := middleware.NewExperimentalMiddleware(cfg.Experimental)
  466. s.UseMiddleware(exp)
  467. vm := middleware.NewVersionMiddleware(v, api.DefaultVersion, api.MinVersion)
  468. s.UseMiddleware(vm)
  469. if cfg.CorsHeaders != "" {
  470. c := middleware.NewCORSMiddleware(cfg.CorsHeaders)
  471. s.UseMiddleware(c)
  472. }
  473. authzMiddleware := authorization.NewMiddleware(cfg.AuthorizationPlugins, pluginStore)
  474. s.UseMiddleware(authzMiddleware)
  475. return authzMiddleware
  476. }
  477. func (cli *DaemonCli) getContainerdDaemonOpts() ([]supervisor.DaemonOpt, error) {
  478. opts, err := cli.getPlatformContainerdDaemonOpts()
  479. if err != nil {
  480. return nil, err
  481. }
  482. if cli.Debug {
  483. opts = append(opts, supervisor.WithLogLevel("debug"))
  484. } else {
  485. opts = append(opts, supervisor.WithLogLevel(cli.LogLevel))
  486. }
  487. if !cli.CriContainerd {
  488. // CRI support in the managed daemon is currently opt-in.
  489. //
  490. // It's disabled by default, originally because it was listening on
  491. // a TCP connection at 0.0.0.0:10010, which was considered a security
  492. // risk, and could conflict with user's container ports.
  493. //
  494. // Current versions of containerd started now listen on localhost on
  495. // an ephemeral port instead, but could still conflict with container
  496. // ports, and running kubernetes using the static binaries is not a
  497. // common scenario, so we (for now) continue disabling it by default.
  498. //
  499. // Also see https://github.com/containerd/containerd/issues/2483#issuecomment-407530608
  500. opts = append(opts, supervisor.WithCRIDisabled())
  501. }
  502. return opts, nil
  503. }
  504. func newAPIServerTLSConfig(config *config.Config) (*tls.Config, error) {
  505. var tlsConfig *tls.Config
  506. if config.TLS != nil && *config.TLS {
  507. var (
  508. clientAuth tls.ClientAuthType
  509. err error
  510. )
  511. if config.TLSVerify == nil || *config.TLSVerify {
  512. // server requires and verifies client's certificate
  513. clientAuth = tls.RequireAndVerifyClientCert
  514. }
  515. tlsConfig, err = tlsconfig.Server(tlsconfig.Options{
  516. CAFile: config.TLSOptions.CAFile,
  517. CertFile: config.TLSOptions.CertFile,
  518. KeyFile: config.TLSOptions.KeyFile,
  519. ExclusiveRootPools: true,
  520. ClientAuth: clientAuth,
  521. })
  522. if err != nil {
  523. return nil, errors.Wrap(err, "invalid TLS configuration")
  524. }
  525. }
  526. return tlsConfig, nil
  527. }
  528. // checkTLSAuthOK checks basically for an explicitly disabled TLS/TLSVerify
  529. // Going forward we do not want to support a scenario where dockerd listens
  530. // on TCP without either TLS client auth (or an explicit opt-in to disable it)
  531. func checkTLSAuthOK(c *config.Config) bool {
  532. if c.TLS == nil {
  533. // Either TLS is enabled by default, in which case TLS verification should be enabled by default, or explicitly disabled
  534. // Or TLS is disabled by default... in any of these cases, we can just take the default value as to how to proceed
  535. return DefaultTLSValue
  536. }
  537. if !*c.TLS {
  538. // TLS is explicitly disabled, which is supported
  539. return true
  540. }
  541. if c.TLSVerify == nil {
  542. // this actually shouldn't happen since we set TLSVerify on the config object anyway
  543. // But in case it does get here, be cautious and assume this is not supported.
  544. return false
  545. }
  546. // Either TLSVerify is explicitly enabled or disabled, both cases are supported
  547. return true
  548. }
  549. func loadListeners(cli *DaemonCli, tlsConfig *tls.Config) ([]string, error) {
  550. if len(cli.Config.Hosts) == 0 {
  551. return nil, errors.New("no hosts configured")
  552. }
  553. var hosts []string
  554. for i := 0; i < len(cli.Config.Hosts); i++ {
  555. protoAddr := cli.Config.Hosts[i]
  556. proto, addr, ok := strings.Cut(protoAddr, "://")
  557. if !ok {
  558. return nil, fmt.Errorf("bad format %s, expected PROTO://ADDR", protoAddr)
  559. }
  560. // It's a bad idea to bind to TCP without tlsverify.
  561. authEnabled := tlsConfig != nil && tlsConfig.ClientAuth == tls.RequireAndVerifyClientCert
  562. if proto == "tcp" && !authEnabled {
  563. logrus.WithField("host", protoAddr).Warn("Binding to IP address without --tlsverify is insecure and gives root access on this machine to everyone who has access to your network.")
  564. logrus.WithField("host", protoAddr).Warn("Binding to an IP address, even on localhost, can also give access to scripts run in a browser. Be safe out there!")
  565. time.Sleep(time.Second)
  566. // If TLSVerify is explicitly set to false we'll take that as "Please let me shoot myself in the foot"
  567. // We do not want to continue to support a default mode where tls verification is disabled, so we do some extra warnings here and eventually remove support
  568. if !checkTLSAuthOK(cli.Config) {
  569. ipAddr, _, err := net.SplitHostPort(addr)
  570. if err != nil {
  571. return nil, errors.Wrap(err, "error parsing tcp address")
  572. }
  573. // shortcut all this extra stuff for literal "localhost"
  574. // -H supports specifying hostnames, since we want to bypass this on loopback interfaces we'll look it up here.
  575. if ipAddr != "localhost" {
  576. ip := net.ParseIP(ipAddr)
  577. if ip == nil {
  578. ipA, err := net.ResolveIPAddr("ip", ipAddr)
  579. if err != nil {
  580. logrus.WithError(err).WithField("host", ipAddr).Error("Error looking up specified host address")
  581. }
  582. if ipA != nil {
  583. ip = ipA.IP
  584. }
  585. }
  586. if ip == nil || !ip.IsLoopback() {
  587. logrus.WithField("host", protoAddr).Warn("Binding to an IP address without --tlsverify is deprecated. Startup is intentionally being slowed down to show this message")
  588. logrus.WithField("host", protoAddr).Warn("Please consider generating tls certificates with client validation to prevent exposing unauthenticated root access to your network")
  589. logrus.WithField("host", protoAddr).Warnf("You can override this by explicitly specifying '--%s=false' or '--%s=false'", FlagTLS, FlagTLSVerify)
  590. logrus.WithField("host", protoAddr).Warnf("Support for listening on TCP without authentication or explicit intent to run without authentication will be removed in the next release")
  591. time.Sleep(15 * time.Second)
  592. }
  593. }
  594. }
  595. }
  596. // If we're binding to a TCP port, make sure that a container doesn't try to use it.
  597. if proto == "tcp" {
  598. if err := allocateDaemonPort(addr); err != nil {
  599. return nil, err
  600. }
  601. }
  602. ls, err := listeners.Init(proto, addr, cli.Config.SocketGroup, tlsConfig)
  603. if err != nil {
  604. return nil, err
  605. }
  606. logrus.Debugf("Listener created for HTTP on %s (%s)", proto, addr)
  607. hosts = append(hosts, addr)
  608. cli.api.Accept(addr, ls...)
  609. }
  610. return hosts, nil
  611. }
  612. func createAndStartCluster(cli *DaemonCli, d *daemon.Daemon) (*cluster.Cluster, error) {
  613. name, _ := os.Hostname()
  614. // Use a buffered channel to pass changes from store watch API to daemon
  615. // A buffer allows store watch API and daemon processing to not wait for each other
  616. watchStream := make(chan *swarmapi.WatchMessage, 32)
  617. c, err := cluster.New(cluster.Config{
  618. Root: cli.Config.Root,
  619. Name: name,
  620. Backend: d,
  621. VolumeBackend: d.VolumesService(),
  622. ImageBackend: d.ImageBackend(),
  623. PluginBackend: d.PluginManager(),
  624. NetworkSubnetsProvider: d,
  625. DefaultAdvertiseAddr: cli.Config.SwarmDefaultAdvertiseAddr,
  626. RaftHeartbeatTick: cli.Config.SwarmRaftHeartbeatTick,
  627. RaftElectionTick: cli.Config.SwarmRaftElectionTick,
  628. RuntimeRoot: cli.getSwarmRunRoot(),
  629. WatchStream: watchStream,
  630. })
  631. if err != nil {
  632. return nil, err
  633. }
  634. d.SetCluster(c)
  635. err = c.Start()
  636. return c, err
  637. }
  638. // validates that the plugins requested with the --authorization-plugin flag are valid AuthzDriver
  639. // plugins present on the host and available to the daemon
  640. func validateAuthzPlugins(requestedPlugins []string, pg plugingetter.PluginGetter) error {
  641. for _, reqPlugin := range requestedPlugins {
  642. if _, err := pg.Get(reqPlugin, authorization.AuthZApiImplements, plugingetter.Lookup); err != nil {
  643. return err
  644. }
  645. }
  646. return nil
  647. }
  648. func systemContainerdRunning(honorXDG bool) (string, bool, error) {
  649. addr := containerddefaults.DefaultAddress
  650. if honorXDG {
  651. runtimeDir, err := homedir.GetRuntimeDir()
  652. if err != nil {
  653. return "", false, err
  654. }
  655. addr = filepath.Join(runtimeDir, "containerd", "containerd.sock")
  656. }
  657. _, err := os.Lstat(addr)
  658. return addr, err == nil, nil
  659. }
  660. // configureDaemonLogs sets the logrus logging level and formatting. It expects
  661. // the passed configuration to already be validated, and ignores invalid options.
  662. func configureDaemonLogs(conf *config.Config) {
  663. if conf.LogLevel != "" {
  664. lvl, err := logrus.ParseLevel(conf.LogLevel)
  665. if err == nil {
  666. logrus.SetLevel(lvl)
  667. }
  668. } else {
  669. logrus.SetLevel(logrus.InfoLevel)
  670. }
  671. logrus.SetFormatter(&logrus.TextFormatter{
  672. TimestampFormat: jsonmessage.RFC3339NanoFixed,
  673. DisableColors: conf.RawLogs,
  674. FullTimestamp: true,
  675. })
  676. }
  677. func configureProxyEnv(conf *config.Config) {
  678. if p := conf.HTTPProxy; p != "" {
  679. overrideProxyEnv("HTTP_PROXY", p)
  680. overrideProxyEnv("http_proxy", p)
  681. }
  682. if p := conf.HTTPSProxy; p != "" {
  683. overrideProxyEnv("HTTPS_PROXY", p)
  684. overrideProxyEnv("https_proxy", p)
  685. }
  686. if p := conf.NoProxy; p != "" {
  687. overrideProxyEnv("NO_PROXY", p)
  688. overrideProxyEnv("no_proxy", p)
  689. }
  690. }
  691. func overrideProxyEnv(name, val string) {
  692. if oldVal := os.Getenv(name); oldVal != "" && oldVal != val {
  693. logrus.WithFields(logrus.Fields{
  694. "name": name,
  695. "old-value": config.MaskCredentials(oldVal),
  696. "new-value": config.MaskCredentials(val),
  697. }).Warn("overriding existing proxy variable with value from configuration")
  698. }
  699. _ = os.Setenv(name, val)
  700. }