diff --git a/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs b/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs
index 091c1f6474..97c1e3fd62 100644
--- a/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs
+++ b/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs
@@ -183,7 +183,7 @@ public sealed class ConnectionFactory : ConnectionFactoryBase, IAsyncConnectionF
///
/// For concurrency greater than one this removes the guarantee that consumers handle messages in the order they receive them.
/// In addition to that consumers need to be thread/concurrency safe.
- public int ProcessingConcurrency { get; set; } = 1;
+ public int ConsumerDispatchConcurrency { get; set; } = 1;
/// The host to connect to.
public string HostName { get; set; } = "localhost";
diff --git a/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs b/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs
index e3205a7d04..1b94ebef39 100644
--- a/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs
+++ b/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs
@@ -189,6 +189,6 @@ public interface IConnectionFactory
///
/// For concurrency greater than one this removes the guarantee that consumers handle messages in the order they receive them.
/// In addition to that consumers need to be thread/concurrency safe.
- int ProcessingConcurrency { get; set; }
+ int ConsumerDispatchConcurrency { get; set; }
}
}
diff --git a/projects/RabbitMQ.Client/client/impl/Connection.cs b/projects/RabbitMQ.Client/client/impl/Connection.cs
index 6639ccd7c4..8b54902f57 100644
--- a/projects/RabbitMQ.Client/client/impl/Connection.cs
+++ b/projects/RabbitMQ.Client/client/impl/Connection.cs
@@ -112,11 +112,11 @@ public Connection(IConnectionFactory factory, bool insist, IFrameHandler frameHa
if (factory is IAsyncConnectionFactory asyncConnectionFactory && asyncConnectionFactory.DispatchConsumersAsync)
{
- ConsumerWorkService = new AsyncConsumerWorkService(factory.ProcessingConcurrency);
+ ConsumerWorkService = new AsyncConsumerWorkService(factory.ConsumerDispatchConcurrency);
}
else
{
- ConsumerWorkService = new ConsumerWorkService(factory.ProcessingConcurrency);
+ ConsumerWorkService = new ConsumerWorkService(factory.ConsumerDispatchConcurrency);
}
_sessionManager = new SessionManager(this, 0);
diff --git a/projects/Unit/APIApproval.Approve.verified.txt b/projects/Unit/APIApproval.Approve.verified.txt
index 787b408905..6c2d56cfb4 100644
--- a/projects/Unit/APIApproval.Approve.verified.txt
+++ b/projects/Unit/APIApproval.Approve.verified.txt
@@ -83,6 +83,7 @@ namespace RabbitMQ.Client
public bool AutomaticRecoveryEnabled { get; set; }
public System.Collections.Generic.IDictionary ClientProperties { get; set; }
public string ClientProvidedName { get; set; }
+ public int ConsumerDispatchConcurrency { get; set; }
public System.TimeSpan ContinuationTimeout { get; set; }
public bool DispatchConsumersAsync { get; set; }
public RabbitMQ.Client.AmqpTcpEndpoint Endpoint { get; set; }
@@ -92,7 +93,6 @@ namespace RabbitMQ.Client
public System.TimeSpan NetworkRecoveryInterval { get; set; }
public string Password { get; set; }
public int Port { get; set; }
- public int ProcessingConcurrency { get; set; }
public ushort RequestedChannelMax { get; set; }
public System.TimeSpan RequestedConnectionTimeout { get; set; }
public uint RequestedFrameMax { get; set; }
@@ -334,10 +334,10 @@ namespace RabbitMQ.Client
{
System.Collections.Generic.IDictionary ClientProperties { get; set; }
string ClientProvidedName { get; set; }
+ int ConsumerDispatchConcurrency { get; set; }
System.TimeSpan ContinuationTimeout { get; set; }
System.TimeSpan HandshakeContinuationTimeout { get; set; }
string Password { get; set; }
- int ProcessingConcurrency { get; set; }
ushort RequestedChannelMax { get; set; }
uint RequestedFrameMax { get; set; }
System.TimeSpan RequestedHeartbeat { get; set; }
diff --git a/projects/Unit/TestAsyncConsumer.cs b/projects/Unit/TestAsyncConsumer.cs
index 74009754aa..9cc518d88f 100644
--- a/projects/Unit/TestAsyncConsumer.cs
+++ b/projects/Unit/TestAsyncConsumer.cs
@@ -85,7 +85,7 @@ public void TestBasicRoundtrip()
[Test]
public async Task TestBasicRoundtripConcurrent()
{
- var cf = new ConnectionFactory{ DispatchConsumersAsync = true, ProcessingConcurrency = 2 };
+ var cf = new ConnectionFactory{ DispatchConsumersAsync = true, ConsumerDispatchConcurrency = 2 };
using(IConnection c = cf.CreateConnection())
using(IModel m = c.CreateModel())
{
diff --git a/projects/Unit/TestConsumer.cs b/projects/Unit/TestConsumer.cs
index bba55c575e..2ee15263de 100644
--- a/projects/Unit/TestConsumer.cs
+++ b/projects/Unit/TestConsumer.cs
@@ -13,7 +13,7 @@ public class TestConsumer
[Test]
public async Task TestBasicRoundtripConcurrent()
{
- var cf = new ConnectionFactory{ ProcessingConcurrency = 2 };
+ var cf = new ConnectionFactory{ ConsumerDispatchConcurrency = 2 };
using(IConnection c = cf.CreateConnection())
using(IModel m = c.CreateModel())
{