diff --git a/deps/rabbit/docs/rabbitmq.conf.example b/deps/rabbit/docs/rabbitmq.conf.example index e293743f6bae..4f69d18b3cbc 100644 --- a/deps/rabbit/docs/rabbitmq.conf.example +++ b/deps/rabbit/docs/rabbitmq.conf.example @@ -12,8 +12,8 @@ ## ## See https://www.rabbitmq.com/docs/documentation for the rest of RabbitMQ documentation. ## -## In case you have questions, please use RabbitMQ community Slack and the rabbitmq-users Google group -## instead of GitHub issues. +## In case you have questions, please use rabbitmq/rabbitmq-server Discussions and the RabbitMQ community Discord server +## for questions. # ====================================== # Core broker section @@ -374,6 +374,22 @@ # tcp_listen_options.sndbuf = 196608 # tcp_listen_options.recbuf = 196608 +## +## Queues +## + +## If set, the 'x-queue-type' header will be ignored (not compared for equivalence) +## for queue redeclaration. This can simplify upgrades of applications that explicitly +## set 'x-queue-type' to 'classic' for historical reasons but do not set any other +## properties that may conflict or significantly change queue behavior and semantics, such as the 'exclusive' field. +# quorum_queue.property_equivalence.relaxed_checks_on_redeclaration = true + +## Changes classic queue storage implementation version. +## In 4.0.x, version 2 is the default and this is a forward compatibility setting, +## that is, it will be useful when a new version is developed. +## +# classic_queue.default_version = 2 + ## ## Resource Limits & Flow Control ## ============================== diff --git a/deps/rabbit/src/rabbit.erl b/deps/rabbit/src/rabbit.erl index 67d49c188741..87580bc2e387 100644 --- a/deps/rabbit/src/rabbit.erl +++ b/deps/rabbit/src/rabbit.erl @@ -1751,10 +1751,26 @@ persist_static_configuration() -> [classic_queue_index_v2_segment_entry_count, classic_queue_store_v2_max_cache_size, classic_queue_store_v2_check_crc32, - incoming_message_interceptors, - credit_flow_default_credit + incoming_message_interceptors ]), + %% Disallow the following two cases: + %% 1. Negative values + %% 2. MoreCreditAfter greater than InitialCredit + CreditFlowDefaultCredit = case application:get_env(?MODULE, credit_flow_default_credit) of + {ok, {InitialCredit, MoreCreditAfter}} + when is_integer(InitialCredit) andalso + is_integer(MoreCreditAfter) andalso + InitialCredit > 0 andalso + MoreCreditAfter > 0 andalso + MoreCreditAfter < InitialCredit -> + {InitialCredit, MoreCreditAfter}; + Other -> + rabbit_log:error("Refusing to boot due to an invalid value of 'rabbit.credit_flow_default_credit'"), + throw({error, {invalid_credit_flow_default_credit_value, Other}}) + end, + ok = persistent_term:put(credit_flow_default_credit, CreditFlowDefaultCredit), + %% Disallow 0 as it means unlimited: %% "If this field is zero or unset, there is no maximum %% size imposed by the link endpoint." [AMQP 1.0 ยง2.7.3] diff --git a/deps/rabbitmq_cli/lib/rabbitmq/cli/diagnostics/commands/check_certificate_expiration_command.ex b/deps/rabbitmq_cli/lib/rabbitmq/cli/diagnostics/commands/check_certificate_expiration_command.ex index 0b70ef4ccf58..a47ff0bd776f 100644 --- a/deps/rabbitmq_cli/lib/rabbitmq/cli/diagnostics/commands/check_certificate_expiration_command.ex +++ b/deps/rabbitmq_cli/lib/rabbitmq/cli/diagnostics/commands/check_certificate_expiration_command.ex @@ -7,10 +7,11 @@ defmodule RabbitMQ.CLI.Diagnostics.Commands.CheckCertificateExpirationCommand do alias RabbitMQ.CLI.Core.DocGuide alias RabbitMQ.CLI.TimeUnit, as: TU - @behaviour RabbitMQ.CLI.CommandBehaviour import RabbitMQ.CLI.Core.Listeners + @behaviour RabbitMQ.CLI.CommandBehaviour + def switches(), do: [unit: :string, within: :integer] def merge_defaults(args, opts) do @@ -102,9 +103,10 @@ defmodule RabbitMQ.CLI.Diagnostics.Commands.CheckCertificateExpirationCommand do def help_section(), do: :observability_and_health_checks - def description(), - do: "Checks the expiration date on the certificates for every listener configured to use TLS" + def description() do + "Checks the expiration date of every certificate (leaf, intermediary or any CA) in every certificate bundle file used by the node" + end def banner(_, %{node: node_name}), - do: "Checking certificate expiration on node #{node_name} ..." + do: "Checking certificate expiration for all certificates on node #{node_name} ..." end diff --git a/deps/rabbitmq_management/priv/www/api/index.html b/deps/rabbitmq_management/priv/www/api/index.html index d7e4a4a5214d..c27ebe4dc8aa 100644 --- a/deps/rabbitmq_management/priv/www/api/index.html +++ b/deps/rabbitmq_management/priv/www/api/index.html @@ -226,7 +226,7 @@

