summaryrefslogtreecommitdiff
path: root/deps/rabbitmq_cli/lib/rabbitmq/cli/ctl/commands/force_boot_command.ex
diff options
context:
space:
mode:
Diffstat (limited to 'deps/rabbitmq_cli/lib/rabbitmq/cli/ctl/commands/force_boot_command.ex')
-rw-r--r--deps/rabbitmq_cli/lib/rabbitmq/cli/ctl/commands/force_boot_command.ex57
1 files changed, 57 insertions, 0 deletions
diff --git a/deps/rabbitmq_cli/lib/rabbitmq/cli/ctl/commands/force_boot_command.ex b/deps/rabbitmq_cli/lib/rabbitmq/cli/ctl/commands/force_boot_command.ex
new file mode 100644
index 0000000000..261f86c6c1
--- /dev/null
+++ b/deps/rabbitmq_cli/lib/rabbitmq/cli/ctl/commands/force_boot_command.ex
@@ -0,0 +1,57 @@
+## This Source Code Form is subject to the terms of the Mozilla Public
+## License, v. 2.0. If a copy of the MPL was not distributed with this
+## file, You can obtain one at https://mozilla.org/MPL/2.0/.
+##
+## Copyright (c) 2007-2020 VMware, Inc. or its affiliates. All rights reserved.
+
+defmodule RabbitMQ.CLI.Ctl.Commands.ForceBootCommand do
+ alias RabbitMQ.CLI.Core.{Config, DocGuide}
+
+ @behaviour RabbitMQ.CLI.CommandBehaviour
+
+ use RabbitMQ.CLI.Core.MergesNoDefaults
+ use RabbitMQ.CLI.Core.AcceptsNoPositionalArguments
+
+ ##
+ def validate_execution_environment(args, opts) do
+ ## We don't use RequiresRabbitAppStopped helper because we don't want to fail
+ ## the validation if the node is not running.
+ case RabbitMQ.CLI.Core.Validators.rabbit_is_not_running(args, opts) do
+ :ok -> :ok
+ {:validation_failure, _} = failure -> failure
+ _other -> RabbitMQ.CLI.Core.Validators.node_is_not_running(args, opts)
+ end
+ end
+
+ def run([], %{node: node_name} = opts) do
+ case :rabbit_misc.rpc_call(node_name, :rabbit_mnesia, :force_load_next_boot, []) do
+ {:badrpc, :nodedown} ->
+ case Config.get_option(:mnesia_dir, opts) do
+ nil ->
+ {:error, :mnesia_dir_not_found}
+
+ dir ->
+ File.write(Path.join(dir, "force_load"), "")
+ end
+
+ _ ->
+ :ok
+ end
+ end
+
+ use RabbitMQ.CLI.DefaultOutput
+
+ def usage, do: "force_boot"
+
+ def usage_doc_guides() do
+ [
+ DocGuide.clustering()
+ ]
+ end
+
+ def help_section(), do: :cluster_management
+
+ def description(), do: "Forces node to start even if it cannot contact or rejoin any of its previously known peers"
+
+ def banner(_, _), do: nil
+end