fix: untangle worker set message from application message
[e-mobility-charging-stations-simulator.git] / src / charging-station / Bootstrap.ts
index c0dc2b3d2ff22aaeefdc221d3ccab4dce8ebc7ac..c13eb1b187cc7d6a60cb93e772096348f44c2309 100644 (file)
@@ -1,30 +1,32 @@
-// Partial Copyright Jerome Benoit. 2021-2023. All Rights Reserved.
+// Partial Copyright Jerome Benoit. 2021-2024. All Rights Reserved.
 
 import { EventEmitter } from 'node:events'
 import { dirname, extname, join } from 'node:path'
 import process, { exit } from 'node:process'
 import { fileURLToPath } from 'node:url'
+import { isMainThread } from 'node:worker_threads'
 
 import chalk from 'chalk'
-import { availableParallelism } from 'poolifier'
+import { availableParallelism, type MessageHandler } from 'poolifier'
+import type { Worker } from 'worker_threads'
 
-import { waitChargingStationEvents } from './Helpers.js'
-import type { AbstractUIServer } from './ui-server/AbstractUIServer.js'
-import { UIServerFactory } from './ui-server/UIServerFactory.js'
 import { version } from '../../package.json'
 import { BaseError } from '../exception/index.js'
 import { type Storage, StorageFactory } from '../performance/index.js'
 import {
   type ChargingStationData,
+  type ChargingStationInfo,
+  type ChargingStationOptions,
   type ChargingStationWorkerData,
   type ChargingStationWorkerMessage,
   type ChargingStationWorkerMessageData,
   ChargingStationWorkerMessageEvents,
   ConfigurationSection,
   ProcedureName,
-  type StationTemplateUrl,
+  type SimulatorState,
   type Statistics,
   type StorageConfiguration,
+  type TemplateStatistics,
   type UIServerConfiguration,
   type WorkerConfiguration
 } from '../types/index.js'
@@ -35,34 +37,37 @@ import {
   generateUUID,
   handleUncaughtException,
   handleUnhandledRejection,
+  isAsyncFunction,
   isNotEmptyArray,
-  logPrefix,
-  logger
+  logger,
+  logPrefix
 } from '../utils/index.js'