Reference

/api/nodes/name/memory - Returns a memory usage breakdown of an individual node in the RabbitMQ cluster. + Returns a memory usage breakdown of an individual node in the RabbitMQ cluster. @@ -246,36 +246,42 @@

Reference

/api/all-configuration (deprecated) - The server definitions - exchanges, queues, bindings, users, - virtual hosts, permissions, topic permissions, and parameters. Everything apart from - messages. POST to upload an existing set of definitions. Note - that: - - For convenience you may upload a file from a browser to this - URI (i.e. you can use multipart/form-data as - well as application/json) in which case the - definitions should be uploaded as a form field named - "file". +

+ The server definitions: exchanges, queues, bindings, users, + virtual hosts, permissions, topic permissions, and parameters. Everything apart from + messages. POST to upload an existing set of definitions. Note + that: + +

+

+

+ This endpoint supports multipart/form-data as + well as the standard application/json content types for uploads. + In the former case, the definitions file should be uploaded as a form field named "file". +

+

+ Relevant documentation guide: Definition Export and Import +

@@ -286,35 +292,41 @@

Reference

/api/definitions/vhost
- The server definitions for a given virtual host - - exchanges, queues, bindings and policies. - POST to upload an existing set of definitions. Note that: - - For convenience you may upload a file from a browser to this - URI (i.e. you can use multipart/form-data as - well as application/json) in which case the - definitions should be uploaded as a form field named - "file". +

+ The server definitions for a given virtual host: + exchanges, queues, bindings and policies. + POST to upload an existing set of definitions. Note that: + +

+

+

+ This endpoint supports multipart/form-data as + well as the standard application/json content types for uploads. + In the former case, the definitions file should be uploaded as a form field named "file". +

+

+ Relevant documentation guide: Definition Export and Import +

@@ -323,7 +335,16 @@

Reference

/api/connections - A list of all open connections. Use pagination parameters to filter connections. + +

+ A list of all open connections. +

+

+ Use pagination parameters to list connections, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -331,7 +352,16 @@

Reference

/api/vhosts/vhost/connections - A list of all open connections in a specific virtual host. Use pagination parameters to filter connections. + +

+ A list of all open connections in a specific virtual host. +

+

+ Use pagination parameters to list connections, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -352,7 +382,7 @@

Reference

/api/connections/username/username - A list of all open connections for a specific username. Use pagination parameters to filter connections. + A list of all open connections for a specific username. Use pagination parameters to list connections. DELETEing a resource will close all the connections for a username. Optionally set the "X-Reason" header when DELETEing to provide a reason. @@ -364,7 +394,14 @@

Reference

/api/connections/name/channels - List of all channels for a given connection. +

+ List of all channels for a given connection. +

+

+ Use pagination parameters to list channels, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

@@ -373,7 +410,16 @@

Reference

/api/channels - A list of all open channels. Use pagination parameters to filter channels. + +

+ A list of all open channels. +

+

+ Use pagination parameters to list channels, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -381,7 +427,16 @@

Reference

/api/vhosts/vhost/channels - A list of all open channels in a specific virtual host. Use pagination parameters to filter channels. + +

+ A list of all open channels in a specific virtual host. +

+

+ Use pagination parameters to list channels, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -397,7 +452,16 @@

Reference

/api/consumers - A list of all consumers. + +

+ A list of all consumers. +

+

+ Use pagination parameters to list consumers, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -413,7 +477,7 @@

