Skip to content

Commit 02df90c

Browse files
committed
Trigger CI
1 parent 4f3f4b0 commit 02df90c

File tree

92 files changed

+582
-611
lines changed

Some content is hidden

Large Commits have some content hidden by default. Use the searchbox below for content that may be hidden.

92 files changed

+582
-611
lines changed

deps/amqp10_client/src/amqp10_client_frame_reader.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -158,7 +158,7 @@ handle_event(info, {TcpError, _Sock, Reason}, StateName, State)
158158
handle_event(info, {TcpClosed, _}, StateName, State)
159159
when TcpClosed == tcp_closed orelse TcpClosed == ssl_closed ->
160160
?LOG_INFO("AMQP 1.0 connection socket was closed, connection state: '~ts'",
161-
[StateName]),
161+
[StateName]),
162162
{stop, normal, socket_closed(State)};
163163
handle_event(info, {gun_down, WsPid, _Proto, Reason, _Streams}, StateName,
164164
#state{socket = {ws, WsPid, _StreamRef}} = State) ->

deps/amqp_client/src/amqp_channel.erl

Lines changed: 8 additions & 8 deletions
Original file line numberDiff line numberDiff line change
@@ -516,7 +516,7 @@ handle_info({bump_credit, Msg}, State) ->
516516
%% @private
517517
handle_info(timed_out_flushing_channel, State) ->
518518
?LOG_WARNING("Channel (~tp) closing: timed out flushing while "
519-
"connection closing", [self()]),
519+
"connection closing", [self()]),
520520
{stop, timed_out_flushing_channel, State};
521521
%% @private
522522
handle_info({'DOWN', _, process, ReturnHandler, shutdown},
@@ -525,7 +525,7 @@ handle_info({'DOWN', _, process, ReturnHandler, shutdown},
525525
handle_info({'DOWN', _, process, ReturnHandler, Reason},
526526
State = #state{return_handler = {ReturnHandler, _Ref}}) ->
527527
?LOG_WARNING("Channel (~tp): Unregistering return handler ~tp because it died. "
528-
"Reason: ~tp", [self(), ReturnHandler, Reason]),
528+
"Reason: ~tp", [self(), ReturnHandler, Reason]),
529529
{noreply, State#state{return_handler = none}};
530530
%% @private
531531
handle_info({'DOWN', _, process, ConfirmHandler, shutdown},
@@ -534,7 +534,7 @@ handle_info({'DOWN', _, process, ConfirmHandler, shutdown},
534534
handle_info({'DOWN', _, process, ConfirmHandler, Reason},
535535
State = #state{confirm_handler = {ConfirmHandler, _Ref}}) ->
536536
?LOG_WARNING("Channel (~tp): Unregistering confirm handler ~tp because it died. "
537-
"Reason: ~tp", [self(), ConfirmHandler, Reason]),
537+
"Reason: ~tp", [self(), ConfirmHandler, Reason]),
538538
{noreply, State#state{confirm_handler = none}};
539539
%% @private
540540
handle_info({'DOWN', _, process, FlowHandler, shutdown},
@@ -543,7 +543,7 @@ handle_info({'DOWN', _, process, FlowHandler, shutdown},
543543
handle_info({'DOWN', _, process, FlowHandler, Reason},
544544
State = #state{flow_handler = {FlowHandler, _Ref}}) ->
545545
?LOG_WARNING("Channel (~tp): Unregistering flow handler ~tp because it died. "
546-
"Reason: ~tp", [self(), FlowHandler, Reason]),
546+
"Reason: ~tp", [self(), FlowHandler, Reason]),
547547
{noreply, State#state{flow_handler = none}};
548548
handle_info({'DOWN', _, process, QPid, _Reason}, State) ->
549549
rabbit_amqqueue_common:notify_sent_queue_down(QPid),
@@ -593,13 +593,13 @@ handle_method_to_server(Method, AmqpMsg, From, Sender, Flow,
593593
From, Sender, Flow, State1)};
594594
{ok, none, BlockReply} ->
595595
?LOG_WARNING("Channel (~tp): discarding method ~tp in cast.~n"
596-
"Reason: ~tp", [self(), Method, BlockReply]),
596+
"Reason: ~tp", [self(), Method, BlockReply]),
597597
{noreply, State};
598598
{ok, _, BlockReply} ->
599599
{reply, BlockReply, State};
600600
{{_, InvalidMethodMessage}, none, _} ->
601601
?LOG_WARNING("Channel (~tp): ignoring cast of ~tp method. " ++
602-
InvalidMethodMessage ++ "", [self(), Method]),
602+
InvalidMethodMessage ++ "", [self(), Method]),
603603
{noreply, State};
604604
{{InvalidMethodReply, _}, _, _} ->
605605
{reply, {error, InvalidMethodReply}, State}
@@ -796,7 +796,7 @@ handle_method_from_server1(#'basic.ack'{} = BasicAck, none,
796796
handle_method_from_server1(#'basic.nack'{} = BasicNack, none,
797797
#state{confirm_handler = none} = State) ->
798798
?LOG_WARNING("Channel (~tp): received ~tp but there is no "
799-
"confirm handler registered", [self(), BasicNack]),
799+
"confirm handler registered", [self(), BasicNack]),
800800
{noreply, update_confirm_set(BasicNack, State)};
801801
handle_method_from_server1(#'basic.nack'{} = BasicNack, none,
802802
#state{confirm_handler = {CH, _Ref}} = State) ->
@@ -932,7 +932,7 @@ server_misbehaved(#amqp_error{} = AmqpError, State = #state{number = Number}) ->
932932
handle_shutdown({server_misbehaved, AmqpError}, State);
933933
{_, Close} ->
934934
?LOG_WARNING("Channel (~tp) flushing and closing due to soft "
935-
"error caused by the server ~tp", [self(), AmqpError]),
935+
"error caused by the server ~tp", [self(), AmqpError]),
936936
Self = self(),
937937
spawn(fun () -> call(Self, Close) end),
938938
{noreply, State}

deps/amqp_client/src/amqp_connection.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -429,7 +429,7 @@ maybe_update_call_timeout(BaseTimeout, CallTimeout)
429429
maybe_update_call_timeout(BaseTimeout, CallTimeout) ->
430430
EffectiveSafeCallTimeout = amqp_util:safe_call_timeout(BaseTimeout),
431431
?LOG_WARNING("AMQP 0-9-1 client call timeout was ~tp ms, is updated to a safe effective "
432-
"value of ~tp ms", [CallTimeout, EffectiveSafeCallTimeout]),
432+
"value of ~tp ms", [CallTimeout, EffectiveSafeCallTimeout]),
433433
amqp_util:update_call_timeout(EffectiveSafeCallTimeout),
434434
ok.
435435

deps/amqp_client/src/amqp_gen_connection.erl

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -207,12 +207,12 @@ handle_cast({register_blocked_handler, HandlerPid}, State) ->
207207
handle_info({'DOWN', _, process, BlockHandler, Reason},
208208
State = #state{block_handler = {BlockHandler, _Ref}}) ->
209209
?LOG_WARNING("Connection (~tp): Unregistering connection.{blocked,unblocked} handler ~tp because it died. "
210-
"Reason: ~tp", [self(), BlockHandler, Reason]),
210+
"Reason: ~tp", [self(), BlockHandler, Reason]),
211211
{noreply, State#state{block_handler = none}};
212212
handle_info({'EXIT', BlockHandler, Reason},
213213
State = #state{block_handler = {BlockHandler, Ref}}) ->
214214
?LOG_WARNING("Connection (~tp): Unregistering connection.{blocked,unblocked} handler ~tp because it died. "
215-
"Reason: ~tp", [self(), BlockHandler, Reason]),
215+
"Reason: ~tp", [self(), BlockHandler, Reason]),
216216
erlang:demonitor(Ref, [flush]),
217217
{noreply, State#state{block_handler = none}};
218218
%% propagate the exit to the module that will stop with a sensible reason logged
@@ -318,7 +318,7 @@ internal_error(Pid, Reason, State) ->
318318

319319
server_initiated_close(Close, State) ->
320320
?LOG_WARNING("Connection (~tp) closing: received hard error ~tp "
321-
"from server", [self(), Close]),
321+
"from server", [self(), Close]),
322322
set_closing_state(abrupt, #closing{reason = server_initiated_close,
323323
close = Close}, State).
324324

deps/amqp_client/src/amqp_ssl.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -53,7 +53,7 @@ maybe_add_verify1(Options) ->
5353
Options;
5454
_ ->
5555
?LOG_WARNING("Connection (~tp): certificate chain verification is not enabled for this TLS connection. "
56-
"Please see https://rabbitmq.com/ssl.html for more information.", [self()]),
56+
"Please see https://rabbitmq.com/ssl.html for more information.", [self()]),
5757
Options
5858
end.
5959

deps/rabbit/src/mirrored_supervisor.erl

Lines changed: 8 additions & 8 deletions
Original file line numberDiff line numberDiff line change
@@ -288,15 +288,15 @@ handle_call({start_child, ChildSpec}, _From,
288288
Result = case maybe_start(Group, Overall, Delegate, ChildSpec) of
289289
already_in_store ->
290290
?LOG_DEBUG("Mirrored supervisor: maybe_start for group ~tp,"
291-
" overall ~p returned 'record already present'", [Group, Overall]),
291+
" overall ~p returned 'record already present'", [Group, Overall]),
292292
{error, already_present};
293293
{already_in_store, Pid} ->
294294
?LOG_DEBUG("Mirrored supervisor: maybe_start for group ~tp,"
295-
" overall ~p returned 'already running: ~tp'", [Group, Overall, Pid]),
295+
" overall ~p returned 'already running: ~tp'", [Group, Overall, Pid]),
296296
{error, {already_started, Pid}};
297297
Else ->
298298
?LOG_DEBUG("Mirrored supervisor: maybe_start for group ~tp,"
299-
" overall ~tp returned ~tp", [Group, Overall, Else]),
299+
" overall ~tp returned ~tp", [Group, Overall, Else]),
300300
Else
301301
end,
302302
mirrored_supervisor_locks:unlock(LockId),
@@ -384,16 +384,16 @@ maybe_start(Group, Overall, Delegate, ChildSpec) ->
384384
try check_start(Group, Overall, Delegate, ChildSpec) of
385385
start ->
386386
?LOG_DEBUG("Mirrored supervisor: check_start for group ~tp,"
387-
" overall ~tp returned 'do start'", [Group, Overall]),
387+
" overall ~tp returned 'do start'", [Group, Overall]),
388388
start(Delegate, ChildSpec);
389389
undefined ->
390390
?LOG_DEBUG("Mirrored supervisor: check_start for group ~tp,"
391-
" overall ~tp returned 'undefined'", [Group, Overall]),
391+
" overall ~tp returned 'undefined'", [Group, Overall]),
392392
already_in_store;
393393
Pid ->
394394
?LOG_DEBUG("Mirrored supervisor: check_start for group ~tp,"
395-
" overall ~tp returned 'already running (~tp)'",
396-
[Group, Overall, Pid]),
395+
" overall ~tp returned 'already running (~tp)'",
396+
[Group, Overall, Pid]),
397397
{already_in_store, Pid}
398398
catch
399399
%% If we are torn down while in the transaction...
@@ -403,7 +403,7 @@ maybe_start(Group, Overall, Delegate, ChildSpec) ->
403403
check_start(Group, Overall, Delegate, ChildSpec) ->
404404
Id = id(ChildSpec),
405405
?LOG_DEBUG("Mirrored supervisor: check_start for group ~tp, id: ~tp, "
406-
"overall: ~tp", [Group, Id, Overall]),
406+
"overall: ~tp", [Group, Id, Overall]),
407407
case rabbit_db_msup:create_or_update(Group, Overall, Delegate, ChildSpec, Id) of
408408
Delegate0 when is_pid(Delegate0) ->
409409
child(Delegate0, Id);

