Skip to content

Commit cea04c5

Browse files
Merge branch 'jsoref-spelling'
2 parents b0dfe93 + eacb501 commit cea04c5

Some content is hidden

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

45 files changed

+75
-75
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: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -903,7 +903,7 @@ fun(Conf) ->
903903
end
904904
end}.
905905

906-
%% Classic config-driven peer discuvery backend.
906+
%% Classic config-driven peer discovery backend.
907907
%%
908908
%% Make clustering happen *automatically* at startup - only applied
909909
%% to nodes that have just been reset or started for the first time.
@@ -1530,7 +1530,7 @@ fun(Size) when is_integer(Size) ->
15301530
Size > 0 andalso Size < 536870912
15311531
end}.
15321532

1533-
{validator, "less_than_1", "Flooat is not beetween 0 and 1",
1533+
{validator, "less_than_1", "Float is not between 0 and 1",
15341534
fun(Float) when is_float(Float) ->
15351535
Float > 0 andalso Float < 1
15361536
end}.

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
@@ -219,7 +219,7 @@ fi
219219
# The defaults are meant to reduce RabbitMQ's memory usage and help
220220
# it reclaim memory at the cost of a slight decrease in performance
221221
# (due to an increase in memory operations). These defaults can be
222-
# overriden using the RABBITMQ_SERVER_ERL_ARGS variable.
222+
# overridden using the RABBITMQ_SERVER_ERL_ARGS variable.
223223
RABBITMQ_DEFAULT_ALLOC_ARGS="+MBas ageffcbf +MHas ageffcbf +MBlmbcs 512 +MHlmbcs 512 +MMmcs 30"
224224

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

scripts/rabbitmq-server.bat

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

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

scripts/rabbitmq-service.bat

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

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

src/gm.erl

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

12731273
%% ---------------------------------------------------------------------------
1274-
%% View monitoring and maintanence
1274+
%% View monitoring and maintenance
12751275
%% ---------------------------------------------------------------------------
12761276

12771277
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
@@ -1195,7 +1195,7 @@ prioritise_cast(Msg, _Len, State) ->
11951195
%% will be rate limited by how fast consumers receive messages -
11961196
%% i.e. by notify_sent. We prioritise ack and resume to discourage
11971197
%% starvation caused by prioritising notify_sent. We don't vary their
1198-
%% prioritiy since acks should stay in order (some parts of the queue
1198+
%% priority since acks should stay in order (some parts of the queue
11991199
%% stack are optimised for that) and to make things easier to reason
12001200
%% about. Finally, we prioritise ack over resume since it should
12011201
%% always reduce memory use.

src/rabbit_backing_queue.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -158,7 +158,7 @@
158158

159159
%% Drop messages from the head of the queue while the supplied
160160
%% predicate on message properties returns true. Returns the first
161-
%% message properties for which the predictate returned false, or
161+
%% message properties for which the predicate returned false, or
162162
%% 'undefined' if the whole backing queue was traversed w/o the
163163
%% predicate ever returning false.
164164
-callback dropwhile(msg_pred(), state())

src/rabbit_channel.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -1455,7 +1455,7 @@ handle_method(#'basic.qos'{prefetch_size = Size}, _, _State) when Size /= 0 ->
14551455
handle_method(#'basic.qos'{global = false,
14561456
prefetch_count = PrefetchCount},
14571457
_, State = #ch{limiter = Limiter}) ->
1458-
%% Ensures that if default was set, it's overriden
1458+
%% Ensures that if default was set, it's overridden
14591459
Limiter1 = rabbit_limiter:unlimit_prefetch(Limiter),
14601460
{reply, #'basic.qos_ok'{}, State#ch{consumer_prefetch = PrefetchCount,
14611461
limiter = Limiter1}};

src/rabbit_feature_flags.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -1411,7 +1411,7 @@ does_node_support(Node, FeatureNames, Timeout) ->
14111411
%% If rabbit_feature_flags:is_supported_locally/1 is undefined
14121412
%% on the remote node, we consider it to be a 3.7.x node.
14131413
%%
1414-
%% Theoritically, it could be an older version (3.6.x and
1414+
%% Theoretically, it could be an older version (3.6.x and
14151415
%% older). But the RabbitMQ version consistency check
14161416
%% (rabbit_misc:version_minor_equivalent/2) called from
14171417
%% rabbit_mnesia:check_rabbit_consistency/2 already blocked

src/rabbit_ff_registry.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -148,7 +148,7 @@ is_registry_written_to_disk() ->
148148
always_return_true() ->
149149
%% This function is here to trick Dialyzer. We want some functions
150150
%% in this initial on-disk registry to always return `true` or
151-
%% `false`. However the generated regsitry will return actual
151+
%% `false`. However the generated registry will return actual
152152
%% booleans. The `-spec()` correctly advertises a return type of
153153
%% `boolean()`. But in the meantime, Dialyzer only knows about this
154154
%% copy which, without the trick below, would always return either

src/rabbit_fifo.erl

Lines changed: 6 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -156,7 +156,7 @@
156156
#update_config{}.
157157

158158
-type command() :: protocol() | ra_machine:builtin_command().
159-
%% all the command types suppored by ra fifo
159+
%% all the command types supported by ra fifo
160160

161161
-type client_msg() :: delivery().
162162
%% the messages `rabbit_fifo' can send to consumers.
@@ -323,7 +323,7 @@ apply(Meta,
323323
case Cons0 of
324324
#{ConsumerId := Con0} ->
325325
% need to increment metrics before completing as any snapshot
326-
% states taken need to includ them
326+
% states taken need to include them
327327
complete_and_checkout(Meta, MsgIds, ConsumerId,
328328
Con0, [], State);
329329
_ ->
@@ -693,7 +693,7 @@ get_checked_out(Cid, From, To, #state{consumers = Consumers}) ->
693693
end.
694694

695695
init_aux(Name) when is_atom(Name) ->
696-
%% TODO: catch specific exeption throw if table already exists
696+
%% TODO: catch specific exception throw if table already exists
697697
ok = ra_machine_ets:create_table(rabbit_fifo_usage,
698698
[named_table, set, public,
699699
{write_concurrency, true}]),
@@ -1108,7 +1108,7 @@ increase_credit(#consumer{lifetime = once,
11081108
increase_credit(#consumer{lifetime = auto,
11091109
credit_mode = credited,
11101110
credit = Credit}, _) ->
1111-
%% credit_mode: credit also doens't automatically increment credit
1111+
%% credit_mode: credit also doesn't automatically increment credit
11121112
Credit;
11131113
increase_credit(#consumer{credit = Current}, Credit) ->
11141114
Current + Credit.
@@ -2139,7 +2139,7 @@ enq_check_settle_duplicate_test() ->
21392139
run_snapshot_test(?FUNCTION_NAME, Commands).
21402140

21412141
run_snapshot_test(Name, Commands) ->
2142-
%% create every incremental permuation of the commands lists
2142+
%% create every incremental permutation of the commands lists
21432143
%% and run the snapshot tests against that
21442144
[begin
21452145
run_snapshot_test0(Name, C)
@@ -2208,7 +2208,7 @@ state_enter_test() ->
22082208
[{mod_call, m, f, [a, the_name]}] = state_enter(leader, S0),
22092209
ok.
22102210

2211-
state_enter_montors_and_notifications_test() ->
2211+
state_enter_monitors_and_notifications_test() ->
22122212
Oth = spawn(fun () -> ok end),
22132213
{State0, _} = enq(1, 1, first, test_init(test)),
22142214
Cid = {<<"adf">>, self()},

src/rabbit_fifo_client.erl

Lines changed: 4 additions & 4 deletions
Original file line numberDiff line numberDiff line change
@@ -165,7 +165,7 @@ enqueue(Msg, State) ->
165165

166166
%% @doc Dequeue a message from the queue.
167167
%%
168-
%% This is a syncronous call. I.e. the call will block until the command
168+
%% This is a synchronous call. I.e. the call will block until the command
169169
%% has been accepted by the ra process or it times out.
170170
%%
171171
%% @param ConsumerTag a unique tag to identify this particular consumer.
@@ -297,7 +297,7 @@ discard(ConsumerTag, [_|_] = MsgIds,
297297
%% @doc Register with the rabbit_fifo queue to "checkout" messages as they
298298
%% become available.
299299
%%
300-
%% This is a syncronous call. I.e. the call will block until the command
300+
%% This is a synchronous call. I.e. the call will block until the command
301301
%% has been accepted by the ra process or it times out.
302302
%%
303303
%% @param ConsumerTag a unique tag to identify this particular consumer.
@@ -316,7 +316,7 @@ checkout(ConsumerTag, NumUnsettled, ConsumerInfo, State0) ->
316316
%% @doc Register with the rabbit_fifo queue to "checkout" messages as they
317317
%% become available.
318318
%%
319-
%% This is a syncronous call. I.e. the call will block until the command
319+
%% This is a synchronous call. I.e. the call will block until the command
320320
%% has been accepted by the ra process or it times out.
321321
%%
322322
%% @param ConsumerTag a unique tag to identify this particular consumer.
@@ -374,7 +374,7 @@ credit(ConsumerTag, Credit, Drain,
374374

375375
%% @doc Cancels a checkout with the rabbit_fifo queue for the consumer tag
376376
%%
377-
%% This is a syncronous call. I.e. the call will block until the command
377+
%% This is a synchronous call. I.e. the call will block until the command
378378
%% has been accepted by the ra process or it times out.
379379
%%
380380
%% @param ConsumerTag a unique tag to identify this particular consumer.

src/rabbit_fifo_index.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -87,7 +87,7 @@ find_next(Next, Last, Map) ->
8787
_ ->
8888
% in degenerate cases the range here could be very large
8989
% and hence this could be very slow
90-
% the typical case should idealy be better
90+
% the typical case should ideally be better
9191
% assuming fifo-ish deletion of entries
9292
find_next(Next+1, Last, Map)
9393
end.

src/rabbit_guid.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -92,7 +92,7 @@ advance_blocks({B1, B2, B3, B4}, I) ->
9292
%% hashing {B5, I}. The new hash is used as last block, and the
9393
%% other three blocks are XORed with it.
9494
%%
95-
%% Doing this is convenient because it avoids cascading conflits,
95+
%% Doing this is convenient because it avoids cascading conflicts,
9696
%% while being very fast. The conflicts are avoided by propagating
9797
%% the changes through all the blocks at each round by XORing, so
9898
%% 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
@@ -364,7 +364,7 @@ handle_cast({gm_deaths, DeadGMPids}, State = #state{q = Q}) when ?amqqueue_pid_r
364364
%% Different slave is now master, stop current coordinator normally.
365365
%% Initiating queue is now slave and the least we could do is report
366366
%% deaths which we 'think' we saw.
367-
%% NOTE: Reported deaths here, could be inconsistant.
367+
%% NOTE: Reported deaths here, could be inconsistent.
368368
rabbit_mirror_queue_misc:report_deaths(MPid, false, QueueName,
369369
DeadPids),
370370
{stop, shutdown, State};

src/rabbit_mirror_queue_misc.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -615,7 +615,7 @@ validate_sync_batch_size(none) ->
615615
validate_sync_batch_size(N) when is_integer(N) andalso N > 0 ->
616616
ok;
617617
validate_sync_batch_size(N) ->
618-
{error, "ha-sync-batch-size takes an integer greather than 0, "
618+
{error, "ha-sync-batch-size takes an integer greater than 0, "
619619
"~p given", [N]}.
620620

621621
validate_pos(PromoteOnShutdown) ->

src/rabbit_msg_store.erl

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -236,7 +236,7 @@
236236
%% updated.
237237
%%
238238
%% On non-clean startup, we scan the files we discover, dealing with
239-
%% the possibilites of a crash having occurred during a compaction
239+
%% the possibilities of a crash having occurred during a compaction
240240
%% (this consists of tidyup - the compaction is deliberately designed
241241
%% such that data is duplicated on disk rather than risking it being
242242
%% lost), and rebuild the file summary and index ETS table.
@@ -596,7 +596,7 @@ client_read2(false, undefined, _MsgLocation, Defer, _CState) ->
596596
Defer();
597597
client_read2(true, _Right, _MsgLocation, Defer, _CState) ->
598598
%% Of course, in the mean time, the GC could have run and our msg
599-
%% is actually in a different file, unlocked. However, defering is
599+
%% is actually in a different file, unlocked. However, deferring is
600600
%% the safest and simplest thing to do.
601601
Defer();
602602
client_read2(false, _Right,

src/rabbit_node_monitor.erl

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -219,7 +219,7 @@ subscribe(Pid) ->
219219
%% We could confirm something by having an HA queue see the pausing
220220
%% state (and fail over into it) before the node monitor stops us, or
221221
%% by using unmirrored queues and just having them vanish (and
222-
%% confiming messages as thrown away).
222+
%% confirming messages as thrown away).
223223
%%
224224
%% So we have channels call in here before issuing confirms, to do a
225225
%% 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
@@ -22,7 +22,7 @@
2222

2323
-behaviour(rabbit_backing_queue).
2424

25-
%% enabled unconditionally. Disabling priority queueing after
25+
%% enabled unconditionally. Disabling priority queuing after
2626
%% it has been enabled is dangerous.
2727
-rabbit_boot_step({?MODULE,
2828
[{description, "enable priority queue"},
@@ -55,7 +55,7 @@
5555
-define(passthrough3(F),
5656
{Res1, Res2, BQS1} = BQ:F, {Res1, Res2, State#passthrough{bqs = BQS1}}).
5757

58-
%% This module adds suport for priority queues.
58+
%% This module adds support for priority queues.
5959
%%
6060
%% Priority queues have one backing queue per priority. Backing queue functions
6161
%% 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
@@ -355,7 +355,7 @@ pre_publish(MsgOrId, SeqId, MsgProps, IsPersistent, IsDelivered, JournalSizeHint
355355
State1#qistate{pre_publish_cache = PPC1,
356356
delivered_cache = DC1})).
357357

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

0 commit comments

Comments
 (0)