Reference

/api/exchanges - A list of all exchanges. Use pagination parameters to filter exchanges. + A list of all exchanges. Use pagination parameters to list exchanges. X @@ -421,7 +485,7 @@

Reference

/api/exchanges/vhost - A list of all exchanges in a given virtual host. Use pagination parameters to filter exchanges. + A list of all exchanges in a given virtual host. Use pagination parameters to list exchanges. X @@ -492,11 +556,21 @@

Reference

/api/queues - A list of all queues returning a reduced set of fields. Use pagination parameters to filter queues. - The parameter enable_queue_totals=true can be used in combination with the - disable_stats=true parameter to return a reduced set of fields and significantly - reduce the amount of data returned by this endpoint. That in turn can significantly reduce - CPU and bandwidth footprint of such requests. + +

+ A list of all queues across all virtual hosts returning a reduced set of fields. +

+

+ Use pagination parameters to list queues, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+

+ The parameter enable_queue_totals=true can be used in combination with the + disable_stats=true parameter to return a reduced set of fields and significantly + reduce the amount of data returned by this endpoint. That in turn can significantly reduce + CPU and bandwidth footprint of such requests. +

@@ -505,7 +579,15 @@

Reference

/api/queues/detailed - A list of all queues containing all available information about the queues. Use pagination parameters to filter queues. + +

+ A list of all queues containing all available information about the queues (over 50 fields per queue). +

+

+ Use pagination parameters to list queues, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

@@ -514,7 +596,16 @@

Reference

/api/queues/vhost - A list of all queues in a given virtual host. Use pagination parameters to filter queues. + +

+ A list of all queues in the given virtual host containing all available information about the queues (over 50 fields per queue).. +

+

+ Use pagination parameters to list queues, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -524,7 +615,7 @@

Reference

/api/queues/vhost/name An individual queue. To PUT a queue, you will need a body looking something like this: -
{"auto_delete":false,"durable":true,"arguments":{},"node":"rabbit@smacmullen"}
+
{"auto_delete":false,"durable":true,"arguments":{},"node":"rabbit@node.hostname"}
All keys are optional.

When DELETEing a queue you can add the query string @@ -602,7 +693,16 @@

Reference

/api/bindings - A list of all bindings. + +

+ A list of all bindings. +

+

+ Use pagination parameters to list bindings, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -610,7 +710,16 @@

Reference

/api/bindings/vhost - A list of all bindings in a given virtual host. + +

+ A list of all bindings in a given virtual host. +

+

+ Use pagination parameters to list bindings, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+ X @@ -690,7 +799,14 @@

Reference

/api/vhosts - A list of all vhosts. + +

+ A list of all vhosts. +

+

+ Pagination: default page size is 100, maximum supported page size is 500. +

+ X @@ -990,19 +1106,6 @@

Reference

pattern and definition are mandatory, priority and apply-to are optional. - - X - - - - /api/aliveness-test/vhost - - Declares a test queue on the target node, then publishes and consumes a - message. Intended to be used as a very basic health check. - Responds a 200 OK if the check succeeded, - otherwise responds with a 503 Service Unavailable. - - X @@ -1010,8 +1113,14 @@

Reference

/api/health/checks/alarms - Responds a 200 OK if there are no alarms in effect in the cluster, - otherwise responds with a 503 Service Unavailable. +

+ Responds a 200 OK if there are no alarms in effect in the cluster, + otherwise responds with a 503 Service Unavailable. +

+ +

+ Relevant documentation guide: Resource Alarms +

@@ -1021,8 +1130,13 @@

Reference

/api/health/checks/local-alarms - Responds a 200 OK if there are no local alarms in effect on the target node, - otherwise responds with a 503 Service Unavailable. +

+ Responds a 200 OK if there are no local alarms in effect on the target node, + otherwise responds with a 503 Service Unavailable. +

+

+ Relevant documentation guide: Resource Alarms +

@@ -1033,15 +1147,32 @@

Reference

/api/health/checks/certificate-expiration/within/unit

- Checks the expiration date on the certificates for every listener configured to use TLS. + Checks the expiration date of every certificate found in the PEM certificate bundles used by + all TLS-enabled listeners on the node, regardless of the "type" of the certificate (leaf/server identity, + intermediary or any CA). +

+

