Skip to content

Commit ea24887

Browse files
Merge branch 'main' into rabbitmq-server-12412
2 parents 1e18716 + 8b79ac7 commit ea24887

File tree

5 files changed

+17
-67
lines changed

5 files changed

+17
-67
lines changed

deps/rabbit/test/amqp_client_SUITE.erl

Lines changed: 15 additions & 35 deletions
Original file line numberDiff line numberDiff line change
@@ -303,12 +303,15 @@ init_per_testcase(T, Config)
303303
when T =:= detach_requeues_one_session_quorum_queue orelse
304304
T =:= single_active_consumer_quorum_queue orelse
305305
T =:= detach_requeues_two_connections_quorum_queue ->
306-
case rabbit_ct_broker_helpers:enable_feature_flag(Config, 'rabbitmq_4.0.0') of
307-
ok ->
308-
rabbit_ct_helpers:testcase_started(Config, T);
309-
{skip, _} ->
310-
{skip, "Feature flag rabbitmq_4.0.0 enables the consumer removal API"}
311-
end;
306+
%% Feature flag rabbitmq_4.0.0 enables the consumer removal API.
307+
ok = rabbit_ct_broker_helpers:enable_feature_flag(Config, 'rabbitmq_4.0.0'),
308+
rabbit_ct_helpers:testcase_started(Config, T);
309+
init_per_testcase(T, Config)
310+
when T =:= leader_transfer_quorum_queue_credit_single orelse
311+
T =:= leader_transfer_quorum_queue_credit_batches ->
312+
%% These test cases flake with feature flag 'rabbitmq_4.0.0' disabled.
313+
ok = rabbit_ct_broker_helpers:enable_feature_flag(Config, 'rabbitmq_4.0.0'),
314+
rabbit_ct_helpers:testcase_started(Config, T);
312315
init_per_testcase(T = immutable_bare_message, Config) ->
313316
case rpc(Config, rabbit_feature_flags, is_enabled, ['rabbitmq_4.0.0']) of
314317
true ->
@@ -333,26 +336,6 @@ init_per_testcase(T = dead_letter_reject, Config) ->
333336
{skip, "This test is known to fail with feature flag message_containers_deaths_v2 disabled "
334337
"due bug https://github.com/rabbitmq/rabbitmq-server/issues/11159"}
335338
end;
336-
init_per_testcase(T, Config)
337-
when T =:= leader_transfer_quorum_queue_credit_single orelse
338-
T =:= leader_transfer_quorum_queue_credit_batches orelse
339-
T =:= leader_transfer_stream_credit_single orelse
340-
T =:= leader_transfer_stream_credit_batches orelse
341-
T =:= leader_transfer_quorum_queue_send orelse
342-
T =:= leader_transfer_stream_send ->
343-
case rpc(Config, rabbit_feature_flags, is_supported, ['rabbitmq_4.0.0']) of
344-
true ->
345-
rabbit_ct_helpers:testcase_started(Config, T);
346-
false ->
347-
{skip, "This test requires the AMQP management extension of RabbitMQ 4.0"}
348-
end;
349-
init_per_testcase(T, Config)
350-
when T =:= classic_queue_on_new_node orelse
351-
T =:= quorum_queue_on_new_node ->
352-
%% If node 1 runs 4.x, this is the new no-op plugin.
353-
%% If node 1 runs 3.x, this is the old real plugin.
354-
ok = rabbit_ct_broker_helpers:enable_plugin(Config, 1, rabbitmq_amqp1_0),
355-
rabbit_ct_helpers:testcase_started(Config, T);
356339
init_per_testcase(Testcase, Config) ->
357340
rabbit_ct_helpers:testcase_started(Config, Testcase).
358341

@@ -3543,14 +3526,11 @@ async_notify_settled_stream(Config) ->
35433526
async_notify(settled, <<"stream">>, Config).
35443527

35453528
async_notify_unsettled_classic_queue(Config) ->
3546-
case rabbit_ct_broker_helpers:enable_feature_flag(Config, 'rabbitmq_4.0.0') of
3547-
ok ->
3548-
async_notify(unsettled, <<"classic">>, Config);
3549-
{skip, _} ->
3550-
{skip, "Skipping as this test will flake. Link flow control in classic "
3551-
"queues with credit API v1 is known to be broken: "
3552-
"https://github.com/rabbitmq/rabbitmq-server/issues/2597"}
3553-
end.
3529+
%% This test flakes with feature flag 'rabbitmq_4.0.0' disabled.
3530+
%% Link flow control in classic queues with credit API v1 is known to be broken:
3531+
%% https://github.com/rabbitmq/rabbitmq-server/issues/2597
3532+
ok = rabbit_ct_broker_helpers:enable_feature_flag(Config, 'rabbitmq_4.0.0'),
3533+
async_notify(unsettled, <<"classic">>, Config).
35543534

