Skip to content

Commit cd1b401

Browse files
Michal Kuratczykmkuratczyk
authored andcommitted
Fix LOG macro continuation line indentation
The continuation lines in multi-line LOG macro calls should align with the opening quote character of the format string.
1 parent c0eabc9 commit cd1b401

File tree

3 files changed

+11
-11
lines changed

3 files changed

+11
-11
lines changed

deps/rabbit/src/rabbit_maintenance.erl

Lines changed: 8 additions & 8 deletions
Original file line numberDiff line numberDiff line change
@@ -190,16 +190,16 @@ close_all_client_connections() ->
190190
-spec transfer_leadership_of_quorum_queues([node()]) -> ok.
191191
transfer_leadership_of_quorum_queues([]) ->
192192
?LOG_WARNING("Skipping leadership transfer of quorum queues: no candidate "
193-
"(online, not under maintenance) nodes to transfer to!");
193+
"(online, not under maintenance) nodes to transfer to!");
194194
transfer_leadership_of_quorum_queues(_TransferCandidates) ->
195195
%% we only transfer leadership for QQs that have local leaders
196196
Queues = rabbit_amqqueue:list_local_leaders(),
197197
?LOG_INFO("Will transfer leadership of ~b quorum queues with current leader on this node",
198-
[length(Queues)]),
198+
[length(Queues)]),
199199
[begin
200200
Name = amqqueue:get_name(Q),
201201
?LOG_DEBUG("Will trigger a leader election for local quorum queue ~ts",
202-
[rabbit_misc:rs(Name)]),
202+
[rabbit_misc:rs(Name)]),
203203
%% we trigger an election and exclude this node from the list of candidates
204204
%% by simply shutting its local QQ replica (Ra server)
205205
RaLeader = amqqueue:get_pid(Q),
@@ -228,7 +228,7 @@ transfer_leadership_of_metadata_store(TransferCandidates) ->
228228
-spec transfer_leadership_of_stream_coordinator([node()]) -> ok.
229229
transfer_leadership_of_stream_coordinator([]) ->
230230
?LOG_WARNING("Skipping leadership transfer of stream coordinator: no candidate "
231-
"(online, not under maintenance) nodes to transfer to!");
231+
"(online, not under maintenance) nodes to transfer to!");
232232
transfer_leadership_of_stream_coordinator(TransferCandidates) ->
233233
% try to transfer to the node with the lowest uptime; the assumption is that
234234
% nodes are usually restarted in a rolling fashion, in a consistent order;
@@ -248,11 +248,11 @@ transfer_leadership_of_stream_coordinator(TransferCandidates) ->
248248
stop_local_quorum_queue_followers() ->
249249
Queues = rabbit_amqqueue:list_local_followers(),
250250
?LOG_INFO("Will stop local follower replicas of ~b quorum queues on this node",
251-
[length(Queues)]),
251+
[length(Queues)]),
252252
[begin
253253
Name = amqqueue:get_name(Q),
254254
?LOG_DEBUG("Will stop a local follower replica of quorum queue ~ts",
255-
[rabbit_misc:rs(Name)]),
255+
[rabbit_misc:rs(Name)]),
256256
%% shut down Ra nodes so that they are not considered for leader election
257257
{RegisteredName, _LeaderNode} = amqqueue:get_pid(Q),
258258
RaNode = {RegisteredName, node()},
@@ -296,13 +296,13 @@ revive_local_quorum_queue_replicas() ->
296296
%% empty binary as the vhost name.
297297
{Recovered, Failed} = rabbit_quorum_queue:recover(<<>>, Queues),
298298
?LOG_DEBUG("Successfully revived ~b quorum queue replicas",
299-
[length(Recovered)]),
299+
[length(Recovered)]),
300300
case length(Failed) of
301301
0 ->
302302
ok;
303303
NumFailed ->
304304
?LOG_ERROR("Failed to revive ~b quorum queue replicas",
305-
[NumFailed])
305+
[NumFailed])
306306
end,
307307

308308
?LOG_INFO("Restart of local quorum queue replicas is complete"),

deps/rabbitmq_federation/src/rabbit_federation_exchange_link.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -178,7 +178,7 @@ handle_info(check_internal_exchange, State = #state{internal_exchange = IntXName
178178
case check_internal_exchange(IntXNameBin, State) of
179179
upstream_not_found ->
180180
?LOG_WARNING("Federation link could not find upstream exchange '~ts' and will restart",
181-
[IntXNameBin]),
181+
[IntXNameBin]),
182182
{stop, {shutdown, restart}, State};
183183
_ ->
184184
TRef = erlang:send_after(Interval, self(), check_internal_exchange),
@@ -468,7 +468,7 @@ go(S0 = {not_started, {Upstream, UParams, DownXName}}) ->
468468
internal_exchange_interval = Interval}),
469469
Bindings),
470470
?LOG_INFO("Federation link for ~ts (upstream: ~ts) will perform internal exchange checks "
471-
"every ~b seconds", [rabbit_misc:rs(DownXName), UName, round(Interval / 1000)]),
471+
"every ~b seconds", [rabbit_misc:rs(DownXName), UName, round(Interval / 1000)]),
472472
TRef = erlang:send_after(Interval, self(), check_internal_exchange),
473473
{noreply, State#state{internal_exchange_timer = TRef}}
474474
end, Upstream, UParams, DownXName, S0).

deps/rabbitmq_shovel_management/src/rabbit_shovel_mgmt_shovel.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -49,7 +49,7 @@ resource_exists(ReqData, Context) ->
4949
case get_shovel_node(VHost, Name, ReqData, Context) of
5050
undefined ->
5151
?LOG_ERROR("Shovel with the name '~ts' was not found on virtual host '~ts'. "
52-
"It may be failing to connect and report its status.",
52+
"It may be failing to connect and report its status.",
5353
[Name, VHost]),
5454
case cowboy_req:method(ReqData) of
5555
<<"DELETE">> ->

0 commit comments

Comments
 (0)