Responds a 200 OK if all certificates are valid (have not expired), otherwise responds with a 503 Service Unavailable.

+

+ This health assumes that + +

+ + Do not use this health check if some of these assumptions are not true. +

Valid units: days, weeks, months, years. The value of the within argument is the number of units. So, when within is 2 and unit is "months", the expiration period used by the check will be the next two months.

+

+ Relevant documentation guides: TLS, Encrypted Inter-node Communication +

@@ -1051,7 +1182,7 @@

Reference

/api/health/checks/port-listener/port - Responds a 200 OK if there is an active listener on the give port, + Responds a 200 OK if there is an active listener on the given port, otherwise responds with a 503 Service Unavailable. @@ -1084,10 +1215,15 @@

Reference

/api/health/checks/node-is-quorum-critical - Checks if there are quorum queues with minimum online quorum (queues that - would lose their quorum and availability if the target node is shut down). - Responds a 200 OK if there are no such quorum queues, - otherwise responds with a 503 Service Unavailable. +

+ Checks if there are quorum queues with minimum online quorum (queues that + would lose their quorum and availability if the target node is shut down). + Responds a 200 OK if there are no such quorum queues, + otherwise responds with a 503 Service Unavailable. +

+

+ Relevant documentation guide: Quorum Queues +

@@ -1117,11 +1253,15 @@

Reference

/api/vhost-limits/vhost/name - Set or delete per-vhost limit for vhost. The name URL path element - refers to the name of the limit (max-connections, max-queues). - Limits are set using a JSON document in the body:
{"value": 100}
. Example - request:
-
curl -4u 'guest:guest' -H 'content-type:application/json' -X PUT localhost:15672/api/vhost-limits/my-vhost/max-connections -d '{"value": 50}'
+

+ Set or delete per-vhost limit for vhost. The name URL path element + refers to the name of the limit (max-connections, max-queues). + Limits are set using a JSON document in the body:

{"value": 100}
. Example request:
+
curl -4u 'guest:guest' -H 'content-type:application/json' -X PUT localhost:15672/api/vhost-limits/my-vhost/max-connections -d '{"value": 50}'
+

+

+ Relevant documentation guide: Virtual Hosts +

@@ -1142,7 +1282,7 @@

Reference

X /api/rebalance/queues - Rebalances all queues in all vhosts. This operation is asynchronous therefore please check + Rebalances all queues in all vhosts. This operation is asynchronous therefore please check the RabbitMQ log file for messages regarding the success or failure of the operation.
curl -4u 'guest:guest' -XPOST localhost:15672/api/rebalance/queues/
@@ -1195,10 +1335,17 @@

Reference

/api/stream/connections - A list of all open stream connections. - Use pagination parameters to filter connections. -
- Requires the rabbitmq_stream_management plugin to be enabled. +

+ A list of all open stream connections. +

+

+ Use pagination parameters to list connections, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+

+ Requires the rabbitmq_stream_management plugin to be enabled. +

@@ -1208,9 +1355,17 @@

Reference

/api/stream/connections/vhost +

A list of all open stream connections in a specific virtual host. -
+

+

+ Use pagination parameters to list connections, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+

Requires the rabbitmq_stream_management plugin to be enabled. +

@@ -1246,9 +1401,17 @@

Reference

/api/stream/connections/vhost/name/consumers +

The list of consumers of a given stream connection. -
+

+

+ Use pagination parameters to list consumers, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+

Requires the rabbitmq_stream_management plugin to be enabled. +

@@ -1294,9 +1457,17 @@

Reference

/api/stream/consumers +

The list of stream consumers. -
+

+

+ Use pagination parameters to list consumers, + otherwise this endpoint can produce very large JSON responses and waste a lot of bandwidth and CPU resources. + Default page size is 100, maximum supported page size is 500. +

+

Requires the rabbitmq_stream_management plugin to be enabled. +

@@ -1306,9 +1477,10 @@

Reference

/api/stream/consumers/vhost - The list of stream consumers in a specific virtual host. -
+

The list of stream consumers in a specific virtual host.

+

Requires the rabbitmq_stream_management plugin to be enabled. +

@@ -1318,7 +1490,12 @@

Reference

/api/feature-flags - The list of feature flags. +

+ The list of feature flags. +

+

+ Relevant documentation guide: Feature Flags +

@@ -1328,7 +1505,12 @@