-import { type WorkerAbstract, WorkerFactory } from '../worker/index.js'
+import { DEFAULT_ELEMENTS_PER_WORKER, type WorkerAbstract, WorkerFactory } from '../worker/index.js'
+import { buildTemplateName, waitChargingStationEvents } from './Helpers.js'
+import type { AbstractUIServer } from './ui-server/AbstractUIServer.js'
+import { UIServerFactory } from './ui-server/UIServerFactory.js'
 
 const moduleName = 'Bootstrap'
 
 enum exitCodes {
   succeeded = 0,
   missingChargingStationsConfiguration = 1,
-  noChargingStationTemplates = 2,
-  gracefulShutdownError = 3
+  duplicateChargingStationTemplateUrls = 2,
+  noChargingStationTemplates = 3,
+  gracefulShutdownError = 4
 }
 
 export class Bootstrap extends EventEmitter {
   private static instance: Bootstrap | null = null
-  public numberOfChargingStations!: number
-  public numberOfChargingStationTemplates!: number
-  private workerImplementation?: WorkerAbstract<ChargingStationWorkerData>
-  private readonly uiServer?: AbstractUIServer
+  private workerImplementation?: WorkerAbstract<ChargingStationWorkerData, ChargingStationInfo>
+  private readonly uiServer: AbstractUIServer
   private storage?: Storage
-  private numberOfStartedChargingStations!: number
+  private readonly templateStatistics: Map<string, TemplateStatistics>
   private readonly version: string = version
-  private initializedCounters: boolean
   private started: boolean
   private starting: boolean
   private stopping: boolean
+  private uiServerStarted: boolean
 
   private constructor () {
     super()
@@ -75,13 +80,19 @@ export class Bootstrap extends EventEmitter {
     this.started = false
     this.starting = false
     this.stopping = false
-    this.initializedCounters = false
-    this.initializeCounters()
+    this.uiServerStarted = false
+    this.templateStatistics = new Map<string, TemplateStatistics>()
     this.uiServer = UIServerFactory.getUIServerImplementation(
       Configuration.getConfigurationSection<UIServerConfiguration>(ConfigurationSection.uiServer)
     )
+    this.initializeCounters()
+    this.initializeWorkerImplementation(
+      Configuration.getConfigurationSection<WorkerConfiguration>(ConfigurationSection.worker)
+    )
     Configuration.configurationChangeCallback = async () => {
-      await Bootstrap.getInstance().restart(false)
+      if (isMainThread) {
+        await Bootstrap.getInstance().restart()
+      }
     }
   }
 
@@ -92,10 +103,62 @@ export class Bootstrap extends EventEmitter {
     return Bootstrap.instance
   }
 
+  public get numberOfChargingStationTemplates (): number {
+    return this.templateStatistics.size
+  }
+
+  public get numberOfConfiguredChargingStations (): number {
+    return [...this.templateStatistics.values()].reduce(
+      (accumulator, value) => accumulator + value.configured,
+      0
+    )
+  }
+
+  public getState (): SimulatorState {
+    return {
+      version: this.version,
+      started: this.started,
+      templateStatistics: this.templateStatistics
+    }
+  }
+
+  public getLastIndex (templateName: string): number {
+    // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
+    const indexes = [...this.templateStatistics.get(templateName)!.indexes]
+      .concat(0)
+      .sort((a, b) => a - b)
+    for (let i = 0; i < indexes.length - 1; i++) {
+      if (indexes[i + 1] - indexes[i] !== 1) {
+        return indexes[i]
+      }
+    }
+    return indexes[indexes.length - 1]
+  }
+
+  public getPerformanceStatistics (): IterableIterator<Statistics> | undefined {
+    return this.storage?.getPerformanceStatistics()
+  }
+
+  private get numberOfAddedChargingStations (): number {
+    return [...this.templateStatistics.values()].reduce(
+      (accumulator, value) => accumulator + value.added,
+      0
+    )
+  }
+
+  private get numberOfStartedChargingStations (): number {
+    return [...this.templateStatistics.values()].reduce(
+      (accumulator, value) => accumulator + value.started,
+      0
+    )
+  }
+
   public async start (): Promise<void> {
     if (!this.started) {
       if (!this.starting) {
         this.starting = true
+        this.on(ChargingStationWorkerMessageEvents.added, this.workerEventAdded)
+        this.on(ChargingStationWorkerMessageEvents.deleted, this.workerEventDeleted)
         this.on(ChargingStationWorkerMessageEvents.started, this.workerEventStarted)
         this.on(ChargingStationWorkerMessageEvents.stopped, this.workerEventStopped)
         this.on(ChargingStationWorkerMessageEvents.updated, this.workerEventUpdated)
@@ -103,12 +166,12 @@ export class Bootstrap extends EventEmitter {
           ChargingStationWorkerMessageEvents.performanceStatistics,
           this.workerEventPerformanceStatistics
         )
-        this.initializeCounters()
-        const workerConfiguration = Configuration.getConfigurationSection<WorkerConfiguration>(
-          ConfigurationSection.worker
-        )
-        this.initializeWorkerImplementation(workerConfiguration)
-        await this.workerImplementation?.start()
+        // eslint-disable-next-line @typescript-eslint/unbound-method
+        if (isAsyncFunction(this.workerImplementation?.start)) {
+          await this.workerImplementation.start()
+        } else {
+          (this.workerImplementation?.start as () => void)()
+        }
         const performanceStorageConfiguration =
           Configuration.getConfigurationSection<StorageConfiguration>(
             ConfigurationSection.performanceStorage
@@ -123,15 +186,22 @@ export class Bootstrap extends EventEmitter {
           )
           await this.storage?.open()
         }
-        Configuration.getConfigurationSection<UIServerConfiguration>(ConfigurationSection.uiServer)
-          .enabled === true && this.uiServer?.start()
+        if (
+          !this.uiServerStarted &&
+          Configuration.getConfigurationSection<UIServerConfiguration>(
+            ConfigurationSection.uiServer
+          ).enabled === true
+        ) {
+          this.uiServer.start()
+          this.uiServerStarted = true
+        }
         // Start ChargingStation object instance in worker thread
         // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
         for (const stationTemplateUrl of Configuration.getStationTemplateUrls()!) {
           try {
             const nbStations = stationTemplateUrl.numberOfStations
             for (let index = 1; index <= nbStations; index++) {
-              await this.startChargingStation(index, stationTemplateUrl)
+              await this.addChargingStation(index, stationTemplateUrl.file)
             }
           } catch (error) {
             console.error(
@@ -142,18 +212,17 @@ export class Bootstrap extends EventEmitter {
             )
           }
         }
+        const workerConfiguration = Configuration.getConfigurationSection<WorkerConfiguration>(
+          ConfigurationSection.worker
+        )
         console.info(
           chalk.green(
             `Charging stations simulator ${
               this.version
-            } started with ${this.numberOfChargingStations.toString()} charging station(s) from ${this.numberOfChargingStationTemplates.toString()} configured charging station template(s) and ${
-              Configuration.workerDynamicPoolInUse()
-                ? `${workerConfiguration.poolMinSize?.toString()}/`
-                : ''
+            } started with ${this.numberOfConfiguredChargingStations} configured charging station(s) from ${this.numberOfChargingStationTemplates} charging station template(s) and ${
+              Configuration.workerDynamicPoolInUse() ? `${workerConfiguration.poolMinSize}/` : ''
             }${this.workerImplementation?.size}${
-              Configuration.workerPoolInUse()
-                ? `/${workerConfiguration.poolMaxSize?.toString()}`
-                : ''
+              Configuration.workerPoolInUse() ? `/${workerConfiguration.poolMaxSize}` : ''
             } worker(s) concurrently running in '${workerConfiguration.processType}' mode${
               this.workerImplementation?.maxElementsPerWorker != null
                 ? ` (${this.workerImplementation.maxElementsPerWorker} charging station(s) per worker)`
@@ -178,31 +247,27 @@ export class Bootstrap extends EventEmitter {
     }
   }
 
-  public async stop (stopChargingStations = true): Promise<void> {
+  public async stop (): Promise<void> {
     if (this.started) {
       if (!this.stopping) {
         this.stopping = true
-        if (stopChargingStations) {
-          await this.uiServer?.sendInternalRequest(
-            this.uiServer.buildProtocolRequest(
-              generateUUID(),
-              ProcedureName.STOP_CHARGING_STATION,
-              Constants.EMPTY_FROZEN_OBJECT
-            )
+        await this.uiServer.sendInternalRequest(
+          this.uiServer.buildProtocolRequest(
+            generateUUID(),
+            ProcedureName.STOP_CHARGING_STATION,
+            Constants.EMPTY_FROZEN_OBJECT
           )
-          try {
-            await this.waitChargingStationsStopped()
-          } catch (error) {
-            console.error(chalk.red('Error while waiting for charging stations to stop: '), error)
-          }
+        )
+        try {
+          await this.waitChargingStationsStopped()
+        } catch (error) {
+          console.error(chalk.red('Error while waiting for charging stations to stop: '), error)
         }
         await this.workerImplementation?.stop()
-        delete this.workerImplementation
         this.removeAllListeners()
+        this.uiServer.clearCaches()
         await this.storage?.close()
         delete this.storage
-        this.resetCounters()
-        this.initializedCounters = false
         this.started = false
         this.stopping = false
       } else {
@@ -213,15 +278,26 @@ export class Bootstrap extends EventEmitter {
     }
   }
 
-  public async restart (stopChargingStations?: boolean): Promise<void> {
-    await this.stop(stopChargingStations)
-    Configuration.getConfigurationSection<UIServerConfiguration>(ConfigurationSection.uiServer)
-      .enabled === false && this.uiServer?.stop()
+  private async restart (): Promise<void> {
+    await this.stop()
+    if (
+      this.uiServerStarted &&
+      Configuration.getConfigurationSection<UIServerConfiguration>(ConfigurationSection.uiServer)
+        .enabled !== true
+    ) {
+      this.uiServer.stop()
+      this.uiServerStarted = false
+    }
+    this.initializeCounters()
+    // FIXME: initialize worker implementation only if the worker section has changed
+    this.initializeWorkerImplementation(
+      Configuration.getConfigurationSection<WorkerConfiguration>(ConfigurationSection.worker)
+    )
     await this.start()
   }
 
   private async waitChargingStationsStopped (): Promise<string> {
-    return await new Promise<string>((resolve, reject) => {
+    return await new Promise<string>((resolve, reject: (reason?: unknown) => void) => {
       const waitTimeout = setTimeout(() => {
         const timeoutMessage = `Timeout ${formatDurationMilliSeconds(
           Constants.STOP_CHARGING_STATIONS_TIMEOUT
@@ -245,19 +321,27 @@ export class Bootstrap extends EventEmitter {
   }
 
   private initializeWorkerImplementation (workerConfiguration: WorkerConfiguration): void {
-    let elementsPerWorker: number | undefined
+    if (!isMainThread) {
+      return
+    }
+    let elementsPerWorker: number
     switch (workerConfiguration.elementsPerWorker) {
+      case 'all':
+        elementsPerWorker = this.numberOfConfiguredChargingStations
+        break
       case 'auto':
         elementsPerWorker =
-          this.numberOfChargingStations > availableParallelism()
-            ? Math.round(this.numberOfChargingStations / (availableParallelism() * 1.5))
+          this.numberOfConfiguredChargingStations > availableParallelism()
+            ? Math.round(this.numberOfConfiguredChargingStations / (availableParallelism() * 1.5))
             : 1
         break
-      case 'all':
-        elementsPerWorker = this.numberOfChargingStations
-        break
+      default:
+        elementsPerWorker = workerConfiguration.elementsPerWorker ?? DEFAULT_ELEMENTS_PER_WORKER
     }
-    this.workerImplementation = WorkerFactory.getWorkerImplementation<ChargingStationWorkerData>(
+    this.workerImplementation = WorkerFactory.getWorkerImplementation<
+    ChargingStationWorkerData,
+    ChargingStationInfo
+    >(
       join(
         dirname(fileURLToPath(import.meta.url)),
         `ChargingStationWorker${extname(fileURLToPath(import.meta.url))}`
@@ -266,15 +350,17 @@ export class Bootstrap extends EventEmitter {
       workerConfiguration.processType!,
       {
         workerStartDelay: workerConfiguration.startDelay,
-        elementStartDelay: workerConfiguration.elementStartDelay,
+        elementAddDelay: workerConfiguration.elementAddDelay,
         // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
         poolMaxSize: workerConfiguration.poolMaxSize!,
         // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
         poolMinSize: workerConfiguration.poolMinSize!,
-        elementsPerWorker: elementsPerWorker ?? (workerConfiguration.elementsPerWorker as number),
+        elementsPerWorker,
         poolOptions: {
-          messageHandler: this.messageHandler.bind(this) as (message: unknown) => void,
-          workerOptions: { resourceLimits: workerConfiguration.resourceLimits }
+          messageHandler: this.messageHandler.bind(this) as MessageHandler<Worker>,
+          ...(workerConfiguration.resourceLimits != null && {
+            workerOptions: { resourceLimits: workerConfiguration.resourceLimits }
+          })
         }
       }
     )
@@ -292,29 +378,23 @@ export class Bootstrap extends EventEmitter {
     // )
     try {
       switch (msg.event) {
+        case ChargingStationWorkerMessageEvents.added:
+          this.emit(ChargingStationWorkerMessageEvents.added, msg.data)
+          break
+        case ChargingStationWorkerMessageEvents.deleted:
+          this.emit(ChargingStationWorkerMessageEvents.deleted, msg.data)
+          break
         case ChargingStationWorkerMessageEvents.started:
-          this.emit(ChargingStationWorkerMessageEvents.started, msg.data as ChargingStationData)
+          this.emit(ChargingStationWorkerMessageEvents.started, msg.data)
           break
         case ChargingStationWorkerMessageEvents.stopped:
-          this.emit(ChargingStationWorkerMessageEvents.stopped, msg.data as ChargingStationData)
+          this.emit(ChargingStationWorkerMessageEvents.stopped, msg.data)
           break
         case ChargingStationWorkerMessageEvents.updated:
-          this.emit(ChargingStationWorkerMessageEvents.updated, msg.data as ChargingStationData)
+          this.emit(ChargingStationWorkerMessageEvents.updated, msg.data)
           break
         case ChargingStationWorkerMessageEvents.performanceStatistics:
-          this.emit(
-            ChargingStationWorkerMessageEvents.performanceStatistics,
-            msg.data as Statistics
-          )
-          break
-        case ChargingStationWorkerMessageEvents.startWorkerElementError:
-          logger.error(
-            `${this.logPrefix()} ${moduleName}.messageHandler: Error occured while starting worker element:`,
-            msg.data
-          )
-          this.emit(ChargingStationWorkerMessageEvents.startWorkerElementError, msg.data)
-          break
-        case ChargingStationWorkerMessageEvents.startedWorkerElement:
+          this.emit(ChargingStationWorkerMessageEvents.performanceStatistics, msg.data)
           break
         default:
           throw new BaseError(
@@ -333,89 +413,152 @@ export class Bootstrap extends EventEmitter {
     }
   }
 
+  private readonly workerEventAdded = (data: ChargingStationData): void => {
+    this.uiServer.chargingStations.set(data.stationInfo.hashId, data)
+    logger.info(
+      `${this.logPrefix()} ${moduleName}.workerEventAdded: Charging station ${
+        data.stationInfo.chargingStationId
+      } (hashId: ${data.stationInfo.hashId}) added (${
+        this.numberOfAddedChargingStations
+      } added from ${this.numberOfConfiguredChargingStations} configured charging station(s))`
+    )
+  }
+
+  private readonly workerEventDeleted = (data: ChargingStationData): void => {
+    this.uiServer.chargingStations.delete(data.stationInfo.hashId)
+    // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
+    const templateStatistics = this.templateStatistics.get(data.stationInfo.templateName)!
+    --templateStatistics.added
+    templateStatistics.indexes.delete(data.stationInfo.templateIndex)
+    logger.info(
+      `${this.logPrefix()} ${moduleName}.workerEventDeleted: Charging station ${
+        data.stationInfo.chargingStationId
+      } (hashId: ${data.stationInfo.hashId}) deleted (${
+        this.numberOfAddedChargingStations
+      } added from ${this.numberOfConfiguredChargingStations} configured charging station(s))`
+    )
+  }
+
   private readonly workerEventStarted = (data: ChargingStationData): void => {
-    this.uiServer?.chargingStations.set(data.stationInfo.hashId, data)
-    ++this.numberOfStartedChargingStations
+    this.uiServer.chargingStations.set(data.stationInfo.hashId, data)
+    // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
+    ++this.templateStatistics.get(data.stationInfo.templateName)!.started
     logger.info(
       `${this.logPrefix()} ${moduleName}.workerEventStarted: Charging station ${
         data.stationInfo.chargingStationId
       } (hashId: ${data.stationInfo.hashId}) started (${
         this.numberOfStartedChargingStations
-      } started from ${this.numberOfChargingStations})`
+      } started from ${this.numberOfAddedChargingStations} added charging station(s))`
     )
   }
 
   private readonly workerEventStopped = (data: ChargingStationData): void => {
-    this.uiServer?.chargingStations.set(data.stationInfo.hashId, data)
-    --this.numberOfStartedChargingStations
+    this.uiServer.chargingStations.set(data.stationInfo.hashId, data)
+    // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
+    --this.templateStatistics.get(data.stationInfo.templateName)!.started
     logger.info(
       `${this.logPrefix()} ${moduleName}.workerEventStopped: Charging station ${
         data.stationInfo.chargingStationId
       } (hashId: ${data.stationInfo.hashId}) stopped (${
         this.numberOfStartedChargingStations
-      } started from ${this.numberOfChargingStations})`
+      } started from ${this.numberOfAddedChargingStations} added charging station(s))`
     )
   }
 
   private readonly workerEventUpdated = (data: ChargingStationData): void => {
-    this.uiServer?.chargingStations.set(data.stationInfo.hashId, data)
+    this.uiServer.chargingStations.set(data.stationInfo.hashId, data)
   }
 
   private readonly workerEventPerformanceStatistics = (data: Statistics): void => {
-    this.storage?.storePerformanceStatistics(data) as undefined
+    // eslint-disable-next-line @typescript-eslint/unbound-method
+    if (isAsyncFunction(this.storage?.storePerformanceStatistics)) {
+      (
+        this.storage.storePerformanceStatistics as (
+          performanceStatistics: Statistics
+        ) => Promise<void>
+      )(data).catch(Constants.EMPTY_FUNCTION)
+    } else {
+      (this.storage?.storePerformanceStatistics as (performanceStatistics: Statistics) => void)(
+        data
+      )
+    }
   }
 
   private initializeCounters (): void {
-    if (!this.initializedCounters) {
-      this.resetCounters()
-      // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
-      const stationTemplateUrls = Configuration.getStationTemplateUrls()!
-      if (isNotEmptyArray(stationTemplateUrls)) {
-        this.numberOfChargingStationTemplates = stationTemplateUrls.length
-        for (const stationTemplateUrl of stationTemplateUrls) {
-          this.numberOfChargingStations += stationTemplateUrl.numberOfStations
-        }
-      } else {
-        console.warn(
-          chalk.yellow("'stationTemplateUrls' not defined or empty in configuration, exiting")
-        )
-        exit(exitCodes.missingChargingStationsConfiguration)
+    // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
+    const stationTemplateUrls = Configuration.getStationTemplateUrls()!
+    if (isNotEmptyArray(stationTemplateUrls)) {
+      for (const stationTemplateUrl of stationTemplateUrls) {
+        const templateName = buildTemplateName(stationTemplateUrl.file)
+        this.templateStatistics.set(templateName, {
+          configured: stationTemplateUrl.numberOfStations,
+          added: 0,
+          started: 0,
+          indexes: new Set<number>()
+        })
+        this.uiServer.chargingStationTemplates.add(templateName)
       }
-      if (this.numberOfChargingStations === 0) {
-        console.warn(chalk.yellow('No charging station template enabled in configuration, exiting'))
-        exit(exitCodes.noChargingStationTemplates)
+      if (this.templateStatistics.size !== stationTemplateUrls.length) {
+        console.error(
+          chalk.red(
+            "'stationTemplateUrls' contains duplicate entries, please check your configuration"
+          )
+        )
+        exit(exitCodes.duplicateChargingStationTemplateUrls)
       }
-      this.initializedCounters = true
+    } else {
+      console.error(
+        chalk.red("'stationTemplateUrls' not defined or empty, please check your configuration")
+      )
+      exit(exitCodes.missingChargingStationsConfiguration)
+    }
+    if (
+      this.numberOfConfiguredChargingStations === 0 &&
+      Configuration.getConfigurationSection<UIServerConfiguration>(ConfigurationSection.uiServer)
+        .enabled !== true
+    ) {
+      console.error(
+        chalk.red(
+          "'stationTemplateUrls' has no charging station enabled and UI server is disabled, please check your configuration"
+        )
+      )
+      exit(exitCodes.noChargingStationTemplates)
     }
   }
 
-  private resetCounters (): void {
-    this.numberOfChargingStationTemplates = 0
-    this.numberOfChargingStations = 0
-    this.numberOfStartedChargingStations = 0
-  }
-
-  private async startChargingStation (
+  public async addChargingStation (
     index: number,
-    stationTemplateUrl: StationTemplateUrl
-  ): Promise<void> {
-    await this.workerImplementation?.addElement({
+    templateFile: string,
+    options?: ChargingStationOptions
+  ): Promise<ChargingStationInfo | undefined> {
+    if (!this.started && !this.starting) {
+      throw new BaseError(
+        'Cannot add charging station while the charging stations simulator is not started'
+      )
+    }
+    const stationInfo = await this.workerImplementation?.addElement({
       index,
       templateFile: join(
         dirname(fileURLToPath(import.meta.url)),
         'assets',
         'station-templates',
-        stationTemplateUrl.file
-      )
+        templateFile
+      ),
+      options
     })
+    // eslint-disable-next-line @typescript-eslint/no-non-null-assertion
+    const templateStatistics = this.templateStatistics.get(buildTemplateName(templateFile))!
+    ++templateStatistics.added
+    templateStatistics.indexes.add(index)
+    return stationInfo
   }
 
   private gracefulShutdown (): void {
     this.stop()
       .then(() => {
         console.info(chalk.green('Graceful shutdown'))
-        this.uiServer?.stop()
-        // stop() asks for charging stations to stop by default
+        this.uiServer.stop()
+        this.uiServerStarted = false
         this.waitChargingStationsStopped()
           .then(() => {
             exit(exitCodes.succeeded)
@@ -424,7 +567,7 @@ export class Bootstrap extends EventEmitter {
             exit(exitCodes.gracefulShutdownError)
           })
       })
-      .catch(error => {
+      .catch((error: unknown) => {
         console.error(chalk.red('Error while shutdowning charging stations simulator: '), error)
         exit(exitCodes.gracefulShutdownError)
       })