rabbitmq-server/deps/rabbit/test/dynamic_qq_SUITE.erl

255 lines
10 KiB
Erlang

%% 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-2021 VMware, Inc. or its affiliates. All rights reserved.
%%
-module(dynamic_qq_SUITE).
-include_lib("common_test/include/ct.hrl").
-include_lib("eunit/include/eunit.hrl").
-include_lib("amqp_client/include/amqp_client.hrl").
-import(quorum_queue_utils, [wait_for_messages_ready/3,
ra_name/1]).
-compile(nowarn_export_all).
-compile(export_all).
all() ->
[
{group, clustered}
].
groups() ->
[
{clustered, [], [
{cluster_size_3, [], [
recover_follower_after_standalone_restart,
vhost_deletion,
force_delete_if_no_consensus,
takeover_on_failure,
takeover_on_shutdown,
quorum_unaffected_after_vhost_failure
]}
]}
].
%% -------------------------------------------------------------------
%% Testsuite setup/teardown.
%% -------------------------------------------------------------------
init_per_suite(Config) ->
rabbit_ct_helpers:log_environment(),
rabbit_ct_helpers:run_setup_steps(Config).
end_per_suite(Config) ->
rabbit_ct_helpers:run_teardown_steps(Config).
init_per_group(clustered, Config) ->
rabbit_ct_helpers:set_config(Config, [{rmq_nodes_clustered, true}]);
init_per_group(cluster_size_2, Config) ->
rabbit_ct_helpers:set_config(Config, [{rmq_nodes_count, 2}]);
init_per_group(cluster_size_3, Config) ->
rabbit_ct_helpers:set_config(Config, [{rmq_nodes_count, 3}]).
end_per_group(_, Config) ->
Config.
init_per_testcase(Testcase, Config) ->
case rabbit_ct_helpers:is_mixed_versions() andalso
Testcase == quorum_unaffected_after_vhost_failure of
true ->
{skip, "test case not mixed versions compatible"};
false ->
rabbit_ct_helpers:testcase_started(Config, Testcase),
ClusterSize = ?config(rmq_nodes_count, Config),
TestNumber = rabbit_ct_helpers:testcase_number(Config, ?MODULE, Testcase),
Group = proplists:get_value(name, ?config(tc_group_properties, Config)),
Q = rabbit_data_coercion:to_binary(io_lib:format("~p_~p", [Group, Testcase])),
Config1 = rabbit_ct_helpers:set_config(Config, [
{rmq_nodename_suffix, Testcase},
{tcp_ports_base, {skip_n_nodes, TestNumber * ClusterSize}},
{queue_name, Q},
{queue_args, [{<<"x-queue-type">>, longstr, <<"quorum">>}]}
]),
Config2 = rabbit_ct_helpers:run_steps(
Config1,
rabbit_ct_broker_helpers:setup_steps() ++
rabbit_ct_client_helpers:setup_steps()),
case rabbit_ct_broker_helpers:enable_feature_flag(Config2, quorum_queue) of
ok ->
Config2;
Skip ->
end_per_testcase(Testcase, Config2),
Skip
end
end.
end_per_testcase(Testcase, Config) ->
Config1 = rabbit_ct_helpers:run_steps(Config,
rabbit_ct_client_helpers:teardown_steps() ++
rabbit_ct_broker_helpers:teardown_steps()),
rabbit_ct_helpers:testcase_finished(Config1, Testcase).
%% -------------------------------------------------------------------
%% Testcases.
%% -------------------------------------------------------------------
%% Vhost deletion needs to successfully tear down queues.
vhost_deletion(Config) ->
Node = rabbit_ct_broker_helpers:get_node_config(Config, 0, nodename),
Ch = rabbit_ct_client_helpers:open_channel(Config, Node),
QName = ?config(queue_name, Config),
Args = ?config(queue_args, Config),
amqp_channel:call(Ch, #'queue.declare'{queue = QName,
arguments = Args,
durable = true
}),
ok = rpc:call(Node, rabbit_vhost, delete, [<<"/">>, <<"acting-user">>]),
?assertMatch([],
rabbit_ct_broker_helpers:rabbitmqctl_list(
Config, 0, ["list_queues", "name"])),
ok.
force_delete_if_no_consensus(Config) ->
[A, B, C] = rabbit_ct_broker_helpers:get_node_configs(Config, nodename),
ACh = rabbit_ct_client_helpers:open_channel(Config, A),
QName = ?config(queue_name, Config),
Args = ?config(queue_args, Config),
amqp_channel:call(ACh, #'queue.declare'{queue = QName,
arguments = Args,
durable = true
}),
rabbit_ct_client_helpers:publish(ACh, QName, 10),
ok = rabbit_ct_broker_helpers:restart_node(Config, B),
ok = rabbit_ct_broker_helpers:stop_node(Config, A),
ok = rabbit_ct_broker_helpers:stop_node(Config, C),
BCh = rabbit_ct_client_helpers:open_channel(Config, B),
?assertMatch(
#'queue.declare_ok'{},
amqp_channel:call(
BCh, #'queue.declare'{queue = QName,
arguments = Args,
durable = true,
passive = true})),
BCh2 = rabbit_ct_client_helpers:open_channel(Config, B),
?assertMatch(#'queue.delete_ok'{},
amqp_channel:call(BCh2, #'queue.delete'{queue = QName})),
ok.
takeover_on_failure(Config) ->
takeover_on(Config, kill_node).
takeover_on_shutdown(Config) ->
takeover_on(Config, stop_node).
takeover_on(Config, Fun) ->
[A, B, C] = rabbit_ct_broker_helpers:get_node_configs(Config, nodename),
ACh = rabbit_ct_client_helpers:open_channel(Config, A),
QName = ?config(queue_name, Config),
Args = ?config(queue_args, Config),
amqp_channel:call(ACh, #'queue.declare'{queue = QName,
arguments = Args,
durable = true
}),
rabbit_ct_client_helpers:publish(ACh, QName, 10),
ok = rabbit_ct_broker_helpers:restart_node(Config, B),
ok = rabbit_ct_broker_helpers:Fun(Config, C),
ok = rabbit_ct_broker_helpers:Fun(Config, A),
BCh = rabbit_ct_client_helpers:open_channel(Config, B),
#'queue.declare_ok'{} =
amqp_channel:call(
BCh, #'queue.declare'{queue = QName,
arguments = Args,
durable = true}),
ok = rabbit_ct_broker_helpers:start_node(Config, A),
ACh2 = rabbit_ct_client_helpers:open_channel(Config, A),
#'queue.declare_ok'{message_count = 10} =
amqp_channel:call(
ACh2, #'queue.declare'{queue = QName,
arguments = Args,
durable = true}),
ok.
quorum_unaffected_after_vhost_failure(Config) ->
[A, B, _] = Servers0 = rabbit_ct_broker_helpers:get_node_configs(Config, nodename),
Servers = lists:sort(Servers0),
ACh = rabbit_ct_client_helpers:open_channel(Config, A),
QName = ?config(queue_name, Config),
Args = ?config(queue_args, Config),
amqp_channel:call(ACh, #'queue.declare'{queue = QName,
arguments = Args,
durable = true
}),
timer:sleep(300),
Info0 = rpc:call(A, rabbit_quorum_queue, infos,
[rabbit_misc:r(<<"/">>, queue, QName)]),
?assertEqual(Servers, lists:sort(proplists:get_value(online, Info0, []))),
%% Crash vhost on both nodes
{ok, SupA} = rabbit_ct_broker_helpers:rpc(Config, A, rabbit_vhost_sup_sup, get_vhost_sup, [<<"/">>]),
exit(SupA, foo),
{ok, SupB} = rabbit_ct_broker_helpers:rpc(Config, B, rabbit_vhost_sup_sup, get_vhost_sup, [<<"/">>]),
exit(SupB, foo),
Info = rpc:call(A, rabbit_quorum_queue, infos,
[rabbit_misc:r(<<"/">>, queue, QName)]),
?assertEqual(Servers, lists:sort(proplists:get_value(online, Info, []))).
recover_follower_after_standalone_restart(Config) ->
case rabbit_ct_helpers:is_mixed_versions() of
false ->
%% Tests that followers can be brought up standalone after forgetting the
%% rest of the cluster. Consensus won't be reached as there is only one node in the
%% new cluster.
Servers = [A, B, C] = rabbit_ct_broker_helpers:get_node_configs(Config, nodename),
Ch = rabbit_ct_client_helpers:open_channel(Config, A),
QName = ?config(queue_name, Config),
Args = ?config(queue_args, Config),
amqp_channel:call(Ch, #'queue.declare'{queue = QName,
arguments = Args,
durable = true
}),
rabbit_ct_client_helpers:publish(Ch, QName, 15),
rabbit_ct_client_helpers:close_channel(Ch),
Name = ra_name(QName),
wait_for_messages_ready(Servers, Name, 15),
rabbit_ct_broker_helpers:stop_node(Config, C),
rabbit_ct_broker_helpers:stop_node(Config, B),
rabbit_ct_broker_helpers:stop_node(Config, A),
%% Restart one follower
forget_cluster_node(Config, B, C),
forget_cluster_node(Config, B, A),
ok = rabbit_ct_broker_helpers:start_node(Config, B),
wait_for_messages_ready([B], Name, 15),
ok = rabbit_ct_broker_helpers:stop_node(Config, B),
%% Restart the other
forget_cluster_node(Config, C, B),
forget_cluster_node(Config, C, A),
ok = rabbit_ct_broker_helpers:start_node(Config, C),
wait_for_messages_ready([C], Name, 15),
ok = rabbit_ct_broker_helpers:stop_node(Config, C),
ok;
_ ->
{skip, "cannot be run in mixed mode"}
end.
%%----------------------------------------------------------------------------
forget_cluster_node(Config, Node, NodeToRemove) ->
rabbit_ct_broker_helpers:rabbitmqctl(
Config, Node, ["forget_cluster_node", "--offline", NodeToRemove]).