Reference

/api/deprecated-features +

The list of deprecated features. +

+

+ Relevant documentation guide: Deprecated Features +

@@ -1338,7 +1520,12 @@

Reference

/api/deprecated-features/used +

The list of deprecated features currently being used. +

+

+ Relevant documentation guide: Deprecated Features +

@@ -1819,94 +2006,6 @@

/api/nodes

Exchange types available on the node. - - fd_total - - File descriptors available. - - - - fd_used - - Used file descriptors. - - - - io_read_avg_time - - Average wall time (milliseconds) for each disk read operation in - the last statistics interval. - - - - io_read_bytes - - Total number of bytes read from disk by the persister. - - - - io_read_count - - Total number of read operations by the persister. - - - - io_reopen_count - - Total number of times the persister has needed to recycle - file handles between queues. In an ideal world this number - will be zero; if the number is large, performance might be - improved by increasing the number of file handles available - to RabbitMQ. - - - - io_seek_avg_time - - Average wall time (milliseconds) for each seek operation in - the last statistics interval. - - - - - io_seek_count - - Total number of seek operations by the persister. - - - - io_sync_avg_time - - Average wall time (milliseconds) for each fsync() operation in - the last statistics interval. - - - - - io_sync_count - - Total number of fsync() operations by the persister. - - - - io_write_avg_time - - Average wall time (milliseconds) for each disk write operation in - the last statistics interval. - - - - io_write_bytes - - Total number of bytes written to disk by the persister. - - - - io_write_count - - Total number of write operations by the persister. - - log_files @@ -1933,36 +2032,6 @@

/api/nodes

Point at which the memory alarm will go off. - - mnesia_disk_tx_count - - Number of Mnesia transactions which have been performed that - required writes to disk. (e.g. creating a durable - queue). Only transactions which originated on this node are - included. - - - - mnesia_ram_tx_count - - Number of Mnesia transactions which have been performed that - did not require writes to disk. (e.g. creating a transient - queue). Only transactions which originated on this node are - included. - - - - msg_store_read_count - - Number of messages which have been read from the message store. - - - - msg_store_write_count - - Number of messages which have been written to the message store. - - name @@ -2000,27 +2069,6 @@

/api/nodes

Number of Erlang processes in use. - - queue_index_journal_write_count - - Number of records written to the queue index journal. Each - record represents a message being published to a queue, - being delivered from a queue, and being acknowledged in a - queue. - - - - queue_index_read_count - - Number of records read from the queue index. - - - - queue_index_write_count - - Number of records written to the queue index. - - rates_mode @@ -2040,12 +2088,6 @@

/api/nodes

false, most other stats will be missing. - - sasl_log_file - - Location of sasl log file. - - type @@ -2356,23 +2398,23 @@

/api/vhosts/(name)

Pagination Parameters

- The pagination can be applied to the endpoints that list - - +

+ The pagination can be applied to the endpoints that list + +

+

+

+ Without pagination, these endpoints can produce very large JSON responses and waste a lot of bandwidth and CPU resources. +

+

+ Default page size is 100, maximum supported page size is 500. +

Below are the query parameters that can be used. @@ -2393,14 +2435,14 @@

Pagination Parameters