deps/rabbit/src/rabbit.erl

Lines changed: 9 additions & 12 deletions
Original file line numberDiff line numberDiff line change
@@ -358,8 +358,7 @@ run_prelaunch_second_phase() ->
358358
case IsInitialPass of
359359
true ->
360360
?LOG_DEBUG(""),
361-
?LOG_DEBUG(
362-
"== Prelaunch phase [2/2] (initial pass) ==");
361+
?LOG_DEBUG("== Prelaunch phase [2/2] (initial pass) ==");
363362
false ->
364363
?LOG_DEBUG(""),
365364
?LOG_DEBUG("== Prelaunch phase [2/2] =="),
@@ -522,10 +521,9 @@ stop_and_halt() ->
522521
try
523522
stop()
524523
catch Type:Reason ->
525-
?LOG_ERROR(
526-
"Error trying to stop ~ts: ~tp:~tp",
527-
[product_name(), Type, Reason],
528-
#{domain => ?RMQLOG_DOMAIN_PRELAUNCH}),
524+
?LOG_ERROR("Error trying to stop ~ts: ~tp:~tp",
525+
[product_name(), Type, Reason],
526+
#{domain => ?RMQLOG_DOMAIN_PRELAUNCH}),
529527
error({Type, Reason})
530528
after
531529
%% Enclose all the logging in the try block.
@@ -896,9 +894,8 @@ environment(App) ->
896894
-spec rotate_logs() -> rabbit_types:ok_or_error(any()).
897895

898896
rotate_logs() ->
899-
?LOG_ERROR(
900-
"Forcing log rotation is currently unsupported",
901-
#{domain => ?RMQLOG_DOMAIN_GLOBAL}),
897+
?LOG_ERROR("Forcing log rotation is currently unsupported",
898+
#{domain => ?RMQLOG_DOMAIN_GLOBAL}),
902899
{error, unsupported}.
903900

904901
%%--------------------------------------------------------------------
@@ -1179,7 +1176,7 @@ prevent_startup_if_node_was_reset() ->
11791176
true ->
11801177
?LOG_ERROR("Node has already been initialized, but database appears empty. "
11811178
"This could indicate data loss or a split-brain scenario.",
1182-
#{domain => ?RMQLOG_DOMAIN_GLOBAL}),
1179+
#{domain => ?RMQLOG_DOMAIN_GLOBAL}),
11831180
throw({error, cluster_already_initialized_but_tables_empty});
11841181
false ->
11851182
?LOG_INFO("Node has already been initialized, proceeding with normal startup",
@@ -1189,7 +1186,7 @@ prevent_startup_if_node_was_reset() ->
11891186
false ->
11901187
%% First time starting, create the marker file
11911188
?LOG_INFO("First node startup detected, creating initialization marker",
1192-
#{domain => ?RMQLOG_DOMAIN_GLOBAL}),
1189+
#{domain => ?RMQLOG_DOMAIN_GLOBAL}),
11931190
ok = filelib:ensure_dir(MarkerFile),
11941191
ok = file:write_file(MarkerFile, <<>>, [exclusive]), % Empty file.
11951192
ok
@@ -1689,7 +1686,7 @@ maybe_warn_low_fd_limit() ->
16891686
ok;
16901687
L ->
16911688
?LOG_WARNING("Available file handles: ~tp. "
1692-
"Please consider increasing system limits", [L])
1689+
"Please consider increasing system limits", [L])
16931690
end.
16941691

16951692
%% Any configuration that

deps/rabbit/src/rabbit_access_control.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -75,7 +75,7 @@ check_user_login(Username, AuthProps, Modules) ->
7575
Type:Error:Stacktrace ->
7676
?LOG_DEBUG("User '~ts' authentication failed with ~ts:~tp:~n~tp", [Username, Type, Error, Stacktrace]),
7777
{refused, Username, "User '~ts' authentication failed with internal error. "
78-
"Enable debug logs to see the real error.", [Username]}
78+
"Enable debug logs to see the real error.", [Username]}
7979

8080
end.
8181

deps/rabbit/src/rabbit_amqqueue.erl

Lines changed: 7 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -535,11 +535,11 @@ maybe_migrate(ByNode, MaxQueuesDesired, [N | Nodes]) ->
535535
end;
536536
[{_, _, true} | _] = All when length(All) > MaxQueuesDesired ->
537537
?LOG_WARNING("Node ~tp contains ~tp queues, but all have already migrated. "
538-
"Do nothing", [N, length(All)]),
538+
"Do nothing", [N, length(All)]),
539539
maybe_migrate(ByNode, MaxQueuesDesired, Nodes);
540540
All ->
541541
?LOG_DEBUG("Node ~tp only contains ~tp queues, do nothing",
542-
[N, length(All)]),
542+
[N, length(All)]),
543543
maybe_migrate(ByNode, MaxQueuesDesired, Nodes)
544544
end.
545545

@@ -1895,7 +1895,8 @@ internal_delete(Queue, ActingUser, Reason) ->
18951895
%% TODO this is used by `rabbit_mnesia:remove_node_if_mnesia_running`
18961896
%% Does it make any sense once mnesia is not used/removed?
18971897
forget_all_durable(Node) ->
1898-
?LOG_INFO("Will remove all classic queues from node ~ts. The node is likely being removed from the cluster.", [Node]),
1898+
?LOG_INFO("Will remove all classic queues from node ~ts. The node is likely being removed from the cluster.",
1899+
[Node]),
18991900
UpdateFun = fun(Q) ->
19001901
forget_node_for_queue(Q)
19011902
end,
@@ -1961,9 +1962,9 @@ on_node_down(Node) ->
19611962
%% restarts - a time that the cluster is very likely to have a
19621963
%% majority - to ensure these records are deleted.
19631964
?LOG_WARNING("transient queues for node '~ts' could not be "
1964-
"deleted because of a timeout. These queues "
1965-
"will be removed when node '~ts' restarts or "
1966-
"is removed from the cluster.", [Node, Node]),
1965+
"deleted because of a timeout. These queues "
1966+
"will be removed when node '~ts' restarts or "
1967+
"is removed from the cluster.", [Node, Node]),
19671968
ok
19681969
end.
19691970

deps/rabbit/src/rabbit_auth_backend_internal.erl

Lines changed: 12 additions & 12 deletions
Original file line numberDiff line numberDiff line change
@@ -472,17 +472,17 @@ notify_user_tags_set(Username, ConvertedTags, ActingUser) ->
472472

473473
set_permissions(Username, VirtualHost, ConfigurePerm, WritePerm, ReadPerm, ActingUser) ->
474474
?LOG_DEBUG("Asked to set permissions for user "
475-
"'~ts' in virtual host '~ts' to '~ts', '~ts', '~ts'",
476-
[Username, VirtualHost, ConfigurePerm, WritePerm, ReadPerm]),
475+
"'~ts' in virtual host '~ts' to '~ts', '~ts', '~ts'",
476+
[Username, VirtualHost, ConfigurePerm, WritePerm, ReadPerm]),
477477
_ = lists:map(
478478
fun (RegexpBin) ->
479479
Regexp = binary_to_list(RegexpBin),
480480
case re:compile(Regexp) of
481481
{ok, _} -> ok;
482482
{error, Reason} ->
483483
?LOG_WARNING("Failed to set permissions for user '~ts' in virtual host '~ts': "
484-
"regular expression '~ts' is invalid",
485-
[Username, VirtualHost, RegexpBin]),
484+
"regular expression '~ts' is invalid",
485+
[Username, VirtualHost, RegexpBin]),
486486
throw({error, {invalid_regexp, Regexp, Reason}})
487487
end
488488
end, [ConfigurePerm, WritePerm, ReadPerm]),
@@ -497,8 +497,8 @@ set_permissions(Username, VirtualHost, ConfigurePerm, WritePerm, ReadPerm, Actin
497497
read = ReadPerm}},
498498
R = rabbit_db_user:set_user_permissions(UserPermission),
499499
?LOG_INFO("Successfully set permissions for user "
500-
"'~ts' in virtual host '~ts' to '~ts', '~ts', '~ts'",
501-
[Username, VirtualHost, ConfigurePerm, WritePerm, ReadPerm]),
500+
"'~ts' in virtual host '~ts' to '~ts', '~ts', '~ts'",
501+
[Username, VirtualHost, ConfigurePerm, WritePerm, ReadPerm]),
502502
rabbit_event:notify(permission_created, [{user, Username},
503503
{vhost, VirtualHost},
504504
{configure, ConfigurePerm},
@@ -579,8 +579,8 @@ set_permissions_globally(Username, ConfigurePerm, WritePerm, ReadPerm, ActingUse
579579

580580
set_topic_permissions(Username, VirtualHost, Exchange, WritePerm, ReadPerm, ActingUser) ->
581581
?LOG_DEBUG("Asked to set topic permissions on exchange '~ts' for "
582-
"user '~ts' in virtual host '~ts' to '~ts', '~ts'",
583-
[Exchange, Username, VirtualHost, WritePerm, ReadPerm]),
582+
"user '~ts' in virtual host '~ts' to '~ts', '~ts'",
583+
[Exchange, Username, VirtualHost, WritePerm, ReadPerm]),
584584
WritePermRegex = rabbit_data_coercion:to_binary(WritePerm),
585585
ReadPermRegex = rabbit_data_coercion:to_binary(ReadPerm),
586586
lists:foreach(
@@ -589,8 +589,8 @@ set_topic_permissions(Username, VirtualHost, Exchange, WritePerm, ReadPerm, Acti
589589
{ok, _} -> ok;
590590
{error, Reason} ->
591591
?LOG_WARNING("Failed to set topic permissions on exchange '~ts' for user "
592-
"'~ts' in virtual host '~ts': regular expression '~ts' is invalid",
593-
[Exchange, Username, VirtualHost, RegexpBin]),
592+
"'~ts' in virtual host '~ts': regular expression '~ts' is invalid",
593+
[Exchange, Username, VirtualHost, RegexpBin]),
594594
throw({error, {invalid_regexp, RegexpBin, Reason}})
595595
end
596596
end, [WritePerm, ReadPerm]),
@@ -609,8 +609,8 @@ set_topic_permissions(Username, VirtualHost, Exchange, WritePerm, ReadPerm, Acti
609609
},
610610
R = rabbit_db_user:set_topic_permissions(TopicPermission),
611611
?LOG_INFO("Successfully set topic permissions on exchange '~ts' for "
612-
"user '~ts' in virtual host '~ts' to '~ts', '~ts'",
613-
[Exchange, Username, VirtualHost, WritePerm, ReadPerm]),
612+
"user '~ts' in virtual host '~ts' to '~ts', '~ts'",
613+
[Exchange, Username, VirtualHost, WritePerm, ReadPerm]),
614614
rabbit_event:notify(topic_permission_created, [
615615
{user, Username},
616616
{vhost, VirtualHost},

0 commit comments

Comments
 (0)