Skip to content

Commit 6f3277f

Browse files
Merge branch 'v3.7.x' into rabbitmq-server-1873-binding-recovery-37
2 parents 02d88df + eb1b137 commit 6f3277f

34 files changed

+53
-53
lines changed

docs/rabbitmq-service.8

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -115,7 +115,7 @@ Defaults to
115115
for 64-bit environments).
116116
This is the installation location of the Erlang service manager.
117117
.It Ev RABBITMQ_CONSOLE_LOG
118-
Set this varable to
118+
Set this variable to
119119
.Sy new or
120120
.Sy reuse
121121
to have the console output from the server redirected to a file named

docs/rabbitmq.conf.example

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -804,7 +804,7 @@
804804
## See http://rabbitmq.com/logging.html and https://github.com/erlang-lager/lager for details.
805805
##
806806

807-
## Log direcrory, taken from the RABBITMQ_LOG_BASE env variable by default.
807+
## Log directory, taken from the RABBITMQ_LOG_BASE env variable by default.
808808
##
809809
# log.dir = /var/log/rabbitmq
810810

docs/rabbitmq.config.example

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -339,7 +339,7 @@
339339

340340
%% Enables flow control between queue mirrors.
341341
%% Disabling this can be dangerous and is not recommended.
342-
%% When flow control is disablied, queue masters can outpace mirrors and not allow mirrors to catch up.
342+
%% When flow control is disabled, queue masters can outpace mirrors and not allow mirrors to catch up.
343343
%% Mirrors will end up using increasingly more RAM, eventually triggering a memory alarm.
344344
%%
345345
%% {mirroring_flow_control, true},
@@ -909,7 +909,7 @@
909909
%% {rabbit_channel_lager_event, [{handlers, [
910910
%% {lager_forwarder_backend,
911911
%% [lager_event, info]}]}]},
912-
%% {rabbit_conection_lager_event, [{handlers, [
912+
%% {rabbit_connection_lager_event, [{handlers, [
913913
%% {lager_forwarder_backend,
914914
%% [lager_event, info]}]}]},
915915
%% {rabbit_mirroring_lager_event, [{handlers, [

docs/rabbitmqctl.8

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -156,7 +156,7 @@ To use this precompiled files, you should set
156156
.Ev RABBITMQ_SERVER_CODE_PATH
157157
environment variable to directory specified in
158158
.Cm hipe_compile
159-
invokation.
159+
invocation.
160160
.Pp
161161
For example, to HiPE-compile modules and store them to
162162
.Pa /tmp/rabbit-hipe/ebin
@@ -255,7 +255,7 @@ For example, to instruct the RabbitMQ node to terminate:
255255
.Dl rabbitmqctl stop
256256
.\" ------------------------------------
257257
.It Cm stop_app
258-
Stops the RabbitMQ application, leaving the runtme (Erlang VM) running.
258+
Stops the RabbitMQ application, leaving the runtime (Erlang VM) running.
259259
.Pp
260260
This command is typically run prior to performing other management
261261
actions that require the RabbitMQ application to be stopped, e.g.\&

erlang.mk

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -596,7 +596,7 @@ pkg_check_node_commit = master
596596

597597
PACKAGES += chronos
598598
pkg_chronos_name = chronos
599-
pkg_chronos_description = Timer module for Erlang that makes it easy to abstact time out of the tests.
599+
pkg_chronos_description = Timer module for Erlang that makes it easy to abstract time out of the tests.
600600
pkg_chronos_homepage = https://github.com/lehoff/chronos
601601
pkg_chronos_fetch = git
602602
pkg_chronos_repo = https://github.com/lehoff/chronos
@@ -1340,7 +1340,7 @@ pkg_erlang_cep_commit = master
13401340

13411341
PACKAGES += erlang_js
13421342
pkg_erlang_js_name = erlang_js
1343-
pkg_erlang_js_description = A linked-in driver for Erlang to Mozilla's Spidermonkey Javascript runtime.
1343+
pkg_erlang_js_description = A linked-in driver for Erlang to Mozilla's Spidermonkey JavaScript runtime.
13441344
pkg_erlang_js_homepage = https://github.com/basho/erlang_js
13451345
pkg_erlang_js_fetch = git
13461346
pkg_erlang_js_repo = https://github.com/basho/erlang_js
@@ -4132,7 +4132,7 @@ pkg_yaws_commit = master
41324132

41334133
PACKAGES += zab_engine
41344134
pkg_zab_engine_name = zab_engine
4135-
pkg_zab_engine_description = zab propotocol implement by erlang
4135+
pkg_zab_engine_description = zab protocol implement by erlang
41364136
pkg_zab_engine_homepage = https://github.com/xinmingyao/zab_engine
41374137
pkg_zab_engine_fetch = git
41384138
pkg_zab_engine_repo = https://github.com/xinmingyao/zab_engine

priv/schema/rabbit.schema

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -900,7 +900,7 @@ fun(Conf) ->
900900
end
901901
end}.
902902

903-
%% Classic config-driven peer discuvery backend.
903+
%% Classic config-driven peer discovery backend.
904904
%%
905905
%% Make clustering happen *automatically* at startup - only applied
906906
%% to nodes that have just been reset or started for the first time.

rabbitmq-components.mk

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -226,7 +226,7 @@ export base_rmq_ref
226226
# If cloning from this computed location fails, we fallback to RabbitMQ
227227
# upstream which is GitHub.
228228

229-
# Maccro to transform eg. "rabbit_common" to "rabbitmq-common".
229+
# Macro to transform eg. "rabbit_common" to "rabbitmq-common".
230230
rmq_cmp_repo_name = $(word 2,$(dep_$(1)))
231231

232232
# Upstream URL for the current project.

scripts/rabbitmq-server

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -218,7 +218,7 @@ fi
218218
# The defaults are meant to reduce RabbitMQ's memory usage and help
219219
# it reclaim memory at the cost of a slight decrease in performance
220220
# (due to an increase in memory operations). These defaults can be
221-
# overriden using the RABBITMQ_SERVER_ERL_ARGS variable.
221+
# overridden using the RABBITMQ_SERVER_ERL_ARGS variable.
222222
RABBITMQ_DEFAULT_ALLOC_ARGS="+MBas ageffcbf +MHas ageffcbf +MBlmbcs 512 +MHlmbcs 512 +MMmcs 30"
223223

224224
${ERL_DIR}erl ${RABBITMQ_DEFAULT_ALLOC_ARGS} \
@@ -371,7 +371,7 @@ else
371371
# This is considered an abnormal process termination. Normally, we
372372
# don't need to specify this exit code because the shell propagates it.
373373
# Unfortunately, the signal handler doesn't work as expected in Dash,
374-
# thus we need to explicitely restate the exit code.
374+
# thus we need to explicitly restate the exit code.
375375
trap "stop_rabbitmq_server; exit 0" HUP TERM TSTP
376376
trap "stop_rabbitmq_server; exit 130" INT
377377

scripts/rabbitmq-server.bat

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -166,7 +166,7 @@ rem
166166
rem The defaults are meant to reduce RabbitMQ's memory usage and help
167167
rem it reclaim memory at the cost of a slight decrease in performance
168168
rem (due to an increase in memory operations). These defaults can be
169-
rem overriden using the RABBITMQ_SERVER_ERL_ARGS variable.
169+
rem overridden using the RABBITMQ_SERVER_ERL_ARGS variable.
170170

171171
set RABBITMQ_DEFAULT_ALLOC_ARGS=+MBas ageffcbf +MHas ageffcbf +MBlmbcs 512 +MHlmbcs 512 +MMmcs 30
172172

scripts/rabbitmq-service.bat

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -253,7 +253,7 @@ rem
253253
rem The defaults are meant to reduce RabbitMQ's memory usage and help
254254
rem it reclaim memory at the cost of a slight decrease in performance
255255
rem (due to an increase in memory operations). These defaults can be
256-
rem overriden using the RABBITMQ_SERVER_ERL_ARGS variable.
256+
rem overridden using the RABBITMQ_SERVER_ERL_ARGS variable.
257257

258258
set RABBITMQ_DEFAULT_ALLOC_ARGS=+MBas ageffcbf +MHas ageffcbf +MBlmbcs 512 +MHlmbcs 512 +MMmcs 30
259259

src/gm.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -1264,7 +1264,7 @@ neighbour_cast(N, Msg) -> ?INSTR_MOD:cast(get_pid(N), Msg).
12641264
neighbour_call(N, Msg) -> ?INSTR_MOD:call(get_pid(N), Msg, infinity).
12651265

12661266
%% ---------------------------------------------------------------------------
1267-
%% View monitoring and maintanence
1267+
%% View monitoring and maintenance
12681268
%% ---------------------------------------------------------------------------
12691269

12701270
ensure_neighbour(_Ver, Self, {Self, undefined}, Self) ->

src/rabbit_amqqueue_process.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -1121,7 +1121,7 @@ prioritise_cast(Msg, _Len, State) ->
11211121
%% will be rate limited by how fast consumers receive messages -
11221122
%% i.e. by notify_sent. We prioritise ack and resume to discourage
11231123
%% starvation caused by prioritising notify_sent. We don't vary their
1124-
%% prioritiy since acks should stay in order (some parts of the queue
1124+
%% priority since acks should stay in order (some parts of the queue
11251125
%% stack are optimised for that) and to make things easier to reason
11261126
%% about. Finally, we prioritise ack over resume since it should
11271127
%% always reduce memory use.

src/rabbit_channel.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -1334,7 +1334,7 @@ handle_method(#'basic.qos'{prefetch_size = Size}, _, _State) when Size /= 0 ->
13341334
handle_method(#'basic.qos'{global = false,
13351335
prefetch_count = PrefetchCount},
13361336
_, State = #ch{limiter = Limiter}) ->
1337-
%% Ensures that if default was set, it's overriden
1337+
%% Ensures that if default was set, it's overridden
13381338
Limiter1 = rabbit_limiter:unlimit_prefetch(Limiter),
13391339
{reply, #'basic.qos_ok'{}, State#ch{consumer_prefetch = PrefetchCount,
13401340
limiter = Limiter1}};

src/rabbit_guid.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -94,7 +94,7 @@ advance_blocks({B1, B2, B3, B4}, I) ->
9494
%% hashing {B5, I}. The new hash is used as last block, and the
9595
%% other three blocks are XORed with it.
9696
%%
97-
%% Doing this is convenient because it avoids cascading conflits,
97+
%% Doing this is convenient because it avoids cascading conflicts,
9898
%% while being very fast. The conflicts are avoided by propagating
9999
%% the changes through all the blocks at each round by XORing, so
100100
%% the only occasion in which a collision will take place is when

src/rabbit_lager.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -396,7 +396,7 @@ prepare_rabbit_log_config() ->
396396
set_env_default_log_console();
397397
FileName when is_list(FileName) ->
398398
case os:getenv("RABBITMQ_LOGS_source") of
399-
%% The user explicitely sets $RABBITMQ_LOGS;
399+
%% The user explicitly sets $RABBITMQ_LOGS;
400400
%% we should override a file location even
401401
%% if it's set in rabbitmq.config
402402
"environment" -> set_env_default_log_file(FileName, override);
@@ -406,7 +406,7 @@ prepare_rabbit_log_config() ->
406406

407407
%% Upgrade log file never overrides the value set in rabbitmq.config
408408
case UpgradeFile of
409-
%% No special env for upgrade logs - rederect to the default sink
409+
%% No special env for upgrade logs - redirect to the default sink
410410
undefined -> ok;
411411
%% Redirect logs to default output.
412412
DefaultFile -> ok;

src/rabbit_mirror_queue_coordinator.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -360,7 +360,7 @@ handle_cast({gm_deaths, DeadGMPids},
360360
%% Different slave is now master, stop current coordinator normally.
361361
%% Initiating queue is now slave and the least we could do is report
362362
%% deaths which we 'think' we saw.
363-
%% NOTE: Reported deaths here, could be inconsistant.
363+
%% NOTE: Reported deaths here, could be inconsistent.
364364
rabbit_mirror_queue_misc:report_deaths(MPid, false, QueueName,
365365
DeadPids),
366366
{stop, shutdown, State};

src/rabbit_mirror_queue_misc.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -572,7 +572,7 @@ validate_sync_batch_size(none) ->
572572
validate_sync_batch_size(N) when is_integer(N) andalso N > 0 ->
573573
ok;
574574
validate_sync_batch_size(N) ->
575-
{error, "ha-sync-batch-size takes an integer greather than 0, "
575+
{error, "ha-sync-batch-size takes an integer greater than 0, "
576576
"~p given", [N]}.
577577

578578
validate_pos(PromoteOnShutdown) ->

src/rabbit_msg_store.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -263,7 +263,7 @@
263263
%% updated.
264264
%%
265265
%% On non-clean startup, we scan the files we discover, dealing with
266-
%% the possibilites of a crash having occurred during a compaction
266+
%% the possibilities of a crash having occurred during a compaction
267267
%% (this consists of tidyup - the compaction is deliberately designed
268268
%% such that data is duplicated on disk rather than risking it being
269269
%% lost), and rebuild the file summary and index ETS table.
@@ -594,7 +594,7 @@ client_read2(false, undefined, _MsgLocation, Defer, _CState) ->
594594
Defer();
595595
client_read2(true, _Right, _MsgLocation, Defer, _CState) ->
596596
%% Of course, in the mean time, the GC could have run and our msg
597-
%% is actually in a different file, unlocked. However, defering is
597+
%% is actually in a different file, unlocked. However, deferring is
598598
%% the safest and simplest thing to do.
599599
Defer();
600600
client_read2(false, _Right,

src/rabbit_node_monitor.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -209,7 +209,7 @@ subscribe(Pid) ->
209209
%% We could confirm something by having an HA queue see the pausing
210210
%% state (and fail over into it) before the node monitor stops us, or
211211
%% by using unmirrored queues and just having them vanish (and
212-
%% confiming messages as thrown away).
212+
%% confirming messages as thrown away).
213213
%%
214214
%% So we have channels call in here before issuing confirms, to do a
215215
%% lightweight check that we have not entered a pausing state.

src/rabbit_priority_queue.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -20,7 +20,7 @@
2020
-include_lib("rabbit_framing.hrl").
2121
-behaviour(rabbit_backing_queue).
2222

23-
%% enabled unconditionally. Disabling priority queueing after
23+
%% enabled unconditionally. Disabling priority queuing after
2424
%% it has been enabled is dangerous.
2525
-rabbit_boot_step({?MODULE,
2626
[{description, "enable priority queue"},
@@ -53,7 +53,7 @@
5353
-define(passthrough3(F),
5454
{Res1, Res2, BQS1} = BQ:F, {Res1, Res2, State#passthrough{bqs = BQS1}}).
5555

56-
%% This module adds suport for priority queues.
56+
%% This module adds support for priority queues.
5757
%%
5858
%% Priority queues have one backing queue per priority. Backing queue functions
5959
%% then produce a list of results for each BQ and fold over them, sorting

src/rabbit_queue_index.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -368,7 +368,7 @@ pre_publish(MsgOrId, SeqId, MsgProps, IsPersistent, IsDelivered, JournalSizeHint
368368
State1#qistate{pre_publish_cache = PPC1,
369369
delivered_cache = DC1})).
370370

371-
%% pre_publish_cache is the entry with most elements when comapred to
371+
%% pre_publish_cache is the entry with most elements when compared to
372372
%% delivered_cache so we only check the former in the guard.
373373
maybe_flush_pre_publish_cache(JournalSizeHint,
374374
#qistate{pre_publish_cache = PPC} = State)

src/rabbit_reader.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -232,7 +232,7 @@ server_properties(Protocol) ->
232232
{ok, RawConfigServerProps} = application:get_env(rabbit,
233233
server_properties),
234234

235-
%% Normalize the simplifed (2-tuple) and unsimplified (3-tuple) forms
235+
%% Normalize the simplified (2-tuple) and unsimplified (3-tuple) forms
236236
%% from the config and merge them with the generated built-in properties
237237
NormalizedConfigServerProps =
238238
[{<<"capabilities">>, table, server_capabilities(Protocol)} |
@@ -839,7 +839,7 @@ handle_exception(State = #v1{connection = #connection{protocol = Protocol},
839839
respond_and_close(State, Channel, Protocol, Reason,
840840
{handshake_error, CS, Reason});
841841
%% when negotiation fails, e.g. due to channel_max being higher than the
842-
%% maxiumum allowed limit
842+
%% maximum allowed limit
843843
handle_exception(State = #v1{connection = #connection{protocol = Protocol,
844844
log_name = ConnName,
845845
user = User},

src/rabbit_upgrade.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -39,7 +39,7 @@
3939
%% clusters.
4040
%%
4141
%% Firstly, we have two different types of upgrades to do: Mnesia and
42-
%% everythinq else. Mnesia upgrades must only be done by one node in
42+
%% everything else. Mnesia upgrades must only be done by one node in
4343
%% the cluster (we treat a non-clustered node as a single-node
4444
%% cluster). This is the primary upgrader. The other upgrades need to
4545
%% be done by all nodes.
@@ -306,7 +306,7 @@ node_type_legacy() ->
306306
%% hang), we can't look at the config file (may not include us
307307
%% even if we're a disc node). We also can't use
308308
%% rabbit_mnesia:node_type/0 because that will give false
309-
%% postivies on Rabbit up to 2.5.1.
309+
%% positives on Rabbit up to 2.5.1.
310310
case filelib:is_regular(filename:join(dir(), "rabbit_durable_exchange.DCD")) of
311311
true -> disc;
312312
false -> ram

src/rabbit_variable_queue.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -1732,7 +1732,7 @@ purge_and_index_reset(State) ->
17321732
%%
17331733
%% purge_betas_and_deltas/2 loads messages from the queue index,
17341734
%% filling up q3 and in some cases moving messages form q2 to q3 while
1735-
%% reseting q2 to an empty queue (see maybe_deltas_to_betas/2). The
1735+
%% resetting q2 to an empty queue (see maybe_deltas_to_betas/2). The
17361736
%% messages loaded into q3 are removed by calling
17371737
%% remove_queue_entries/3 until there are no more messages to be read
17381738
%% from the queue index. Messages are read in batches from the queue
@@ -1936,7 +1936,7 @@ maybe_write_msg_to_disk(Force, MsgStatus = #msg_status {
19361936
maybe_write_msg_to_disk(_Force, MsgStatus, State) ->
19371937
{MsgStatus, State}.
19381938

1939-
%% Due to certain optimizations made inside
1939+
%% Due to certain optimisations made inside
19401940
%% rabbit_queue_index:pre_publish/7 we need to have two separate
19411941
%% functions for index persistence. This one is only used when paging
19421942
%% during memory pressure. We didn't want to modify

test/channel_operation_timeout_SUITE.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -86,7 +86,7 @@ notify_down_all(Config) ->
8686
declare(QCfg0),
8787
%% Testing rabbit_amqqueue:notify_down_all via rabbit_channel.
8888
%% Consumer count = 0 after correct channel termination and
89-
%% notification of queues via delagate:call/3
89+
%% notification of queues via delegate:call/3
9090
true = (0 =/= length(get_consumers(Config, Rabbit, ?DEFAULT_VHOST))),
9191
rabbit_ct_client_helpers:close_channel(RabbitCh),
9292
0 = length(get_consumers(Config, Rabbit, ?DEFAULT_VHOST)),

test/clustering_management_SUITE.erl

Lines changed: 6 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -153,9 +153,9 @@ join_and_part_cluster(Config) ->
153153
join_cluster_bad_operations(Config) ->
154154
[Rabbit, Hare, Bunny] = cluster_members(Config),
155155

156-
%% Non-existant node
156+
%% Nonexistent node
157157
ok = stop_app(Rabbit),
158-
assert_failure(fun () -> join_cluster(Rabbit, non@existant) end),
158+
assert_failure(fun () -> join_cluster(Rabbit, non@existent) end),
159159
ok = start_app(Rabbit),
160160
assert_not_clustered(Rabbit),
161161

@@ -217,8 +217,8 @@ forget_cluster_node(Config) ->
217217
ok = stop_app(Rabbit),
218218
%% We're passing the --offline flag, but Hare is online
219219
assert_failure(fun () -> forget_cluster_node(Hare, Rabbit, true) end),
220-
%% Removing some non-existant node will fail
221-
assert_failure(fun () -> forget_cluster_node(Hare, non@existant) end),
220+
%% Removing some nonexistent node will fail
221+
assert_failure(fun () -> forget_cluster_node(Hare, non@existent) end),
222222
ok = forget_cluster_node(Hare, Rabbit),
223223
assert_not_clustered(Hare),
224224
assert_cluster_status({[Rabbit, Hare], [Rabbit, Hare], [Hare]},
@@ -480,8 +480,8 @@ update_cluster_nodes(Config) ->
480480
stop_reset_start(Hare),
481481
assert_failure(fun () -> start_app(Rabbit) end),
482482
%% Bogus node
483-
assert_failure(fun () -> update_cluster_nodes(Rabbit, non@existant) end),
484-
%% Inconsisent node
483+
assert_failure(fun () -> update_cluster_nodes(Rabbit, non@existent) end),
484+
%% Inconsistent node
485485
assert_failure(fun () -> update_cluster_nodes(Rabbit, Hare) end),
486486
ok = update_cluster_nodes(Rabbit, Bunny),
487487
ok = start_app(Rabbit),

test/dynamic_ha_SUITE.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -484,7 +484,7 @@ failing_random_policies(Config) ->
484484
[A, B | _] = Nodes = rabbit_ct_broker_helpers:get_node_configs(Config,
485485
nodename),
486486
%% Those set of policies were found as failing by PropEr in the
487-
%% `random_policy` test above. We add them explicitely here to make
487+
%% `random_policy` test above. We add them explicitly here to make
488488
%% sure they get tested.
489489
?assertEqual(true, test_random_policy(Config, Nodes,
490490
[{nodes, [A, B]}, {nodes, [A]}])),

test/metrics_SUITE.erl

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -144,7 +144,7 @@ connection_metric_idemp(Config, {N, R}) ->
144144
|| _ <- lists:seq(1, N)],
145145
Table = [ Pid || {Pid, _} <- read_table_rpc(Config, connection_metrics)],
146146
Table2 = [ Pid || {Pid, _} <- read_table_rpc(Config, connection_coarse_metrics)],
147-
% referesh stats 'R' times
147+
% refresh stats 'R' times
148148
[[Pid ! emit_stats || Pid <- Table] || _ <- lists:seq(1, R)],
149149
force_metric_gc(Config),
150150
TableAfter = [ Pid || {Pid, _} <- read_table_rpc(Config, connection_metrics)],
@@ -158,7 +158,7 @@ channel_metric_idemp(Config, {N, R}) ->
158158
[amqp_connection:open_channel(Conn) || _ <- lists:seq(1, N)],
159159
Table = [ Pid || {Pid, _} <- read_table_rpc(Config, channel_metrics)],
160160
Table2 = [ Pid || {Pid, _} <- read_table_rpc(Config, channel_process_metrics)],
161-
% referesh stats 'R' times
161+
% refresh stats 'R' times
162162
[[Pid ! emit_stats || Pid <- Table] || _ <- lists:seq(1, R)],
163163
force_metric_gc(Config),
164164
TableAfter = [ Pid || {Pid, _} <- read_table_rpc(Config, channel_metrics)],
@@ -181,7 +181,7 @@ queue_metric_idemp(Config, {N, R}) ->
181181

182182
Table = [ Pid || {Pid, _, _} <- read_table_rpc(Config, queue_metrics)],
183183
Table2 = [ Pid || {Pid, _, _} <- read_table_rpc(Config, queue_coarse_metrics)],
184-
% referesh stats 'R' times
184+
% refresh stats 'R' times
185185
ChanTable = read_table_rpc(Config, channel_created),
186186
[[Pid ! emit_stats || {Pid, _, _} <- ChanTable ] || _ <- lists:seq(1, R)],
187187
force_metric_gc(Config),

0 commit comments

Comments
 (0)