convergence.go 24 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781
  1. /*
  2. Copyright 2020 Docker Compose CLI authors
  3. Licensed under the Apache License, Version 2.0 (the "License");
  4. you may not use this file except in compliance with the License.
  5. You may obtain a copy of the License at
  6. http://www.apache.org/licenses/LICENSE-2.0
  7. Unless required by applicable law or agreed to in writing, software
  8. distributed under the License is distributed on an "AS IS" BASIS,
  9. WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  10. See the License for the specific language governing permissions and
  11. limitations under the License.
  12. */
  13. package compose
  14. import (
  15. "context"
  16. "fmt"
  17. "sort"
  18. "strconv"
  19. "strings"
  20. "sync"
  21. "time"
  22. "go.opentelemetry.io/otel/attribute"
  23. "go.opentelemetry.io/otel/trace"
  24. "github.com/compose-spec/compose-go/types"
  25. "github.com/containerd/containerd/platforms"
  26. "github.com/docker/compose/v2/internal/tracing"
  27. moby "github.com/docker/docker/api/types"
  28. containerType "github.com/docker/docker/api/types/container"
  29. specs "github.com/opencontainers/image-spec/specs-go/v1"
  30. "github.com/pkg/errors"
  31. "github.com/sirupsen/logrus"
  32. "golang.org/x/sync/errgroup"
  33. "github.com/docker/compose/v2/pkg/api"
  34. "github.com/docker/compose/v2/pkg/progress"
  35. "github.com/docker/compose/v2/pkg/utils"
  36. )
  37. const (
  38. extLifecycle = "x-lifecycle"
  39. forceRecreate = "force_recreate"
  40. doubledContainerNameWarning = "WARNING: The %q service is using the custom container name %q. " +
  41. "Docker requires each container to have a unique name. " +
  42. "Remove the custom name to scale the service.\n"
  43. )
  44. // convergence manages service's container lifecycle.
  45. // Based on initially observed state, it reconciles the existing container with desired state, which might include
  46. // re-creating container, adding or removing replicas, or starting stopped containers.
  47. // Cross services dependencies are managed by creating services in expected order and updating `service:xx` reference
  48. // when a service has converged, so dependent ones can be managed with resolved containers references.
  49. type convergence struct {
  50. service *composeService
  51. observedState map[string]Containers
  52. stateMutex sync.Mutex
  53. }
  54. func (c *convergence) getObservedState(serviceName string) Containers {
  55. c.stateMutex.Lock()
  56. defer c.stateMutex.Unlock()
  57. return c.observedState[serviceName]
  58. }
  59. func (c *convergence) setObservedState(serviceName string, containers Containers) {
  60. c.stateMutex.Lock()
  61. defer c.stateMutex.Unlock()
  62. c.observedState[serviceName] = containers
  63. }
  64. func newConvergence(services []string, state Containers, s *composeService) *convergence {
  65. observedState := map[string]Containers{}
  66. for _, s := range services {
  67. observedState[s] = Containers{}
  68. }
  69. for _, c := range state.filter(isNotOneOff) {
  70. service := c.Labels[api.ServiceLabel]
  71. observedState[service] = append(observedState[service], c)
  72. }
  73. return &convergence{
  74. service: s,
  75. observedState: observedState,
  76. }
  77. }
  78. func (c *convergence) apply(ctx context.Context, project *types.Project, options api.CreateOptions) error {
  79. return InDependencyOrder(ctx, project, func(ctx context.Context, name string) error {
  80. service, err := project.GetService(name)
  81. if err != nil {
  82. return err
  83. }
  84. return tracing.SpanWrapFunc("service/apply", tracing.ServiceOptions(service), func(ctx context.Context) error {
  85. strategy := options.RecreateDependencies
  86. if utils.StringContains(options.Services, name) {
  87. strategy = options.Recreate
  88. }
  89. err = c.ensureService(ctx, project, service, strategy, options.Inherit, options.Timeout)
  90. if err != nil {
  91. return err
  92. }
  93. c.updateProject(project, name)
  94. return nil
  95. })(ctx)
  96. })
  97. }
  98. var mu sync.Mutex
  99. // updateProject updates project after service converged, so dependent services relying on `service:xx` can refer to actual containers.
  100. func (c *convergence) updateProject(project *types.Project, serviceName string) {
  101. // operation is protected by a Mutex so that we can safely update project.Services while running concurrent convergence on services
  102. mu.Lock()
  103. defer mu.Unlock()
  104. cnts := c.getObservedState(serviceName)
  105. for i, s := range project.Services {
  106. updateServices(&s, cnts)
  107. project.Services[i] = s
  108. }
  109. }
  110. func updateServices(service *types.ServiceConfig, cnts Containers) {
  111. if len(cnts) == 0 {
  112. return
  113. }
  114. for _, str := range []*string{&service.NetworkMode, &service.Ipc, &service.Pid} {
  115. if d := getDependentServiceFromMode(*str); d != "" {
  116. if serviceContainers := cnts.filter(isService(d)); len(serviceContainers) > 0 {
  117. *str = types.NetworkModeContainerPrefix + serviceContainers[0].ID
  118. }
  119. }
  120. }
  121. var links []string
  122. for _, serviceLink := range service.Links {
  123. parts := strings.Split(serviceLink, ":")
  124. serviceName := serviceLink
  125. serviceAlias := ""
  126. if len(parts) == 2 {
  127. serviceName = parts[0]
  128. serviceAlias = parts[1]
  129. }
  130. if serviceName != service.Name {
  131. links = append(links, serviceLink)
  132. continue
  133. }
  134. for _, container := range cnts {
  135. name := getCanonicalContainerName(container)
  136. if serviceAlias != "" {
  137. links = append(links,
  138. fmt.Sprintf("%s:%s", name, serviceAlias))
  139. }
  140. links = append(links,
  141. fmt.Sprintf("%s:%s", name, name),
  142. fmt.Sprintf("%s:%s", name, getContainerNameWithoutProject(container)))
  143. }
  144. service.Links = links
  145. }
  146. }
  147. func (c *convergence) ensureService(ctx context.Context, project *types.Project, service types.ServiceConfig, recreate string, inherit bool, timeout *time.Duration) error {
  148. expected, err := getScale(service)
  149. if err != nil {
  150. return err
  151. }
  152. containers := c.getObservedState(service.Name)
  153. actual := len(containers)
  154. updated := make(Containers, expected)
  155. eg, _ := errgroup.WithContext(ctx)
  156. err = c.resolveVolumeFrom(&service)
  157. if err != nil {
  158. return err
  159. }
  160. sort.Slice(containers, func(i, j int) bool {
  161. return containers[i].Created < containers[j].Created
  162. })
  163. for i, container := range containers {
  164. if i >= expected {
  165. // Scale Down
  166. container := container
  167. traceOpts := append(tracing.ServiceOptions(service), tracing.ContainerOptions(container)...)
  168. eg.Go(tracing.SpanWrapFuncForErrGroup(ctx, "service/scale/down", traceOpts, func(ctx context.Context) error {
  169. timeoutInSecond := utils.DurationSecondToInt(timeout)
  170. err := c.service.apiClient().ContainerStop(ctx, container.ID, containerType.StopOptions{
  171. Timeout: timeoutInSecond,
  172. })
  173. if err != nil {
  174. return err
  175. }
  176. return c.service.apiClient().ContainerRemove(ctx, container.ID, moby.ContainerRemoveOptions{})
  177. }))
  178. continue
  179. }
  180. mustRecreate, err := mustRecreate(service, container, recreate)
  181. if err != nil {
  182. return err
  183. }
  184. if mustRecreate {
  185. i, container := i, container
  186. eg.Go(tracing.SpanWrapFuncForErrGroup(ctx, "container/recreate", tracing.ContainerOptions(container), func(ctx context.Context) error {
  187. recreated, err := c.service.recreateContainer(ctx, project, service, container, inherit, timeout)
  188. updated[i] = recreated
  189. return err
  190. }))
  191. continue
  192. }
  193. // Enforce non-diverged containers are running
  194. w := progress.ContextWriter(ctx)
  195. name := getContainerProgressName(container)
  196. switch container.State {
  197. case ContainerRunning:
  198. w.Event(progress.RunningEvent(name))
  199. case ContainerCreated:
  200. case ContainerRestarting:
  201. case ContainerExited:
  202. w.Event(progress.CreatedEvent(name))
  203. default:
  204. container := container
  205. eg.Go(tracing.EventWrapFuncForErrGroup(ctx, "service/start", tracing.ContainerOptions(container), func(ctx context.Context) error {
  206. return c.service.startContainer(ctx, container)
  207. }))
  208. }
  209. updated[i] = container
  210. }
  211. next := nextContainerNumber(containers)
  212. for i := 0; i < expected-actual; i++ {
  213. // Scale UP
  214. number := next + i
  215. name := getContainerName(project.Name, service, number)
  216. i := i
  217. eventOpts := tracing.SpanOptions{trace.WithAttributes(attribute.String("container.name", name))}
  218. eg.Go(tracing.EventWrapFuncForErrGroup(ctx, "service/scale/up", eventOpts, func(ctx context.Context) error {
  219. opts := createOptions{
  220. AutoRemove: false,
  221. AttachStdin: false,
  222. UseNetworkAliases: true,
  223. Labels: mergeLabels(service.Labels, service.CustomLabels),
  224. }
  225. container, err := c.service.createContainer(ctx, project, service, name, number, opts)
  226. updated[actual+i] = container
  227. return err
  228. }))
  229. continue
  230. }
  231. err = eg.Wait()
  232. c.setObservedState(service.Name, updated)
  233. return err
  234. }
  235. func (c *convergence) resolveVolumeFrom(service *types.ServiceConfig) error {
  236. for i, vol := range service.VolumesFrom {
  237. spec := strings.Split(vol, ":")
  238. if len(spec) == 0 {
  239. continue
  240. }
  241. if spec[0] == "container" {
  242. service.VolumesFrom[i] = spec[1]
  243. continue
  244. }
  245. name := spec[0]
  246. dependencies := c.getObservedState(name)
  247. if len(dependencies) == 0 {
  248. return fmt.Errorf("cannot share volume with service %s: container missing", name)
  249. }
  250. service.VolumesFrom[i] = dependencies.sorted()[0].ID
  251. }
  252. return nil
  253. }
  254. func mustRecreate(expected types.ServiceConfig, actual moby.Container, policy string) (bool, error) {
  255. if policy == api.RecreateNever {
  256. return false, nil
  257. }
  258. if policy == api.RecreateForce || expected.Extensions[extLifecycle] == forceRecreate {
  259. return true, nil
  260. }
  261. configHash, err := ServiceHash(expected)
  262. if err != nil {
  263. return false, err
  264. }
  265. configChanged := actual.Labels[api.ConfigHashLabel] != configHash
  266. imageUpdated := actual.Labels[api.ImageDigestLabel] != expected.CustomLabels[api.ImageDigestLabel]
  267. return configChanged || imageUpdated, nil
  268. }
  269. func getContainerName(projectName string, service types.ServiceConfig, number int) string {
  270. name := strings.Join([]string{projectName, service.Name, strconv.Itoa(number)}, api.Separator)
  271. if service.ContainerName != "" {
  272. name = service.ContainerName
  273. }
  274. return name
  275. }
  276. func getContainerProgressName(container moby.Container) string {
  277. return "Container " + getCanonicalContainerName(container)
  278. }
  279. func containerEvents(containers Containers, eventFunc func(string) progress.Event) []progress.Event {
  280. events := []progress.Event{}
  281. for _, container := range containers {
  282. events = append(events, eventFunc(getContainerProgressName(container)))
  283. }
  284. return events
  285. }
  286. func containerReasonEvents(containers Containers, eventFunc func(string, string) progress.Event, reason string) []progress.Event {
  287. events := []progress.Event{}
  288. for _, container := range containers {
  289. events = append(events, eventFunc(getContainerProgressName(container), reason))
  290. }
  291. return events
  292. }
  293. // ServiceConditionRunningOrHealthy is a service condition on status running or healthy
  294. const ServiceConditionRunningOrHealthy = "running_or_healthy"
  295. //nolint:gocyclo
  296. func (s *composeService) waitDependencies(ctx context.Context, project *types.Project, dependencies types.DependsOnConfig, containers Containers) error {
  297. eg, _ := errgroup.WithContext(ctx)
  298. w := progress.ContextWriter(ctx)
  299. for dep, config := range dependencies {
  300. if shouldWait, err := shouldWaitForDependency(dep, config, project); err != nil {
  301. return err
  302. } else if !shouldWait {
  303. continue
  304. }
  305. waitingFor := containers.filter(isService(dep))
  306. w.Events(containerEvents(waitingFor, progress.Waiting))
  307. dep, config := dep, config
  308. eg.Go(func() error {
  309. ticker := time.NewTicker(500 * time.Millisecond)
  310. defer ticker.Stop()
  311. for {
  312. select {
  313. case <-ticker.C:
  314. case <-ctx.Done():
  315. return nil
  316. }
  317. switch config.Condition {
  318. case ServiceConditionRunningOrHealthy:
  319. healthy, err := s.isServiceHealthy(ctx, waitingFor, true)
  320. if err != nil {
  321. if !config.Required {
  322. w.Events(containerReasonEvents(waitingFor, progress.SkippedEvent, fmt.Sprintf("optional dependency %q is not running or is unhealthy", dep)))
  323. logrus.Warnf("optional dependency %q is not running or is unhealthy: %s", dep, err.Error())
  324. return nil
  325. }
  326. return err
  327. }
  328. if healthy {
  329. w.Events(containerEvents(waitingFor, progress.Healthy))
  330. return nil
  331. }
  332. case types.ServiceConditionHealthy:
  333. healthy, err := s.isServiceHealthy(ctx, waitingFor, false)
  334. if err != nil {
  335. if !config.Required {
  336. w.Events(containerReasonEvents(waitingFor, progress.SkippedEvent, fmt.Sprintf("optional dependency %q failed to start", dep)))
  337. logrus.Warnf("optional dependency %q failed to start: %s", dep, err.Error())
  338. return nil
  339. }
  340. w.Events(containerEvents(waitingFor, progress.ErrorEvent))
  341. return errors.Wrap(err, "dependency failed to start")
  342. }
  343. if healthy {
  344. w.Events(containerEvents(waitingFor, progress.Healthy))
  345. return nil
  346. }
  347. case types.ServiceConditionCompletedSuccessfully:
  348. exited, code, err := s.isServiceCompleted(ctx, waitingFor)
  349. if err != nil {
  350. return err
  351. }
  352. if exited {
  353. if code == 0 {
  354. w.Events(containerEvents(waitingFor, progress.Exited))
  355. return nil
  356. }
  357. messageSuffix := fmt.Sprintf("%q didn't complete successfully: exit %d", dep, code)
  358. if !config.Required {
  359. // optional -> mark as skipped & don't propagate error
  360. w.Events(containerReasonEvents(waitingFor, progress.SkippedEvent, fmt.Sprintf("optional dependency %s", messageSuffix)))
  361. logrus.Warnf("optional dependency %s", messageSuffix)
  362. return nil
  363. }
  364. msg := fmt.Sprintf("service %s", messageSuffix)
  365. w.Events(containerReasonEvents(waitingFor, progress.ErrorMessageEvent, msg))
  366. return errors.New(msg)
  367. }
  368. default:
  369. logrus.Warnf("unsupported depends_on condition: %s", config.Condition)
  370. return nil
  371. }
  372. }
  373. })
  374. }
  375. return eg.Wait()
  376. }
  377. func shouldWaitForDependency(serviceName string, dependencyConfig types.ServiceDependency, project *types.Project) (bool, error) {
  378. if dependencyConfig.Condition == types.ServiceConditionStarted {
  379. // already managed by InDependencyOrder
  380. return false, nil
  381. }
  382. if service, err := project.GetService(serviceName); err != nil {
  383. for _, ds := range project.DisabledServices {
  384. if ds.Name == serviceName {
  385. // don't wait for disabled service (--no-deps)
  386. return false, nil
  387. }
  388. }
  389. return false, err
  390. } else if service.Scale == 0 {
  391. // don't wait for the dependency which configured to have 0 containers running
  392. return false, nil
  393. }
  394. return true, nil
  395. }
  396. func nextContainerNumber(containers []moby.Container) int {
  397. max := 0
  398. for _, c := range containers {
  399. s, ok := c.Labels[api.ContainerNumberLabel]
  400. if !ok {
  401. logrus.Warnf("container %s is missing %s label", c.ID, api.ContainerNumberLabel)
  402. }
  403. n, err := strconv.Atoi(s)
  404. if err != nil {
  405. logrus.Warnf("container %s has invalid %s label: %s", c.ID, api.ContainerNumberLabel, s)
  406. continue
  407. }
  408. if n > max {
  409. max = n
  410. }
  411. }
  412. return max + 1
  413. }
  414. func getScale(config types.ServiceConfig) (int, error) {
  415. scale := 1
  416. if config.Deploy != nil && config.Deploy.Replicas != nil {
  417. scale = int(*config.Deploy.Replicas)
  418. }
  419. if scale > 1 && config.ContainerName != "" {
  420. return 0, fmt.Errorf(doubledContainerNameWarning,
  421. config.Name,
  422. config.ContainerName)
  423. }
  424. return scale, nil
  425. }
  426. func (s *composeService) createContainer(ctx context.Context, project *types.Project, service types.ServiceConfig,
  427. name string, number int, opts createOptions) (container moby.Container, err error) {
  428. w := progress.ContextWriter(ctx)
  429. eventName := "Container " + name
  430. w.Event(progress.CreatingEvent(eventName))
  431. container, err = s.createMobyContainer(ctx, project, service, name, number, nil, opts, w)
  432. if err != nil {
  433. return
  434. }
  435. w.Event(progress.CreatedEvent(eventName))
  436. return
  437. }
  438. func (s *composeService) recreateContainer(ctx context.Context, project *types.Project, service types.ServiceConfig,
  439. replaced moby.Container, inherit bool, timeout *time.Duration) (moby.Container, error) {
  440. var created moby.Container
  441. w := progress.ContextWriter(ctx)
  442. w.Event(progress.NewEvent(getContainerProgressName(replaced), progress.Working, "Recreate"))
  443. number, err := strconv.Atoi(replaced.Labels[api.ContainerNumberLabel])
  444. if err != nil {
  445. return created, err
  446. }
  447. var inherited *moby.Container
  448. if inherit {
  449. inherited = &replaced
  450. }
  451. name := getContainerName(project.Name, service, number)
  452. tmpName := fmt.Sprintf("%s_%s", replaced.ID[:12], name)
  453. opts := createOptions{
  454. AutoRemove: false,
  455. AttachStdin: false,
  456. UseNetworkAliases: true,
  457. Labels: mergeLabels(service.Labels, service.CustomLabels).Add(api.ContainerReplaceLabel, replaced.ID),
  458. }
  459. created, err = s.createMobyContainer(ctx, project, service, tmpName, number, inherited, opts, w)
  460. if err != nil {
  461. return created, err
  462. }
  463. timeoutInSecond := utils.DurationSecondToInt(timeout)
  464. err = s.apiClient().ContainerStop(ctx, replaced.ID, containerType.StopOptions{Timeout: timeoutInSecond})
  465. if err != nil {
  466. return created, err
  467. }
  468. err = s.apiClient().ContainerRemove(ctx, replaced.ID, moby.ContainerRemoveOptions{})
  469. if err != nil {
  470. return created, err
  471. }
  472. err = s.apiClient().ContainerRename(ctx, created.ID, name)
  473. if err != nil {
  474. return created, err
  475. }
  476. w.Event(progress.NewEvent(getContainerProgressName(replaced), progress.Done, "Recreated"))
  477. setDependentLifecycle(project, service.Name, forceRecreate)
  478. return created, err
  479. }
  480. // setDependentLifecycle define the Lifecycle strategy for all services to depend on specified service
  481. func setDependentLifecycle(project *types.Project, service string, strategy string) {
  482. mu.Lock()
  483. defer mu.Unlock()
  484. for i, s := range project.Services {
  485. if utils.StringContains(s.GetDependencies(), service) {
  486. if s.Extensions == nil {
  487. s.Extensions = map[string]interface{}{}
  488. }
  489. s.Extensions[extLifecycle] = strategy
  490. project.Services[i] = s
  491. }
  492. }
  493. }
  494. func (s *composeService) startContainer(ctx context.Context, container moby.Container) error {
  495. w := progress.ContextWriter(ctx)
  496. w.Event(progress.NewEvent(getContainerProgressName(container), progress.Working, "Restart"))
  497. err := s.apiClient().ContainerStart(ctx, container.ID, moby.ContainerStartOptions{})
  498. if err != nil {
  499. return err
  500. }
  501. w.Event(progress.NewEvent(getContainerProgressName(container), progress.Done, "Restarted"))
  502. return nil
  503. }
  504. func (s *composeService) createMobyContainer(ctx context.Context,
  505. project *types.Project,
  506. service types.ServiceConfig,
  507. name string,
  508. number int,
  509. inherit *moby.Container,
  510. opts createOptions,
  511. w progress.Writer,
  512. ) (moby.Container, error) {
  513. var created moby.Container
  514. cfgs, err := s.getCreateConfigs(ctx, project, service, number, inherit, opts)
  515. if err != nil {
  516. return created, err
  517. }
  518. platform := service.Platform
  519. if platform == "" {
  520. platform = project.Environment["DOCKER_DEFAULT_PLATFORM"]
  521. }
  522. var plat *specs.Platform
  523. if platform != "" {
  524. var p specs.Platform
  525. p, err = platforms.Parse(platform)
  526. if err != nil {
  527. return created, err
  528. }
  529. plat = &p
  530. }
  531. response, err := s.apiClient().ContainerCreate(ctx, cfgs.Container, cfgs.Host, cfgs.Network, plat, name)
  532. if err != nil {
  533. return created, err
  534. }
  535. for _, warning := range response.Warnings {
  536. w.Event(progress.Event{
  537. ID: service.Name,
  538. Status: progress.Warning,
  539. Text: warning,
  540. })
  541. }
  542. inspectedContainer, err := s.apiClient().ContainerInspect(ctx, response.ID)
  543. if err != nil {
  544. return created, err
  545. }
  546. created = moby.Container{
  547. ID: inspectedContainer.ID,
  548. Labels: inspectedContainer.Config.Labels,
  549. Names: []string{inspectedContainer.Name},
  550. NetworkSettings: &moby.SummaryNetworkSettings{
  551. Networks: inspectedContainer.NetworkSettings.Networks,
  552. },
  553. }
  554. // the highest-priority network is the primary and is included in the ContainerCreate API
  555. // call via container.NetworkMode & network.NetworkingConfig
  556. // any remaining networks are connected one-by-one here after creation (but before start)
  557. serviceNetworks := service.NetworksByPriority()
  558. for _, networkKey := range serviceNetworks {
  559. mobyNetworkName := project.Networks[networkKey].Name
  560. if string(cfgs.Host.NetworkMode) == mobyNetworkName {
  561. // primary network already configured as part of ContainerCreate
  562. continue
  563. }
  564. epSettings := createEndpointSettings(project, service, number, networkKey, cfgs.Links, opts.UseNetworkAliases)
  565. if err := s.apiClient().NetworkConnect(ctx, mobyNetworkName, created.ID, epSettings); err != nil {
  566. return created, err
  567. }
  568. }
  569. err = s.injectSecrets(ctx, project, service, created.ID)
  570. return created, err
  571. }
  572. // getLinks mimics V1 compose/service.py::Service::_get_links()
  573. func (s *composeService) getLinks(ctx context.Context, projectName string, service types.ServiceConfig, number int) ([]string, error) {
  574. var links []string
  575. format := func(k, v string) string {
  576. return fmt.Sprintf("%s:%s", k, v)
  577. }
  578. getServiceContainers := func(serviceName string) (Containers, error) {
  579. return s.getContainers(ctx, projectName, oneOffExclude, true, serviceName)
  580. }
  581. for _, rawLink := range service.Links {
  582. linkSplit := strings.Split(rawLink, ":")
  583. linkServiceName := linkSplit[0]
  584. linkName := linkServiceName
  585. if len(linkSplit) == 2 {
  586. linkName = linkSplit[1] // linkName if informed like in: "serviceName:linkName"
  587. }
  588. cnts, err := getServiceContainers(linkServiceName)
  589. if err != nil {
  590. return nil, err
  591. }
  592. for _, c := range cnts {
  593. containerName := getCanonicalContainerName(c)
  594. links = append(links,
  595. format(containerName, linkName),
  596. format(containerName, linkServiceName+api.Separator+strconv.Itoa(number)),
  597. format(containerName, strings.Join([]string{projectName, linkServiceName, strconv.Itoa(number)}, api.Separator)),
  598. )
  599. }
  600. }
  601. if service.Labels[api.OneoffLabel] == "True" {
  602. cnts, err := getServiceContainers(service.Name)
  603. if err != nil {
  604. return nil, err
  605. }
  606. for _, c := range cnts {
  607. containerName := getCanonicalContainerName(c)
  608. links = append(links,
  609. format(containerName, service.Name),
  610. format(containerName, strings.TrimPrefix(containerName, projectName+api.Separator)),
  611. format(containerName, containerName),
  612. )
  613. }
  614. }
  615. for _, rawExtLink := range service.ExternalLinks {
  616. extLinkSplit := strings.Split(rawExtLink, ":")
  617. externalLink := extLinkSplit[0]
  618. linkName := externalLink
  619. if len(extLinkSplit) == 2 {
  620. linkName = extLinkSplit[1]
  621. }
  622. links = append(links, format(externalLink, linkName))
  623. }
  624. return links, nil
  625. }
  626. func (s *composeService) isServiceHealthy(ctx context.Context, containers Containers, fallbackRunning bool) (bool, error) {
  627. for _, c := range containers {
  628. container, err := s.apiClient().ContainerInspect(ctx, c.ID)
  629. if err != nil {
  630. return false, err
  631. }
  632. name := container.Name[1:]
  633. if container.State.Status == "exited" {
  634. return false, fmt.Errorf("container %s exited (%d)", name, container.State.ExitCode)
  635. }
  636. if container.Config.Healthcheck == nil && fallbackRunning {
  637. // Container does not define a health check, but we can fall back to "running" state
  638. return container.State != nil && container.State.Status == "running", nil
  639. }
  640. if container.State == nil || container.State.Health == nil {
  641. return false, fmt.Errorf("container %s has no healthcheck configured", name)
  642. }
  643. switch container.State.Health.Status {
  644. case moby.Healthy:
  645. // Continue by checking the next container.
  646. case moby.Unhealthy:
  647. return false, fmt.Errorf("container %s is unhealthy", name)
  648. case moby.Starting:
  649. return false, nil
  650. default:
  651. return false, fmt.Errorf("container %s had unexpected health status %q", name, container.State.Health.Status)
  652. }
  653. }
  654. return true, nil
  655. }
  656. func (s *composeService) isServiceCompleted(ctx context.Context, containers Containers) (bool, int, error) {
  657. for _, c := range containers {
  658. container, err := s.apiClient().ContainerInspect(ctx, c.ID)
  659. if err != nil {
  660. return false, 0, err
  661. }
  662. if container.State != nil && container.State.Status == "exited" {
  663. return true, container.State.ExitCode, nil
  664. }
  665. }
  666. return false, 0, nil
  667. }
  668. func (s *composeService) startService(ctx context.Context, project *types.Project, service types.ServiceConfig, containers Containers) error {
  669. if service.Deploy != nil && service.Deploy.Replicas != nil && *service.Deploy.Replicas == 0 {
  670. return nil
  671. }
  672. err := s.waitDependencies(ctx, project, service.DependsOn, containers)
  673. if err != nil {
  674. return err
  675. }
  676. if len(containers) == 0 {
  677. if scale, err := getScale(service); err != nil && scale == 0 {
  678. return nil
  679. }
  680. return fmt.Errorf("service %q has no container to start", service.Name)
  681. }
  682. w := progress.ContextWriter(ctx)
  683. for _, container := range containers.filter(isService(service.Name)) {
  684. if container.State == ContainerRunning {
  685. continue
  686. }
  687. eventName := getContainerProgressName(container)
  688. w.Event(progress.StartingEvent(eventName))
  689. err := s.apiClient().ContainerStart(ctx, container.ID, moby.ContainerStartOptions{})
  690. if err != nil {
  691. return err
  692. }
  693. w.Event(progress.StartedEvent(eventName))
  694. }
  695. return nil
  696. }
  697. func mergeLabels(ls ...types.Labels) types.Labels {
  698. merged := types.Labels{}
  699. for _, l := range ls {
  700. for k, v := range l {
  701. merged[k] = v
  702. }
  703. }
  704. return merged
  705. }