page_size Positive integer - Number of elements for page (default value: 100) + Number of elements for page (default value: 100, maximum supported value: 500) name String - Filter by name, for example queue name, exchange name etc.. + Filter by name, for example queue name, exchange name etc. diff --git a/deps/rabbitmq_management/src/rabbit_mgmt_wm_aliveness_test.erl b/deps/rabbitmq_management/src/rabbit_mgmt_wm_aliveness_test.erl index 92074a1f11e1..c1a59696a0e5 100644 --- a/deps/rabbitmq_management/src/rabbit_mgmt_wm_aliveness_test.erl +++ b/deps/rabbitmq_management/src/rabbit_mgmt_wm_aliveness_test.erl @@ -35,37 +35,15 @@ resource_exists(ReqData, Context) -> end, ReqData, Context}. to_json(ReqData, Context) -> + %% This health check is deprecated and is now a no-op. + %% More specific health checks under GET /api/health/checks/* should be used instead. + %% https://www.rabbitmq.com/docs/monitoring#health-checks rabbit_mgmt_util:with_channel( rabbit_mgmt_util:vhost(ReqData), ReqData, Context, - fun(Ch) -> - #'queue.declare_ok'{queue = ?QUEUE} = amqp_channel:call(Ch, #'queue.declare'{ - queue = ?QUEUE - }), - ok = amqp_channel:call(Ch, #'basic.publish'{routing_key = ?QUEUE}, #amqp_msg{ - payload = <<"test_message">> - }), - case amqp_channel:call(Ch, #'basic.get'{queue = ?QUEUE, no_ack = true}) of - {#'basic.get_ok'{}, _} -> - %% Don't delete the queue. If this is pinged every few - %% seconds we don't want to create a mnesia transaction - %% each time. - rabbit_mgmt_util:reply([{status, ok}], ReqData, Context); - #'basic.get_empty'{} -> - Reason = <<"aliveness-test queue is empty">>, - failure(Reason, ReqData, Context); - Error -> - Reason = rabbit_data_coercion:to_binary(Error), - failure(Reason, ReqData, Context) - end - end + fun(_Ch) -> rabbit_mgmt_util:reply([{status, ok}], ReqData, Context) end ). -failure(Reason, ReqData0, Context0) -> - Body = #{status => failed, reason => Reason}, - {Response, ReqData1, Context1} = rabbit_mgmt_util:reply(Body, ReqData0, Context0), - {stop, cowboy_req:reply(?HEALTH_CHECK_FAILURE_STATUS, #{}, Response, ReqData1), Context1}. - is_authorized(ReqData, Context) -> rabbit_mgmt_util:is_authorized_vhost(ReqData, Context). diff --git a/deps/rabbitmq_mqtt/test/java_SUITE_data/pom.xml b/deps/rabbitmq_mqtt/test/java_SUITE_data/pom.xml index 5a9a21337be4..479aed20769d 100644 --- a/deps/rabbitmq_mqtt/test/java_SUITE_data/pom.xml +++ b/deps/rabbitmq_mqtt/test/java_SUITE_data/pom.xml @@ -17,13 +17,13 @@ [1.2.5,) 5.24.0 5.11.4 - 3.27.1 + 3.27.2 1.2.13 3.5.2 2.1.1 2.4.21 3.12.1 - 2.43.0 + 2.44.1 1.17.0 ${project.build.directory}/ca.keystore bunnychow diff --git a/deps/rabbitmq_stream/test/rabbit_stream_SUITE_data/pom.xml b/deps/rabbitmq_stream/test/rabbit_stream_SUITE_data/pom.xml index 3c95c630ac0f..0c1dd1737784 100644 --- a/deps/rabbitmq_stream/test/rabbit_stream_SUITE_data/pom.xml +++ b/deps/rabbitmq_stream/test/rabbit_stream_SUITE_data/pom.xml @@ -28,11 +28,11 @@ [0.12.0-SNAPSHOT,) 5.11.4 - 3.27.1 + 3.27.2 1.2.13 3.12.1 3.5.2 - 2.43.0 + 2.44.1 1.17.0 UTF-8 diff --git a/deps/rabbitmq_stream_management/test/http_SUITE_data/pom.xml b/deps/rabbitmq_stream_management/test/http_SUITE_data/pom.xml index 4e964f6365c9..f456f6024920 100644 --- a/deps/rabbitmq_stream_management/test/http_SUITE_data/pom.xml +++ b/deps/rabbitmq_stream_management/test/http_SUITE_data/pom.xml @@ -28,11 +28,11 @@ [0.12.0-SNAPSHOT,) 5.11.4 - 3.27.1 + 3.27.2 1.2.13 3.12.1 3.5.2 - 2.43.0 + 2.44.1 1.18.1 4.12.0 2.11.0 diff --git a/deps/rabbitmq_web_mqtt_examples/README.md b/deps/rabbitmq_web_mqtt_examples/README.md index 4fde10815e7f..7b435f726062 100644 --- a/deps/rabbitmq_web_mqtt_examples/README.md +++ b/deps/rabbitmq_web_mqtt_examples/README.md @@ -5,8 +5,6 @@ usage. It starts a server that binds to port 15670 and serves a few static HTML files on port 15670 (e.g. [http://127.0.0.1:15670](http://127.0.0.1:15670/)). -Note that Web STOMP examples use the same port, so these plugins cannot be enabled -at the same time unless they are configured to use different ports. ## Installation