diff --git a/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs b/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs
index 2f2ec7505..3bfb30a46 100644
--- a/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs
+++ b/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs
@@ -64,7 +64,7 @@ public class OAuth2ClientBuilder
/// Id of the client
/// Secret of the client
/// Endpoint to receive the Access Token
- /// Issuer of the Access Token. Used to automaticly receive the Token Endpoint while building
+ /// Issuer of the Access Token. Used to automatically receive the Token Endpoint while building
///
/// Either or must be provided.
///
@@ -163,7 +163,7 @@ private async Task GetTokenEndpointFromIssuerAsync(CancellationToken cancel
httpClient.DefaultRequestHeaders.Accept.Clear();
httpClient.DefaultRequestHeaders.Accept.Add(new MediaTypeWithQualityHeaderValue("application/json"));
- // Build endpoint from Issuer and dicovery endpoint, we can't use the Uri overload because the Issuer Uri may not have a trailing '/'
+ // Build endpoint from Issuer and discovery endpoint, we can't use the Uri overload because the Issuer Uri may not have a trailing '/'
string tempIssuer = _issuer.AbsoluteUri.EndsWith("/") ? _issuer.AbsoluteUri : _issuer.AbsoluteUri + "/";
Uri discoveryEndpoint = new Uri(tempIssuer + DISCOVERY_ENDPOINT);
@@ -187,7 +187,7 @@ private async Task GetTokenEndpointFromIssuerAsync(CancellationToken cancel
/**
* Default implementation of IOAuth2Client. It uses Client_Credentials OAuth2 flow to request a
- * token. The basic constructor assumes no scopes are needed only the OAuth2 Client credentiuals.
+ * token. The basic constructor assumes no scopes are needed only the OAuth2 Client credentials.
* The additional constructor accepts a Dictionary with all the request parameters passed onto the
* OAuth2 request token.
*/
diff --git a/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs b/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs
index 07e4bca5a..3eb94272d 100644
--- a/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs
+++ b/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs
@@ -120,7 +120,7 @@ await HandleMainLoopExceptionAsync(new ShutdownEventArgs(ShutdownInitiator.Libra
MaybeTerminateMainloopAndStopHeartbeatTimers();
/*
* Note: do NOT use the main loop cancellation token,
- * because FininshCloseAsync immediately cancels it
+ * because FinishCloseAsync immediately cancels it
*/
using var cts = new CancellationTokenSource(InternalConstants.DefaultConnectionAbortTimeout);
await FinishCloseAsync(cts.Token)
diff --git a/projects/Test/Common/IntegrationFixture.cs b/projects/Test/Common/IntegrationFixture.cs
index 3251fd7f7..1c5fb07f1 100644
--- a/projects/Test/Common/IntegrationFixture.cs
+++ b/projects/Test/Common/IntegrationFixture.cs
@@ -637,7 +637,7 @@ protected static byte[] GetRandomBody(ushort size = 1024)
protected static Task WaitForRecoveryAsync(IConnection conn)
{
TaskCompletionSource tcs = PrepareForRecovery((AutorecoveringConnection)conn);
- return WaitAsync(tcs, "recovery succeded");
+ return WaitAsync(tcs, "recovery succeeded");
}
protected static TaskCompletionSource PrepareForRecovery(IConnection conn)
diff --git a/projects/Test/Integration/TestConnectionTopologyRecovery.cs b/projects/Test/Integration/TestConnectionTopologyRecovery.cs
index 048879d62..7a300f4ba 100644
--- a/projects/Test/Integration/TestConnectionTopologyRecovery.cs
+++ b/projects/Test/Integration/TestConnectionTopologyRecovery.cs
@@ -383,7 +383,7 @@ await _channel.QueueDeclareAsync(queueToRecoverWithException, false, false, fals
try
{
await CloseAndWaitForRecoveryAsync(conn);
- await WaitAsync(tcs, "recovery succeded");
+ await WaitAsync(tcs, "recovery succeeded");
Assert.True(ch.IsOpen);
await AssertQueueRecoveryAsync(ch, queueToRecoverSuccessfully, false);
diff --git a/projects/Test/SequentialIntegration/TestConnectionRecovery.cs b/projects/Test/SequentialIntegration/TestConnectionRecovery.cs
index e1e603b4c..0644f4068 100644
--- a/projects/Test/SequentialIntegration/TestConnectionRecovery.cs
+++ b/projects/Test/SequentialIntegration/TestConnectionRecovery.cs
@@ -160,7 +160,7 @@ public async Task TestBlockedListenersRecovery()
}
finally
{
- // NOTE: must unblock so that close succeeeds on test tear-down
+ // NOTE: must unblock so that close succeeds on test tear-down
await UnblockAsync();
}
}