35553535
async_notify_unsettled_quorum_queue(Config) ->
35563536
async_notify(unsettled, <<"quorum">>, Config).
@@ -3852,7 +3832,6 @@ leader_transfer_credit(QName, QType, Credit, Config) ->
38523832
ok = end_session_sync(Session1),
38533833
ok = close_connection_sync(Connection1),
38543834

3855-
%% Consume from a follower.
38563835
OpnConf = connection_config(0, Config),
38573836
{ok, Connection0} = amqp10_client:open_connection(OpnConf),
38583837
{ok, Session0} = amqp10_client:begin_session_sync(Connection0),
@@ -3866,6 +3845,7 @@ leader_transfer_credit(QName, QType, Credit, Config) ->
38663845
ok = wait_for_accepts(NumMsgs),
38673846
ok = detach_link_sync(Sender),
38683847

3848+
%% Consume from a follower.
38693849
ok = wait_for_local_member(QType, QName, Config),
38703850
Filter = consume_from_first(QType),
38713851
{ok, Receiver} = amqp10_client:attach_receiver_link(

deps/rabbit/test/amqp_system_SUITE.erl

Lines changed: 0 additions & 13 deletions
Original file line numberDiff line numberDiff line change
@@ -38,7 +38,6 @@ groups() ->
3838
routing,
3939
invalid_routes,
4040
auth_failure,
41-
access_failure,
4241
access_failure_not_allowed,
4342
access_failure_send,
4443
streams
@@ -217,18 +216,6 @@ invalid_routes(Config) ->
217216
auth_failure(Config) ->
218217
run(Config, [ {dotnet, "auth_failure"} ]).
219218

220-
access_failure(Config) ->
221-
User = atom_to_binary(?FUNCTION_NAME),
222-
ok = rabbit_ct_broker_helpers:add_user(Config, User, <<"boo">>),
223-
ok = rabbit_ct_broker_helpers:set_permissions(Config, User, <<"/">>,
224-
<<".*">>, %% configure
225-
<<"^banana.*">>, %% write
226-
<<"^banana.*">> %% read
227-
),
228-
run(Config, [ {dotnet, "access_failure"} ]),
229-
ok = rabbit_ct_broker_helpers:delete_user(Config, User).
230-
231-
232219
access_failure_not_allowed(Config) ->
233220
User = atom_to_binary(?FUNCTION_NAME),
234221
ok = rabbit_ct_broker_helpers:add_user(Config, User, <<"boo">>),

deps/rabbit/test/amqp_system_SUITE_data/fsharp-tests/Program.fs

Lines changed: 0 additions & 17 deletions
Original file line numberDiff line numberDiff line change
@@ -466,20 +466,6 @@ module Test =
466466
printfn "Exception %A" ex
467467
()
468468

469-
let accessFailure uri =
470-
try
471-
let u = Uri uri
472-
let uri = sprintf "amqp://access_failure:boo@%s:%i" u.Host u.Port
473-
use ac = connect uri
474-
let src = "/queues/test"
475-
let receiver = ReceiverLink(ac.Session, "test-receiver", src)
476-
receiver.Close()
477-
failwith "expected exception not received"
478-
with
479-
| :? Amqp.AmqpException as ex ->
480-
printfn "Exception %A" ex
481-
()
482-
483469
let accessFailureNotAllowed uri =
484470
try
485471
let u = Uri uri
@@ -505,9 +491,6 @@ let main argv =
505491
| [AsLower "auth_failure"; uri] ->
506492
authFailure uri
507493
0
508-
| [AsLower "access_failure"; uri] ->
509-
accessFailure uri
510-
0
511494
| [AsLower "access_failure_not_allowed"; uri] ->
512495
accessFailureNotAllowed uri
513496
0

deps/rabbitmq_auth_backend_http/examples/rabbitmq_auth_backend_spring_boot/pom.xml

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -29,7 +29,7 @@
2929
<parent>
3030
<groupId>org.springframework.boot</groupId>
3131
<artifactId>spring-boot-starter-parent</artifactId>
32-
<version>3.3.4</version>
32+
<version>3.3.5</version>
3333
</parent>
3434

3535
<properties>

deps/rabbitmq_auth_backend_http/examples/rabbitmq_auth_backend_spring_boot_kotlin/pom.xml

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -14,7 +14,7 @@
1414
<parent>
1515
<groupId>org.springframework.boot</groupId>
1616
<artifactId>spring-boot-starter-parent</artifactId>
17-
<version>3.3.4</version>
17+
<version>3.3.5</version>
1818
<relativePath/> <!-- lookup parent from repository -->
1919
</parent>
2020

0 commit comments

Comments
 (0)