From ba8c2e0e78eb168647228243f989c383fec18ef1 Mon Sep 17 00:00:00 2001 From: Luke Bakken Date: Fri, 3 Jan 2025 07:12:26 -0800 Subject: [PATCH] Update copyright year to 2025 --- projects/Applications/CreateChannel/Program.cs | 4 ++-- projects/Applications/GH-1647/Program.cs | 4 ++-- projects/Applications/MassPublish/Program.cs | 4 ++-- projects/Applications/PublisherConfirms/PublisherConfirms.cs | 4 ++-- .../Benchmarks/ConsumerDispatching/AsyncBasicConsumerFake.cs | 4 ++-- projects/Benchmarks/WireFormatting/MethodFraming.cs | 4 ++-- projects/RabbitMQ.Client.OAuth2/CredentialsRefresher.cs | 4 ++-- .../RabbitMQ.Client.OAuth2/CredentialsRefresherEventSource.cs | 4 ++-- projects/RabbitMQ.Client.OAuth2/IOAuth2Client.cs | 4 ++-- projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs | 4 ++-- projects/RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs | 4 ++-- projects/RabbitMQ.Client.OAuth2/RabbitMQ.Client.OAuth2.csproj | 2 +- projects/RabbitMQ.Client.OAuth2/Token.cs | 4 ++-- .../RabbitMQ.Client.OpenTelemetry.csproj | 2 +- projects/RabbitMQ.Client/AmqpTcpEndpoint.cs | 4 ++-- projects/RabbitMQ.Client/AmqpTimestamp.cs | 4 ++-- projects/RabbitMQ.Client/BasicCredentialsProvider.cs | 4 ++-- projects/RabbitMQ.Client/BasicGetResult.cs | 4 ++-- projects/RabbitMQ.Client/BasicProperties.cs | 4 ++-- projects/RabbitMQ.Client/BinaryTableValue.cs | 4 ++-- projects/RabbitMQ.Client/ConnectionConfig.cs | 4 ++-- projects/RabbitMQ.Client/ConnectionFactory.cs | 4 ++-- projects/RabbitMQ.Client/ConnectionFactoryBase.cs | 4 ++-- projects/RabbitMQ.Client/Constants.cs | 4 ++-- .../ConsumerDispatching/ConsumerDispatcherBase.cs | 4 ++-- .../ConsumerDispatching/ConsumerDispatcherChannelBase.cs | 4 ++-- .../RabbitMQ.Client/ConsumerDispatching/FallbackConsumer.cs | 2 +- .../ConsumerDispatching/IConsumerDispatcher.cs | 4 ++-- projects/RabbitMQ.Client/CreateChannelOptions.cs | 4 ++-- projects/RabbitMQ.Client/DefaultEndpointResolver.cs | 4 ++-- projects/RabbitMQ.Client/DeliveryModes.cs | 4 ++-- projects/RabbitMQ.Client/DictionaryExtension.cs | 4 ++-- projects/RabbitMQ.Client/Events/AsyncEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/AsyncEventHandler.cs | 4 ++-- projects/RabbitMQ.Client/Events/BasicAckEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/BasicDeliverEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/BasicNackEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/BasicReturnEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/CallbackExceptionEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/ConnectionBlockedEventArgs.cs | 4 ++-- .../Events/ConnectionRecoveryErrorEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/ConsumerEventArgs.cs | 4 ++-- .../Events/ConsumerTagChangedAfterRecoveryEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/FlowControlEventArgs.cs | 4 ++-- .../Events/QueueNameChangedAfterRecoveryEventArgs.cs | 4 ++-- .../RabbitMQ.Client/Events/RecoveringConsumerEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Events/ShutdownEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/Exceptions/AlreadyClosedException.cs | 4 ++-- .../Exceptions/AuthenticationFailureException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/BrokerUnreachableException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/ChannelAllocationException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/ConnectFailureException.cs | 4 ++-- projects/RabbitMQ.Client/Exceptions/HardProtocolException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/MalformedFrameException.cs | 4 ++-- .../Exceptions/OperationInterruptedException.cs | 4 ++-- .../Exceptions/PacketNotRecognizedException.cs | 4 ++-- .../Exceptions/PossibleAuthenticationFailureException.cs | 4 ++-- projects/RabbitMQ.Client/Exceptions/ProtocolException.cs | 4 ++-- .../Exceptions/ProtocolVersionMismatchException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/ProtocolViolationException.cs | 4 ++-- projects/RabbitMQ.Client/Exceptions/PublishException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/RabbitMQClientException.cs | 4 ++-- projects/RabbitMQ.Client/Exceptions/SyntaxErrorException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/TopologyRecoveryException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/UnexpectedFrameException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/UnexpectedMethodException.cs | 4 ++-- .../Exceptions/UnknownClassOrMethodException.cs | 4 ++-- .../RabbitMQ.Client/Exceptions/WireFormattingException.cs | 4 ++-- projects/RabbitMQ.Client/ExchangeType.cs | 4 ++-- projects/RabbitMQ.Client/ExternalMechanism.cs | 4 ++-- projects/RabbitMQ.Client/ExternalMechanismFactory.cs | 4 ++-- projects/RabbitMQ.Client/Framing/AmqpVersion.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicAck.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicCancel.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicCancelOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicConsume.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicConsumeOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicDeliver.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicGet.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicGetOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicNack.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicPublish.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicQos.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicReject.cs | 4 ++-- projects/RabbitMQ.Client/Framing/BasicReturn.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ChannelClose.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ChannelCloseOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ChannelFlow.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ChannelFlowOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ChannelMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ChannelOpen.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ClassConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConfirmMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConfirmSelect.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionBlocked.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionClose.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionCloseOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionOpen.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionSecure.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionSecureOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionStart.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionStartOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionTune.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionTuneOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ConnectionUpdateSecret.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ExchangeBind.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ExchangeDeclare.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ExchangeDelete.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ExchangeMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ExchangeUnbind.cs | 4 ++-- projects/RabbitMQ.Client/Framing/IAmqpMethod.cs | 4 ++-- projects/RabbitMQ.Client/Framing/Protocol.cs | 4 ++-- projects/RabbitMQ.Client/Framing/ProtocolCommandId.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueueBind.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueueDeclare.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueueDeclareOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueueDelete.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueueDeleteOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueueMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueuePurge.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueuePurgeOk.cs | 4 ++-- projects/RabbitMQ.Client/Framing/QueueUnbind.cs | 4 ++-- projects/RabbitMQ.Client/Framing/TxCommit.cs | 4 ++-- projects/RabbitMQ.Client/Framing/TxMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/Framing/TxRollback.cs | 4 ++-- projects/RabbitMQ.Client/Framing/TxSelect.cs | 4 ++-- projects/RabbitMQ.Client/Headers.cs | 4 ++-- projects/RabbitMQ.Client/IAmqpHeader.cs | 4 ++-- projects/RabbitMQ.Client/IAmqpWriteable.cs | 4 ++-- projects/RabbitMQ.Client/IAsyncBasicConsumer.cs | 4 ++-- projects/RabbitMQ.Client/IAuthMechanism.cs | 4 ++-- projects/RabbitMQ.Client/IAuthMechanismFactory.cs | 4 ++-- projects/RabbitMQ.Client/IBasicProperties.cs | 4 ++-- projects/RabbitMQ.Client/IChannel.cs | 4 ++-- projects/RabbitMQ.Client/IChannelExtensions.cs | 4 ++-- projects/RabbitMQ.Client/IConnection.cs | 4 ++-- projects/RabbitMQ.Client/IConnectionFactory.cs | 4 ++-- projects/RabbitMQ.Client/ICredentialsProvider.cs | 4 ++-- projects/RabbitMQ.Client/IEndpointResolver.cs | 4 ++-- projects/RabbitMQ.Client/IEndpointResolverExtensions.cs | 4 ++-- projects/RabbitMQ.Client/INetworkConnection.cs | 4 ++-- projects/RabbitMQ.Client/IProtocol.cs | 4 ++-- projects/RabbitMQ.Client/IRecoverable.cs | 4 ++-- projects/RabbitMQ.Client/Impl/AsyncManualResetEvent.cs | 4 ++-- projects/RabbitMQ.Client/Impl/AsyncRpcContinuations.cs | 4 ++-- projects/RabbitMQ.Client/Impl/AutorecoveringChannel.cs | 4 ++-- .../Impl/AutorecoveringConnection.Recording.cs | 4 ++-- .../RabbitMQ.Client/Impl/AutorecoveringConnection.Recovery.cs | 4 ++-- projects/RabbitMQ.Client/Impl/AutorecoveringConnection.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Channel.BasicPublish.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Channel.PublisherConfirms.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Channel.cs | 4 ++-- projects/RabbitMQ.Client/Impl/CommandAssembler.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Connection.Commands.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Connection.Receive.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Connection.cs | 4 ++-- projects/RabbitMQ.Client/Impl/ConnectionSecureOrTune.cs | 4 ++-- projects/RabbitMQ.Client/Impl/ConnectionStartDetails.cs | 4 ++-- projects/RabbitMQ.Client/Impl/EmptyBasicProperty.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Frame.cs | 4 ++-- projects/RabbitMQ.Client/Impl/IFrameHandler.cs | 4 ++-- projects/RabbitMQ.Client/Impl/IRpcContinuation.cs | 4 ++-- projects/RabbitMQ.Client/Impl/ISession.cs | 4 ++-- projects/RabbitMQ.Client/Impl/IncomingCommand.cs | 4 ++-- projects/RabbitMQ.Client/Impl/MainSession.cs | 4 ++-- projects/RabbitMQ.Client/Impl/ProtocolBase.cs | 4 ++-- projects/RabbitMQ.Client/Impl/RecordedBinding.cs | 4 ++-- projects/RabbitMQ.Client/Impl/RecordedConsumer.cs | 4 ++-- projects/RabbitMQ.Client/Impl/RecordedExchange.cs | 4 ++-- projects/RabbitMQ.Client/Impl/RecordedQueue.cs | 4 ++-- projects/RabbitMQ.Client/Impl/RecoveryAwareChannel.cs | 4 ++-- projects/RabbitMQ.Client/Impl/RpcContinuationQueue.cs | 4 ++-- projects/RabbitMQ.Client/Impl/Session.cs | 4 ++-- projects/RabbitMQ.Client/Impl/SessionBase.cs | 4 ++-- projects/RabbitMQ.Client/Impl/SessionManager.cs | 4 ++-- projects/RabbitMQ.Client/Impl/SocketFactory.cs | 4 ++-- projects/RabbitMQ.Client/Impl/SocketFrameHandler.cs | 4 ++-- projects/RabbitMQ.Client/Impl/SslHelper.cs | 4 ++-- projects/RabbitMQ.Client/Impl/WireFormatting.Read.cs | 4 ++-- projects/RabbitMQ.Client/Impl/WireFormatting.Write.cs | 4 ++-- projects/RabbitMQ.Client/Impl/WireFormatting.cs | 4 ++-- projects/RabbitMQ.Client/InternalConstants.cs | 4 ++-- projects/RabbitMQ.Client/Logging/ESLog.cs | 4 ++-- .../Logging/RabbitMqClientEventSource.Counters.cs | 4 ++-- projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.cs | 4 ++-- projects/RabbitMQ.Client/Logging/RabbitMqExceptionDetail.cs | 4 ++-- projects/RabbitMQ.Client/PlainMechanism.cs | 4 ++-- projects/RabbitMQ.Client/PlainMechanismFactory.cs | 4 ++-- projects/RabbitMQ.Client/Protocols.cs | 4 ++-- projects/RabbitMQ.Client/PublicationAddress.cs | 4 ++-- projects/RabbitMQ.Client/QueueDeclareOk.cs | 4 ++-- projects/RabbitMQ.Client/RabbitMQ.Client.csproj | 2 +- projects/RabbitMQ.Client/ReadonlyBasicProperties.cs | 4 ++-- projects/RabbitMQ.Client/RentedMemory.cs | 4 ++-- projects/RabbitMQ.Client/ShutdownInitiator.cs | 4 ++-- projects/RabbitMQ.Client/ShutdownReportEntry.cs | 4 ++-- projects/RabbitMQ.Client/SslOption.cs | 4 ++-- projects/RabbitMQ.Client/TaskExtensions.cs | 4 ++-- projects/RabbitMQ.Client/ThrottlingRateLimiter.cs | 4 ++-- projects/RabbitMQ.Client/TypeExtensions.cs | 4 ++-- projects/RabbitMQ.Client/Util/IntAllocator.cs | 4 ++-- projects/RabbitMQ.Client/Util/NetworkOrderDeserializer.cs | 4 ++-- projects/RabbitMQ.Client/Util/NetworkOrderSerializer.cs | 4 ++-- projects/Test/Common/IntegrationFixture.cs | 4 ++-- projects/Test/Common/ProcessUtil.cs | 4 ++-- projects/Test/Common/RabbitMQCtl.cs | 4 ++-- projects/Test/Common/SslEnv.cs | 4 ++-- projects/Test/Common/TestConnectionRecoveryBase.cs | 4 ++-- projects/Test/Common/TestOutputWriter.cs | 4 ++-- projects/Test/Common/TestOutputWriterEventListener.cs | 4 ++-- projects/Test/Common/TimingFixture.cs | 4 ++-- .../EventHandlerRecovery/Channel/TestRecoveryEventHandlers.cs | 4 ++-- .../EventHandlerRecovery/Channel/TestShutdownEventHandlers.cs | 4 ++-- .../Connection/TestRecoveringConsumerEventHandlers.cs | 4 ++-- .../Connection/TestRecoverySucceededEventHandlers.cs | 4 ++-- .../Connection/TestShutdownEventHandlers.cs | 4 ++-- .../ConnectionRecovery/TestBasicAckAndBasicNack.cs | 4 ++-- .../ConnectionRecovery/TestBasicConnectionRecovery.cs | 4 ++-- .../Integration/ConnectionRecovery/TestConnectionRecovery.cs | 4 ++-- .../Integration/ConnectionRecovery/TestConsumerRecovery.cs | 4 ++-- .../Test/Integration/ConnectionRecovery/TestDeclaration.cs | 4 ++-- .../Integration/ConnectionRecovery/TestExchangeRecovery.cs | 4 ++-- .../Test/Integration/ConnectionRecovery/TestQueueRecovery.cs | 4 ++-- .../ConnectionRecovery/TestQueueRecoveryWithArguments.cs | 4 ++-- .../ConnectionRecovery/TestRecoveryWithDeletedEntities.cs | 4 ++-- .../Integration/ConnectionRecovery/TestRpcAfterRecovery.cs | 4 ++-- projects/Test/Integration/TestAsyncConsumer.cs | 4 ++-- projects/Test/Integration/TestAsyncConsumerCancelNotify.cs | 4 ++-- projects/Test/Integration/TestAsyncConsumerCount.cs | 4 ++-- projects/Test/Integration/TestAsyncConsumerExceptions.cs | 4 ++-- .../Test/Integration/TestAsyncConsumerOperationDispatch.cs | 4 ++-- projects/Test/Integration/TestAsyncEventingBasicConsumer.cs | 4 ++-- projects/Test/Integration/TestAuth.cs | 4 ++-- projects/Test/Integration/TestBasicGet.cs | 4 ++-- projects/Test/Integration/TestBasicPublish.cs | 4 ++-- projects/Test/Integration/TestBasicPublishAsync.cs | 4 ++-- projects/Test/Integration/TestChannelAllocation.cs | 4 ++-- projects/Test/Integration/TestChannelShutdown.cs | 4 ++-- projects/Test/Integration/TestChannelSoftErrors.cs | 4 ++-- projects/Test/Integration/TestConcurrentAccessBase.cs.cs | 4 ++-- .../Test/Integration/TestConcurrentAccessWithSharedChannel.cs | 4 ++-- .../Integration/TestConcurrentAccessWithSharedConnection.cs | 4 ++-- projects/Test/Integration/TestConfirmSelect.cs | 4 ++-- projects/Test/Integration/TestConfirmSelectAsync.cs | 4 ++-- projects/Test/Integration/TestConnectionFactory.cs | 4 ++-- .../Integration/TestConnectionFactoryContinuationTimeout.cs | 4 ++-- .../Test/Integration/TestConnectionRecoveryWithoutSetup.cs | 4 ++-- projects/Test/Integration/TestConnectionShutdown.cs | 4 ++-- projects/Test/Integration/TestConnectionTopologyRecovery.cs | 4 ++-- projects/Test/Integration/TestExceptionMessages.cs | 4 ++-- projects/Test/Integration/TestExchangeDeclare.cs | 4 ++-- projects/Test/Integration/TestExtensions.cs | 4 ++-- projects/Test/Integration/TestFloodPublishing.cs | 4 ++-- projects/Test/Integration/TestInitialConnection.cs | 4 ++-- projects/Test/Integration/TestInvalidAck.cs | 4 ++-- projects/Test/Integration/TestMainLoop.cs | 4 ++-- projects/Test/Integration/TestMessageCount.cs | 4 ++-- projects/Test/Integration/TestNowait.cs | 4 ++-- projects/Test/Integration/TestPassiveDeclare.cs | 4 ++-- projects/Test/Integration/TestPublishSharedChannelAsync.cs | 4 ++-- projects/Test/Integration/TestPublisherConfirms.cs | 4 ++-- projects/Test/Integration/TestQueueDeclare.cs | 4 ++-- projects/Test/Integration/TestSsl.cs | 4 ++-- projects/Test/Integration/TestToxiproxy.cs | 4 ++-- projects/Test/Integration/TestUpdateSecret.cs | 4 ++-- projects/Test/OAuth2/MockOAuth2Client.cs | 4 ++-- projects/Test/OAuth2/RequestFormMatcher.cs | 4 ++-- projects/Test/OAuth2/TestCredentialsRefresher.cs | 4 ++-- projects/Test/OAuth2/TestOAuth2.cs | 4 ++-- projects/Test/OAuth2/TestOAuth2Client.cs | 4 ++-- projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs | 4 ++-- .../SequentialIntegration/SequentialIntegrationFixture.cs | 4 ++-- projects/Test/SequentialIntegration/TestActivitySource.cs | 4 ++-- projects/Test/SequentialIntegration/TestConnectionBlocked.cs | 4 ++-- .../SequentialIntegration/TestConnectionBlockedChannelLeak.cs | 4 ++-- projects/Test/SequentialIntegration/TestConnectionRecovery.cs | 4 ++-- projects/Test/SequentialIntegration/TestHeartbeats.cs | 4 ++-- projects/Test/SequentialIntegration/TestOpenTelemetry.cs | 4 ++-- projects/Test/Unit/DebugUtil.cs | 4 ++-- projects/Test/Unit/TestAmqpTcpEndpointParsing.cs | 4 ++-- projects/Test/Unit/TestAmqpUri.cs | 4 ++-- projects/Test/Unit/TestBasicProperties.cs | 4 ++-- projects/Test/Unit/TestContentHeaderCodec.cs | 4 ++-- projects/Test/Unit/TestFieldTableFormatting.cs | 4 ++-- projects/Test/Unit/TestFieldTableFormattingGeneric.cs | 4 ++-- projects/Test/Unit/TestFrameFormatting.cs | 4 ++-- projects/Test/Unit/TestIEndpointResolverExtensions.cs | 4 ++-- projects/Test/Unit/TestIntAllocator.cs | 4 ++-- projects/Test/Unit/TestMethodArgumentCodec.cs | 4 ++-- projects/Test/Unit/TestNetworkByteOrderSerialization.cs | 4 ++-- projects/Test/Unit/TestPublicationAddress.cs | 4 ++-- projects/Test/Unit/TestRpcContinuationQueue.cs | 4 ++-- projects/Test/Unit/TestTcpClientAdapter.cs | 4 ++-- projects/Test/Unit/TimingFixture.cs | 4 ++-- projects/Test/Unit/WireFormattingFixture.cs | 4 ++-- 298 files changed, 592 insertions(+), 592 deletions(-) diff --git a/projects/Applications/CreateChannel/Program.cs b/projects/Applications/CreateChannel/Program.cs index 69d96e2570..4ed61c6f97 100644 --- a/projects/Applications/CreateChannel/Program.cs +++ b/projects/Applications/CreateChannel/Program.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Applications/GH-1647/Program.cs b/projects/Applications/GH-1647/Program.cs index 6a7c4b5234..967a0f98b5 100644 --- a/projects/Applications/GH-1647/Program.cs +++ b/projects/Applications/GH-1647/Program.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- #pragma warning disable CA2007 // Consider calling ConfigureAwait on the awaited task diff --git a/projects/Applications/MassPublish/Program.cs b/projects/Applications/MassPublish/Program.cs index 1abab26f9d..ddc967ffbc 100644 --- a/projects/Applications/MassPublish/Program.cs +++ b/projects/Applications/MassPublish/Program.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Applications/PublisherConfirms/PublisherConfirms.cs b/projects/Applications/PublisherConfirms/PublisherConfirms.cs index 87c1bfd843..e683e283ca 100644 --- a/projects/Applications/PublisherConfirms/PublisherConfirms.cs +++ b/projects/Applications/PublisherConfirms/PublisherConfirms.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Benchmarks/ConsumerDispatching/AsyncBasicConsumerFake.cs b/projects/Benchmarks/ConsumerDispatching/AsyncBasicConsumerFake.cs index 86ed09de93..39e216286f 100644 --- a/projects/Benchmarks/ConsumerDispatching/AsyncBasicConsumerFake.cs +++ b/projects/Benchmarks/ConsumerDispatching/AsyncBasicConsumerFake.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Benchmarks/WireFormatting/MethodFraming.cs b/projects/Benchmarks/WireFormatting/MethodFraming.cs index e9c9e36e1e..4a68e80ab9 100644 --- a/projects/Benchmarks/WireFormatting/MethodFraming.cs +++ b/projects/Benchmarks/WireFormatting/MethodFraming.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client.OAuth2/CredentialsRefresher.cs b/projects/RabbitMQ.Client.OAuth2/CredentialsRefresher.cs index 14b639b712..add1d4e819 100644 --- a/projects/RabbitMQ.Client.OAuth2/CredentialsRefresher.cs +++ b/projects/RabbitMQ.Client.OAuth2/CredentialsRefresher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client.OAuth2/CredentialsRefresherEventSource.cs b/projects/RabbitMQ.Client.OAuth2/CredentialsRefresherEventSource.cs index 9db7beb3bd..bf7168f068 100644 --- a/projects/RabbitMQ.Client.OAuth2/CredentialsRefresherEventSource.cs +++ b/projects/RabbitMQ.Client.OAuth2/CredentialsRefresherEventSource.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Diagnostics.CodeAnalysis; diff --git a/projects/RabbitMQ.Client.OAuth2/IOAuth2Client.cs b/projects/RabbitMQ.Client.OAuth2/IOAuth2Client.cs index b79d0627e7..a533937c38 100644 --- a/projects/RabbitMQ.Client.OAuth2/IOAuth2Client.cs +++ b/projects/RabbitMQ.Client.OAuth2/IOAuth2Client.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs b/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs index 7d71685a79..2f2ec75051 100644 --- a/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs +++ b/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs b/projects/RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs index 3033a2a954..42ad3dccb0 100644 --- a/projects/RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs +++ b/projects/RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client.OAuth2/RabbitMQ.Client.OAuth2.csproj b/projects/RabbitMQ.Client.OAuth2/RabbitMQ.Client.OAuth2.csproj index 3059350139..e262aa5ead 100644 --- a/projects/RabbitMQ.Client.OAuth2/RabbitMQ.Client.OAuth2.csproj +++ b/projects/RabbitMQ.Client.OAuth2/RabbitMQ.Client.OAuth2.csproj @@ -7,7 +7,7 @@ RabbitMQ OAuth2 Client Library for .NET Broadcom Broadcom, Inc. and/or its subsidiaries. - Copyright (c) 2007-2024 Broadcom. All Rights Reserved. The term "Broadcom" refers to Broadcom Inc. and/or its subsidiaries. + Copyright (c) 2007-2025 Broadcom. All Rights Reserved. The term "Broadcom" refers to Broadcom Inc. and/or its subsidiaries. The RabbitMQ OAuth2 Client Library for .NET enables OAuth2 token refresh for RabbitMQ.Client true icon.png diff --git a/projects/RabbitMQ.Client.OAuth2/Token.cs b/projects/RabbitMQ.Client.OAuth2/Token.cs index 4c7e4941d2..93ec0e85be 100644 --- a/projects/RabbitMQ.Client.OAuth2/Token.cs +++ b/projects/RabbitMQ.Client.OAuth2/Token.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client.OpenTelemetry/RabbitMQ.Client.OpenTelemetry.csproj b/projects/RabbitMQ.Client.OpenTelemetry/RabbitMQ.Client.OpenTelemetry.csproj index 10efe3c889..fe1af035f7 100644 --- a/projects/RabbitMQ.Client.OpenTelemetry/RabbitMQ.Client.OpenTelemetry.csproj +++ b/projects/RabbitMQ.Client.OpenTelemetry/RabbitMQ.Client.OpenTelemetry.csproj @@ -7,7 +7,7 @@ RabbitMQ OpenTelemetry Integration Package for .NET Broadcom Broadcom, Inc. and/or its subsidiaries. - Copyright (c) 2007-2024 Broadcom. All Rights Reserved. The term "Broadcom" refers to Broadcom Inc. and/or its subsidiaries. + Copyright (c) 2007-2025 Broadcom. All Rights Reserved. The term "Broadcom" refers to Broadcom Inc. and/or its subsidiaries. The RabbitMQ OpenTelemetry Library for .NET adds convenience extension methods for RabbitMQ/OpenTelemetry true icon.png diff --git a/projects/RabbitMQ.Client/AmqpTcpEndpoint.cs b/projects/RabbitMQ.Client/AmqpTcpEndpoint.cs index 83489964b9..4778ccbb8d 100644 --- a/projects/RabbitMQ.Client/AmqpTcpEndpoint.cs +++ b/projects/RabbitMQ.Client/AmqpTcpEndpoint.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/AmqpTimestamp.cs b/projects/RabbitMQ.Client/AmqpTimestamp.cs index ecafffcfa7..3947939b72 100644 --- a/projects/RabbitMQ.Client/AmqpTimestamp.cs +++ b/projects/RabbitMQ.Client/AmqpTimestamp.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/BasicCredentialsProvider.cs b/projects/RabbitMQ.Client/BasicCredentialsProvider.cs index 850def2523..4587481e4f 100644 --- a/projects/RabbitMQ.Client/BasicCredentialsProvider.cs +++ b/projects/RabbitMQ.Client/BasicCredentialsProvider.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/BasicGetResult.cs b/projects/RabbitMQ.Client/BasicGetResult.cs index 5502f86fe5..3257c794c9 100644 --- a/projects/RabbitMQ.Client/BasicGetResult.cs +++ b/projects/RabbitMQ.Client/BasicGetResult.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/BasicProperties.cs b/projects/RabbitMQ.Client/BasicProperties.cs index 35a65b6881..848bed7dd6 100644 --- a/projects/RabbitMQ.Client/BasicProperties.cs +++ b/projects/RabbitMQ.Client/BasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/BinaryTableValue.cs b/projects/RabbitMQ.Client/BinaryTableValue.cs index 16a2e08c83..e4aef32019 100644 --- a/projects/RabbitMQ.Client/BinaryTableValue.cs +++ b/projects/RabbitMQ.Client/BinaryTableValue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ConnectionConfig.cs b/projects/RabbitMQ.Client/ConnectionConfig.cs index 6bce2d44ba..8b714b8ebd 100644 --- a/projects/RabbitMQ.Client/ConnectionConfig.cs +++ b/projects/RabbitMQ.Client/ConnectionConfig.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ConnectionFactory.cs b/projects/RabbitMQ.Client/ConnectionFactory.cs index d8f669d710..06ed2b23e0 100644 --- a/projects/RabbitMQ.Client/ConnectionFactory.cs +++ b/projects/RabbitMQ.Client/ConnectionFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ConnectionFactoryBase.cs b/projects/RabbitMQ.Client/ConnectionFactoryBase.cs index e6d07e5ab1..e61d296425 100644 --- a/projects/RabbitMQ.Client/ConnectionFactoryBase.cs +++ b/projects/RabbitMQ.Client/ConnectionFactoryBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Constants.cs b/projects/RabbitMQ.Client/Constants.cs index b9c77dc753..27d1fa898a 100644 --- a/projects/RabbitMQ.Client/Constants.cs +++ b/projects/RabbitMQ.Client/Constants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherBase.cs b/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherBase.cs index 19462c945f..e7c7bcbc86 100644 --- a/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherBase.cs +++ b/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Concurrent; diff --git a/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherChannelBase.cs b/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherChannelBase.cs index 92c2739574..963fced575 100644 --- a/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherChannelBase.cs +++ b/projects/RabbitMQ.Client/ConsumerDispatching/ConsumerDispatcherChannelBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ConsumerDispatching/FallbackConsumer.cs b/projects/RabbitMQ.Client/ConsumerDispatching/FallbackConsumer.cs index 31f31b115c..2061c3f36a 100644 --- a/projects/RabbitMQ.Client/ConsumerDispatching/FallbackConsumer.cs +++ b/projects/RabbitMQ.Client/ConsumerDispatching/FallbackConsumer.cs @@ -19,7 +19,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ConsumerDispatching/IConsumerDispatcher.cs b/projects/RabbitMQ.Client/ConsumerDispatching/IConsumerDispatcher.cs index d3fb5fc32c..79676f37cf 100644 --- a/projects/RabbitMQ.Client/ConsumerDispatching/IConsumerDispatcher.cs +++ b/projects/RabbitMQ.Client/ConsumerDispatching/IConsumerDispatcher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/CreateChannelOptions.cs b/projects/RabbitMQ.Client/CreateChannelOptions.cs index 5faabc1663..06b23a8e62 100644 --- a/projects/RabbitMQ.Client/CreateChannelOptions.cs +++ b/projects/RabbitMQ.Client/CreateChannelOptions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/DefaultEndpointResolver.cs b/projects/RabbitMQ.Client/DefaultEndpointResolver.cs index 27368b1249..87236bf472 100644 --- a/projects/RabbitMQ.Client/DefaultEndpointResolver.cs +++ b/projects/RabbitMQ.Client/DefaultEndpointResolver.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/DeliveryModes.cs b/projects/RabbitMQ.Client/DeliveryModes.cs index 094fde31ac..f1a60a617e 100644 --- a/projects/RabbitMQ.Client/DeliveryModes.cs +++ b/projects/RabbitMQ.Client/DeliveryModes.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/DictionaryExtension.cs b/projects/RabbitMQ.Client/DictionaryExtension.cs index a6abf0633a..9ca5ba6e13 100644 --- a/projects/RabbitMQ.Client/DictionaryExtension.cs +++ b/projects/RabbitMQ.Client/DictionaryExtension.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- #if NETSTANDARD diff --git a/projects/RabbitMQ.Client/Events/AsyncEventArgs.cs b/projects/RabbitMQ.Client/Events/AsyncEventArgs.cs index 1426731dca..4907fc626f 100644 --- a/projects/RabbitMQ.Client/Events/AsyncEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/AsyncEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client/Events/AsyncEventHandler.cs b/projects/RabbitMQ.Client/Events/AsyncEventHandler.cs index c01d73b3bb..e64e95559f 100644 --- a/projects/RabbitMQ.Client/Events/AsyncEventHandler.cs +++ b/projects/RabbitMQ.Client/Events/AsyncEventHandler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/RabbitMQ.Client/Events/BasicAckEventArgs.cs b/projects/RabbitMQ.Client/Events/BasicAckEventArgs.cs index 09b3b39860..0e180d21c4 100644 --- a/projects/RabbitMQ.Client/Events/BasicAckEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/BasicAckEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/BasicDeliverEventArgs.cs b/projects/RabbitMQ.Client/Events/BasicDeliverEventArgs.cs index 5b4f2e7bb9..0feeddaced 100644 --- a/projects/RabbitMQ.Client/Events/BasicDeliverEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/BasicDeliverEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/BasicNackEventArgs.cs b/projects/RabbitMQ.Client/Events/BasicNackEventArgs.cs index 6d63318e5e..a7625fbe27 100644 --- a/projects/RabbitMQ.Client/Events/BasicNackEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/BasicNackEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/BasicReturnEventArgs.cs b/projects/RabbitMQ.Client/Events/BasicReturnEventArgs.cs index dd4c4e1992..8398831c85 100644 --- a/projects/RabbitMQ.Client/Events/BasicReturnEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/BasicReturnEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/CallbackExceptionEventArgs.cs b/projects/RabbitMQ.Client/Events/CallbackExceptionEventArgs.cs index c2bfb2f359..f23e99afe8 100644 --- a/projects/RabbitMQ.Client/Events/CallbackExceptionEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/CallbackExceptionEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/ConnectionBlockedEventArgs.cs b/projects/RabbitMQ.Client/Events/ConnectionBlockedEventArgs.cs index 0a9b14c39f..6ec93a2a6c 100644 --- a/projects/RabbitMQ.Client/Events/ConnectionBlockedEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/ConnectionBlockedEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/ConnectionRecoveryErrorEventArgs.cs b/projects/RabbitMQ.Client/Events/ConnectionRecoveryErrorEventArgs.cs index f956ec7316..b984e8fc82 100644 --- a/projects/RabbitMQ.Client/Events/ConnectionRecoveryErrorEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/ConnectionRecoveryErrorEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/ConsumerEventArgs.cs b/projects/RabbitMQ.Client/Events/ConsumerEventArgs.cs index cc972915c9..ec98483995 100644 --- a/projects/RabbitMQ.Client/Events/ConsumerEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/ConsumerEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/ConsumerTagChangedAfterRecoveryEventArgs.cs b/projects/RabbitMQ.Client/Events/ConsumerTagChangedAfterRecoveryEventArgs.cs index 80bdf6242a..34056e4755 100644 --- a/projects/RabbitMQ.Client/Events/ConsumerTagChangedAfterRecoveryEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/ConsumerTagChangedAfterRecoveryEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/FlowControlEventArgs.cs b/projects/RabbitMQ.Client/Events/FlowControlEventArgs.cs index 347f0e5120..06bffb0c45 100644 --- a/projects/RabbitMQ.Client/Events/FlowControlEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/FlowControlEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/QueueNameChangedAfterRecoveryEventArgs.cs b/projects/RabbitMQ.Client/Events/QueueNameChangedAfterRecoveryEventArgs.cs index d052d681e8..92a26bf477 100644 --- a/projects/RabbitMQ.Client/Events/QueueNameChangedAfterRecoveryEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/QueueNameChangedAfterRecoveryEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Events/RecoveringConsumerEventArgs.cs b/projects/RabbitMQ.Client/Events/RecoveringConsumerEventArgs.cs index f2702cc37c..da657e8c5f 100644 --- a/projects/RabbitMQ.Client/Events/RecoveringConsumerEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/RecoveringConsumerEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/Events/ShutdownEventArgs.cs b/projects/RabbitMQ.Client/Events/ShutdownEventArgs.cs index f5b5bd282f..cc25bd23d8 100644 --- a/projects/RabbitMQ.Client/Events/ShutdownEventArgs.cs +++ b/projects/RabbitMQ.Client/Events/ShutdownEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/AlreadyClosedException.cs b/projects/RabbitMQ.Client/Exceptions/AlreadyClosedException.cs index e0e7104932..50b4d8655b 100644 --- a/projects/RabbitMQ.Client/Exceptions/AlreadyClosedException.cs +++ b/projects/RabbitMQ.Client/Exceptions/AlreadyClosedException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/AuthenticationFailureException.cs b/projects/RabbitMQ.Client/Exceptions/AuthenticationFailureException.cs index 4f7b736f19..7f9f16d1cd 100644 --- a/projects/RabbitMQ.Client/Exceptions/AuthenticationFailureException.cs +++ b/projects/RabbitMQ.Client/Exceptions/AuthenticationFailureException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/BrokerUnreachableException.cs b/projects/RabbitMQ.Client/Exceptions/BrokerUnreachableException.cs index caa06ac9c4..0d1907006a 100644 --- a/projects/RabbitMQ.Client/Exceptions/BrokerUnreachableException.cs +++ b/projects/RabbitMQ.Client/Exceptions/BrokerUnreachableException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/ChannelAllocationException.cs b/projects/RabbitMQ.Client/Exceptions/ChannelAllocationException.cs index 9af300fbb3..c76f9d9b51 100644 --- a/projects/RabbitMQ.Client/Exceptions/ChannelAllocationException.cs +++ b/projects/RabbitMQ.Client/Exceptions/ChannelAllocationException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/ConnectFailureException.cs b/projects/RabbitMQ.Client/Exceptions/ConnectFailureException.cs index e8f6e197cd..07b2d20480 100644 --- a/projects/RabbitMQ.Client/Exceptions/ConnectFailureException.cs +++ b/projects/RabbitMQ.Client/Exceptions/ConnectFailureException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/HardProtocolException.cs b/projects/RabbitMQ.Client/Exceptions/HardProtocolException.cs index e055f04215..4da8e076e1 100644 --- a/projects/RabbitMQ.Client/Exceptions/HardProtocolException.cs +++ b/projects/RabbitMQ.Client/Exceptions/HardProtocolException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/Exceptions/MalformedFrameException.cs b/projects/RabbitMQ.Client/Exceptions/MalformedFrameException.cs index 3a52926958..82af068f01 100644 --- a/projects/RabbitMQ.Client/Exceptions/MalformedFrameException.cs +++ b/projects/RabbitMQ.Client/Exceptions/MalformedFrameException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/Exceptions/OperationInterruptedException.cs b/projects/RabbitMQ.Client/Exceptions/OperationInterruptedException.cs index 78e2238d64..0676e54f9f 100644 --- a/projects/RabbitMQ.Client/Exceptions/OperationInterruptedException.cs +++ b/projects/RabbitMQ.Client/Exceptions/OperationInterruptedException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/PacketNotRecognizedException.cs b/projects/RabbitMQ.Client/Exceptions/PacketNotRecognizedException.cs index 7d212542ef..d587f7b5c5 100644 --- a/projects/RabbitMQ.Client/Exceptions/PacketNotRecognizedException.cs +++ b/projects/RabbitMQ.Client/Exceptions/PacketNotRecognizedException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/PossibleAuthenticationFailureException.cs b/projects/RabbitMQ.Client/Exceptions/PossibleAuthenticationFailureException.cs index feeb54a036..31595b697f 100644 --- a/projects/RabbitMQ.Client/Exceptions/PossibleAuthenticationFailureException.cs +++ b/projects/RabbitMQ.Client/Exceptions/PossibleAuthenticationFailureException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/ProtocolException.cs b/projects/RabbitMQ.Client/Exceptions/ProtocolException.cs index 18575c63c6..69e945428e 100644 --- a/projects/RabbitMQ.Client/Exceptions/ProtocolException.cs +++ b/projects/RabbitMQ.Client/Exceptions/ProtocolException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using RabbitMQ.Client.Events; diff --git a/projects/RabbitMQ.Client/Exceptions/ProtocolVersionMismatchException.cs b/projects/RabbitMQ.Client/Exceptions/ProtocolVersionMismatchException.cs index a87fd0d988..d1a9818268 100644 --- a/projects/RabbitMQ.Client/Exceptions/ProtocolVersionMismatchException.cs +++ b/projects/RabbitMQ.Client/Exceptions/ProtocolVersionMismatchException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/ProtocolViolationException.cs b/projects/RabbitMQ.Client/Exceptions/ProtocolViolationException.cs index 2e973f5f44..42c5d4e9e6 100644 --- a/projects/RabbitMQ.Client/Exceptions/ProtocolViolationException.cs +++ b/projects/RabbitMQ.Client/Exceptions/ProtocolViolationException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/PublishException.cs b/projects/RabbitMQ.Client/Exceptions/PublishException.cs index ac404f660c..42939ed23c 100644 --- a/projects/RabbitMQ.Client/Exceptions/PublishException.cs +++ b/projects/RabbitMQ.Client/Exceptions/PublishException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/RabbitMQClientException.cs b/projects/RabbitMQ.Client/Exceptions/RabbitMQClientException.cs index 97e5403990..405fef3290 100644 --- a/projects/RabbitMQ.Client/Exceptions/RabbitMQClientException.cs +++ b/projects/RabbitMQ.Client/Exceptions/RabbitMQClientException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/SyntaxErrorException.cs b/projects/RabbitMQ.Client/Exceptions/SyntaxErrorException.cs index 37f6611a63..a65bc38326 100644 --- a/projects/RabbitMQ.Client/Exceptions/SyntaxErrorException.cs +++ b/projects/RabbitMQ.Client/Exceptions/SyntaxErrorException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/Exceptions/TopologyRecoveryException.cs b/projects/RabbitMQ.Client/Exceptions/TopologyRecoveryException.cs index e4ffc1b614..262df968f7 100644 --- a/projects/RabbitMQ.Client/Exceptions/TopologyRecoveryException.cs +++ b/projects/RabbitMQ.Client/Exceptions/TopologyRecoveryException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/UnexpectedFrameException.cs b/projects/RabbitMQ.Client/Exceptions/UnexpectedFrameException.cs index e7dc8d48e8..ba77276c4c 100644 --- a/projects/RabbitMQ.Client/Exceptions/UnexpectedFrameException.cs +++ b/projects/RabbitMQ.Client/Exceptions/UnexpectedFrameException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using RabbitMQ.Client.Impl; diff --git a/projects/RabbitMQ.Client/Exceptions/UnexpectedMethodException.cs b/projects/RabbitMQ.Client/Exceptions/UnexpectedMethodException.cs index 5e925053db..e4a0b5596e 100644 --- a/projects/RabbitMQ.Client/Exceptions/UnexpectedMethodException.cs +++ b/projects/RabbitMQ.Client/Exceptions/UnexpectedMethodException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Exceptions/UnknownClassOrMethodException.cs b/projects/RabbitMQ.Client/Exceptions/UnknownClassOrMethodException.cs index 3f796c7e78..27842b18dc 100644 --- a/projects/RabbitMQ.Client/Exceptions/UnknownClassOrMethodException.cs +++ b/projects/RabbitMQ.Client/Exceptions/UnknownClassOrMethodException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/Exceptions/WireFormattingException.cs b/projects/RabbitMQ.Client/Exceptions/WireFormattingException.cs index 9a9b3dfd00..70b982d80c 100644 --- a/projects/RabbitMQ.Client/Exceptions/WireFormattingException.cs +++ b/projects/RabbitMQ.Client/Exceptions/WireFormattingException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ExchangeType.cs b/projects/RabbitMQ.Client/ExchangeType.cs index d2a16923a1..ec79b628e6 100644 --- a/projects/RabbitMQ.Client/ExchangeType.cs +++ b/projects/RabbitMQ.Client/ExchangeType.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/ExternalMechanism.cs b/projects/RabbitMQ.Client/ExternalMechanism.cs index ef54d96878..522c340328 100644 --- a/projects/RabbitMQ.Client/ExternalMechanism.cs +++ b/projects/RabbitMQ.Client/ExternalMechanism.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ExternalMechanismFactory.cs b/projects/RabbitMQ.Client/ExternalMechanismFactory.cs index d1f53476bf..ab5c31ab2a 100644 --- a/projects/RabbitMQ.Client/ExternalMechanismFactory.cs +++ b/projects/RabbitMQ.Client/ExternalMechanismFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/Framing/AmqpVersion.cs b/projects/RabbitMQ.Client/Framing/AmqpVersion.cs index 335e7eb4aa..37acf0655b 100644 --- a/projects/RabbitMQ.Client/Framing/AmqpVersion.cs +++ b/projects/RabbitMQ.Client/Framing/AmqpVersion.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicAck.cs b/projects/RabbitMQ.Client/Framing/BasicAck.cs index 8710403bb7..b5f51d8848 100644 --- a/projects/RabbitMQ.Client/Framing/BasicAck.cs +++ b/projects/RabbitMQ.Client/Framing/BasicAck.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicCancel.cs b/projects/RabbitMQ.Client/Framing/BasicCancel.cs index 8a5cdc75c9..7a5da6e725 100644 --- a/projects/RabbitMQ.Client/Framing/BasicCancel.cs +++ b/projects/RabbitMQ.Client/Framing/BasicCancel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicCancelOk.cs b/projects/RabbitMQ.Client/Framing/BasicCancelOk.cs index 0efd12dfe3..9cf8c0359c 100644 --- a/projects/RabbitMQ.Client/Framing/BasicCancelOk.cs +++ b/projects/RabbitMQ.Client/Framing/BasicCancelOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicConsume.cs b/projects/RabbitMQ.Client/Framing/BasicConsume.cs index 45cb84b836..52354b2ccb 100644 --- a/projects/RabbitMQ.Client/Framing/BasicConsume.cs +++ b/projects/RabbitMQ.Client/Framing/BasicConsume.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicConsumeOk.cs b/projects/RabbitMQ.Client/Framing/BasicConsumeOk.cs index 97da24fb75..0f3a00e84e 100644 --- a/projects/RabbitMQ.Client/Framing/BasicConsumeOk.cs +++ b/projects/RabbitMQ.Client/Framing/BasicConsumeOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicDeliver.cs b/projects/RabbitMQ.Client/Framing/BasicDeliver.cs index 4e7f8f37d7..61b1ea2a4e 100644 --- a/projects/RabbitMQ.Client/Framing/BasicDeliver.cs +++ b/projects/RabbitMQ.Client/Framing/BasicDeliver.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicGet.cs b/projects/RabbitMQ.Client/Framing/BasicGet.cs index 956ac5b0bc..fd6f0c2fd3 100644 --- a/projects/RabbitMQ.Client/Framing/BasicGet.cs +++ b/projects/RabbitMQ.Client/Framing/BasicGet.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicGetOk.cs b/projects/RabbitMQ.Client/Framing/BasicGetOk.cs index c19db27fbb..29d9aae6ac 100644 --- a/projects/RabbitMQ.Client/Framing/BasicGetOk.cs +++ b/projects/RabbitMQ.Client/Framing/BasicGetOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicMethodConstants.cs b/projects/RabbitMQ.Client/Framing/BasicMethodConstants.cs index 416c4e2fed..a4deefa3b3 100644 --- a/projects/RabbitMQ.Client/Framing/BasicMethodConstants.cs +++ b/projects/RabbitMQ.Client/Framing/BasicMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/BasicNack.cs b/projects/RabbitMQ.Client/Framing/BasicNack.cs index 4122eb3397..bd56c79fd3 100644 --- a/projects/RabbitMQ.Client/Framing/BasicNack.cs +++ b/projects/RabbitMQ.Client/Framing/BasicNack.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicPublish.cs b/projects/RabbitMQ.Client/Framing/BasicPublish.cs index 3fceb20b4d..5ac389afd2 100644 --- a/projects/RabbitMQ.Client/Framing/BasicPublish.cs +++ b/projects/RabbitMQ.Client/Framing/BasicPublish.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicQos.cs b/projects/RabbitMQ.Client/Framing/BasicQos.cs index 67ed69ba75..152d4f439f 100644 --- a/projects/RabbitMQ.Client/Framing/BasicQos.cs +++ b/projects/RabbitMQ.Client/Framing/BasicQos.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicReject.cs b/projects/RabbitMQ.Client/Framing/BasicReject.cs index 568f79433b..8a39f6fe2e 100644 --- a/projects/RabbitMQ.Client/Framing/BasicReject.cs +++ b/projects/RabbitMQ.Client/Framing/BasicReject.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/BasicReturn.cs b/projects/RabbitMQ.Client/Framing/BasicReturn.cs index 830f5d0a68..e0f9f7cd06 100644 --- a/projects/RabbitMQ.Client/Framing/BasicReturn.cs +++ b/projects/RabbitMQ.Client/Framing/BasicReturn.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ChannelClose.cs b/projects/RabbitMQ.Client/Framing/ChannelClose.cs index 176b4a6a36..3e98f006a0 100644 --- a/projects/RabbitMQ.Client/Framing/ChannelClose.cs +++ b/projects/RabbitMQ.Client/Framing/ChannelClose.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ChannelCloseOk.cs b/projects/RabbitMQ.Client/Framing/ChannelCloseOk.cs index 379f8760fb..1463ae0817 100644 --- a/projects/RabbitMQ.Client/Framing/ChannelCloseOk.cs +++ b/projects/RabbitMQ.Client/Framing/ChannelCloseOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ChannelFlow.cs b/projects/RabbitMQ.Client/Framing/ChannelFlow.cs index 9abd6d9ed1..1b7179c897 100644 --- a/projects/RabbitMQ.Client/Framing/ChannelFlow.cs +++ b/projects/RabbitMQ.Client/Framing/ChannelFlow.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ChannelFlowOk.cs b/projects/RabbitMQ.Client/Framing/ChannelFlowOk.cs index 87ac10a285..5edd77e4df 100644 --- a/projects/RabbitMQ.Client/Framing/ChannelFlowOk.cs +++ b/projects/RabbitMQ.Client/Framing/ChannelFlowOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ChannelMethodConstants.cs b/projects/RabbitMQ.Client/Framing/ChannelMethodConstants.cs index 728419f8d2..b7d1b3c228 100644 --- a/projects/RabbitMQ.Client/Framing/ChannelMethodConstants.cs +++ b/projects/RabbitMQ.Client/Framing/ChannelMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/ChannelOpen.cs b/projects/RabbitMQ.Client/Framing/ChannelOpen.cs index ab5ad35678..43d64e399b 100644 --- a/projects/RabbitMQ.Client/Framing/ChannelOpen.cs +++ b/projects/RabbitMQ.Client/Framing/ChannelOpen.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ClassConstants.cs b/projects/RabbitMQ.Client/Framing/ClassConstants.cs index 320b1846ef..e6e45db1bb 100644 --- a/projects/RabbitMQ.Client/Framing/ClassConstants.cs +++ b/projects/RabbitMQ.Client/Framing/ClassConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/ConfirmMethodConstants.cs b/projects/RabbitMQ.Client/Framing/ConfirmMethodConstants.cs index a291be47c6..b1a14aa5ad 100644 --- a/projects/RabbitMQ.Client/Framing/ConfirmMethodConstants.cs +++ b/projects/RabbitMQ.Client/Framing/ConfirmMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/ConfirmSelect.cs b/projects/RabbitMQ.Client/Framing/ConfirmSelect.cs index 781636c942..0491713ed8 100644 --- a/projects/RabbitMQ.Client/Framing/ConfirmSelect.cs +++ b/projects/RabbitMQ.Client/Framing/ConfirmSelect.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionBlocked.cs b/projects/RabbitMQ.Client/Framing/ConnectionBlocked.cs index 62864afaf1..a2c22e542d 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionBlocked.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionBlocked.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionClose.cs b/projects/RabbitMQ.Client/Framing/ConnectionClose.cs index 73275d1389..6f791897f2 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionClose.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionClose.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionCloseOk.cs b/projects/RabbitMQ.Client/Framing/ConnectionCloseOk.cs index 9b48e30193..a5767f76ba 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionCloseOk.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionCloseOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionMethodConstants.cs b/projects/RabbitMQ.Client/Framing/ConnectionMethodConstants.cs index b2a3af9598..d18915bbfc 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionMethodConstants.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/ConnectionOpen.cs b/projects/RabbitMQ.Client/Framing/ConnectionOpen.cs index fe3f26e88e..c8595a08c3 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionOpen.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionOpen.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionSecure.cs b/projects/RabbitMQ.Client/Framing/ConnectionSecure.cs index 0daad6d554..81851bb032 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionSecure.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionSecure.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionSecureOk.cs b/projects/RabbitMQ.Client/Framing/ConnectionSecureOk.cs index cae9437b25..5759986204 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionSecureOk.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionSecureOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionStart.cs b/projects/RabbitMQ.Client/Framing/ConnectionStart.cs index da8d3e3ce3..21dc690e95 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionStart.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionStart.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionStartOk.cs b/projects/RabbitMQ.Client/Framing/ConnectionStartOk.cs index 293bb1ac10..1ed1102190 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionStartOk.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionStartOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionTune.cs b/projects/RabbitMQ.Client/Framing/ConnectionTune.cs index 9e07faee97..b85fcb18ac 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionTune.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionTune.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionTuneOk.cs b/projects/RabbitMQ.Client/Framing/ConnectionTuneOk.cs index 0146238797..ba1eb3ebf4 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionTuneOk.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionTuneOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ConnectionUpdateSecret.cs b/projects/RabbitMQ.Client/Framing/ConnectionUpdateSecret.cs index c6a06e3b8f..e5e1236491 100644 --- a/projects/RabbitMQ.Client/Framing/ConnectionUpdateSecret.cs +++ b/projects/RabbitMQ.Client/Framing/ConnectionUpdateSecret.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ExchangeBind.cs b/projects/RabbitMQ.Client/Framing/ExchangeBind.cs index f91be18fc5..bf9be7a932 100644 --- a/projects/RabbitMQ.Client/Framing/ExchangeBind.cs +++ b/projects/RabbitMQ.Client/Framing/ExchangeBind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ExchangeDeclare.cs b/projects/RabbitMQ.Client/Framing/ExchangeDeclare.cs index ffcd17d72f..adcfa37460 100644 --- a/projects/RabbitMQ.Client/Framing/ExchangeDeclare.cs +++ b/projects/RabbitMQ.Client/Framing/ExchangeDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ExchangeDelete.cs b/projects/RabbitMQ.Client/Framing/ExchangeDelete.cs index 5e9d6dd2a3..45667b0493 100644 --- a/projects/RabbitMQ.Client/Framing/ExchangeDelete.cs +++ b/projects/RabbitMQ.Client/Framing/ExchangeDelete.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ExchangeMethodConstants.cs b/projects/RabbitMQ.Client/Framing/ExchangeMethodConstants.cs index f583862e10..7ecd0674b3 100644 --- a/projects/RabbitMQ.Client/Framing/ExchangeMethodConstants.cs +++ b/projects/RabbitMQ.Client/Framing/ExchangeMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/ExchangeUnbind.cs b/projects/RabbitMQ.Client/Framing/ExchangeUnbind.cs index 129808106d..7e66e857a8 100644 --- a/projects/RabbitMQ.Client/Framing/ExchangeUnbind.cs +++ b/projects/RabbitMQ.Client/Framing/ExchangeUnbind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/IAmqpMethod.cs b/projects/RabbitMQ.Client/Framing/IAmqpMethod.cs index f7dc16f676..cbd62628d8 100644 --- a/projects/RabbitMQ.Client/Framing/IAmqpMethod.cs +++ b/projects/RabbitMQ.Client/Framing/IAmqpMethod.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/Protocol.cs b/projects/RabbitMQ.Client/Framing/Protocol.cs index 758398af07..9a8df66fd0 100644 --- a/projects/RabbitMQ.Client/Framing/Protocol.cs +++ b/projects/RabbitMQ.Client/Framing/Protocol.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/ProtocolCommandId.cs b/projects/RabbitMQ.Client/Framing/ProtocolCommandId.cs index 5c65b3dbd6..df8d6d1a09 100644 --- a/projects/RabbitMQ.Client/Framing/ProtocolCommandId.cs +++ b/projects/RabbitMQ.Client/Framing/ProtocolCommandId.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/QueueBind.cs b/projects/RabbitMQ.Client/Framing/QueueBind.cs index ca1aabd732..ad354c3d5d 100644 --- a/projects/RabbitMQ.Client/Framing/QueueBind.cs +++ b/projects/RabbitMQ.Client/Framing/QueueBind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/QueueDeclare.cs b/projects/RabbitMQ.Client/Framing/QueueDeclare.cs index c9e5cc3ca4..e67e5abf04 100644 --- a/projects/RabbitMQ.Client/Framing/QueueDeclare.cs +++ b/projects/RabbitMQ.Client/Framing/QueueDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/QueueDeclareOk.cs b/projects/RabbitMQ.Client/Framing/QueueDeclareOk.cs index c51164ddff..5348168d26 100644 --- a/projects/RabbitMQ.Client/Framing/QueueDeclareOk.cs +++ b/projects/RabbitMQ.Client/Framing/QueueDeclareOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/QueueDelete.cs b/projects/RabbitMQ.Client/Framing/QueueDelete.cs index ceb839cd38..62a8546225 100644 --- a/projects/RabbitMQ.Client/Framing/QueueDelete.cs +++ b/projects/RabbitMQ.Client/Framing/QueueDelete.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/QueueDeleteOk.cs b/projects/RabbitMQ.Client/Framing/QueueDeleteOk.cs index edaded22a4..3f8e90f05d 100644 --- a/projects/RabbitMQ.Client/Framing/QueueDeleteOk.cs +++ b/projects/RabbitMQ.Client/Framing/QueueDeleteOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/QueueMethodConstants.cs b/projects/RabbitMQ.Client/Framing/QueueMethodConstants.cs index d9a39aba98..7eedf4e65b 100644 --- a/projects/RabbitMQ.Client/Framing/QueueMethodConstants.cs +++ b/projects/RabbitMQ.Client/Framing/QueueMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/QueuePurge.cs b/projects/RabbitMQ.Client/Framing/QueuePurge.cs index 5b6f0d1f47..db02eb54b1 100644 --- a/projects/RabbitMQ.Client/Framing/QueuePurge.cs +++ b/projects/RabbitMQ.Client/Framing/QueuePurge.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/QueuePurgeOk.cs b/projects/RabbitMQ.Client/Framing/QueuePurgeOk.cs index b477781710..8ee41260a9 100644 --- a/projects/RabbitMQ.Client/Framing/QueuePurgeOk.cs +++ b/projects/RabbitMQ.Client/Framing/QueuePurgeOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/QueueUnbind.cs b/projects/RabbitMQ.Client/Framing/QueueUnbind.cs index b8a775d964..50d7a09de9 100644 --- a/projects/RabbitMQ.Client/Framing/QueueUnbind.cs +++ b/projects/RabbitMQ.Client/Framing/QueueUnbind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/TxCommit.cs b/projects/RabbitMQ.Client/Framing/TxCommit.cs index f48c9618cf..9a474ee441 100644 --- a/projects/RabbitMQ.Client/Framing/TxCommit.cs +++ b/projects/RabbitMQ.Client/Framing/TxCommit.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/TxMethodConstants.cs b/projects/RabbitMQ.Client/Framing/TxMethodConstants.cs index 292f1dbe8d..29b336aaee 100644 --- a/projects/RabbitMQ.Client/Framing/TxMethodConstants.cs +++ b/projects/RabbitMQ.Client/Framing/TxMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing diff --git a/projects/RabbitMQ.Client/Framing/TxRollback.cs b/projects/RabbitMQ.Client/Framing/TxRollback.cs index 023a61e12d..e6dcd833f4 100644 --- a/projects/RabbitMQ.Client/Framing/TxRollback.cs +++ b/projects/RabbitMQ.Client/Framing/TxRollback.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Framing/TxSelect.cs b/projects/RabbitMQ.Client/Framing/TxSelect.cs index 3d62ddd229..93ed8ae11d 100644 --- a/projects/RabbitMQ.Client/Framing/TxSelect.cs +++ b/projects/RabbitMQ.Client/Framing/TxSelect.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Headers.cs b/projects/RabbitMQ.Client/Headers.cs index 4c896f8bb4..651b64c941 100644 --- a/projects/RabbitMQ.Client/Headers.cs +++ b/projects/RabbitMQ.Client/Headers.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/IAmqpHeader.cs b/projects/RabbitMQ.Client/IAmqpHeader.cs index 23192d21f8..fa1963d662 100644 --- a/projects/RabbitMQ.Client/IAmqpHeader.cs +++ b/projects/RabbitMQ.Client/IAmqpHeader.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/IAmqpWriteable.cs b/projects/RabbitMQ.Client/IAmqpWriteable.cs index 0b02af222e..e471066508 100644 --- a/projects/RabbitMQ.Client/IAmqpWriteable.cs +++ b/projects/RabbitMQ.Client/IAmqpWriteable.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/IAsyncBasicConsumer.cs b/projects/RabbitMQ.Client/IAsyncBasicConsumer.cs index a581757ae8..0c6879d4c9 100644 --- a/projects/RabbitMQ.Client/IAsyncBasicConsumer.cs +++ b/projects/RabbitMQ.Client/IAsyncBasicConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/IAuthMechanism.cs b/projects/RabbitMQ.Client/IAuthMechanism.cs index 3f33195aa7..770fddeddf 100644 --- a/projects/RabbitMQ.Client/IAuthMechanism.cs +++ b/projects/RabbitMQ.Client/IAuthMechanism.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client/IAuthMechanismFactory.cs b/projects/RabbitMQ.Client/IAuthMechanismFactory.cs index fc848b1676..fbab1649f5 100644 --- a/projects/RabbitMQ.Client/IAuthMechanismFactory.cs +++ b/projects/RabbitMQ.Client/IAuthMechanismFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/IBasicProperties.cs b/projects/RabbitMQ.Client/IBasicProperties.cs index c5a289501c..162d2efdf1 100644 --- a/projects/RabbitMQ.Client/IBasicProperties.cs +++ b/projects/RabbitMQ.Client/IBasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/IChannel.cs b/projects/RabbitMQ.Client/IChannel.cs index 852b7e8ee4..b3d4cfb74a 100644 --- a/projects/RabbitMQ.Client/IChannel.cs +++ b/projects/RabbitMQ.Client/IChannel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/IChannelExtensions.cs b/projects/RabbitMQ.Client/IChannelExtensions.cs index c7359e0db2..3f04d47576 100644 --- a/projects/RabbitMQ.Client/IChannelExtensions.cs +++ b/projects/RabbitMQ.Client/IChannelExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/IConnection.cs b/projects/RabbitMQ.Client/IConnection.cs index 8217013e3f..835eb3b4d2 100644 --- a/projects/RabbitMQ.Client/IConnection.cs +++ b/projects/RabbitMQ.Client/IConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/IConnectionFactory.cs b/projects/RabbitMQ.Client/IConnectionFactory.cs index f66d8c522d..ab4aec4d73 100644 --- a/projects/RabbitMQ.Client/IConnectionFactory.cs +++ b/projects/RabbitMQ.Client/IConnectionFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ICredentialsProvider.cs b/projects/RabbitMQ.Client/ICredentialsProvider.cs index 1518331e90..db1736657f 100644 --- a/projects/RabbitMQ.Client/ICredentialsProvider.cs +++ b/projects/RabbitMQ.Client/ICredentialsProvider.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/IEndpointResolver.cs b/projects/RabbitMQ.Client/IEndpointResolver.cs index 4838468267..3cc0ec01cd 100644 --- a/projects/RabbitMQ.Client/IEndpointResolver.cs +++ b/projects/RabbitMQ.Client/IEndpointResolver.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/IEndpointResolverExtensions.cs b/projects/RabbitMQ.Client/IEndpointResolverExtensions.cs index e571d628ad..74378f8933 100644 --- a/projects/RabbitMQ.Client/IEndpointResolverExtensions.cs +++ b/projects/RabbitMQ.Client/IEndpointResolverExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/INetworkConnection.cs b/projects/RabbitMQ.Client/INetworkConnection.cs index ee4d8e30e3..dd9f8e36ca 100644 --- a/projects/RabbitMQ.Client/INetworkConnection.cs +++ b/projects/RabbitMQ.Client/INetworkConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/IProtocol.cs b/projects/RabbitMQ.Client/IProtocol.cs index 0140abcc1f..8d88f73582 100644 --- a/projects/RabbitMQ.Client/IProtocol.cs +++ b/projects/RabbitMQ.Client/IProtocol.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/IRecoverable.cs b/projects/RabbitMQ.Client/IRecoverable.cs index 82a8cd80da..6c93f2ea25 100644 --- a/projects/RabbitMQ.Client/IRecoverable.cs +++ b/projects/RabbitMQ.Client/IRecoverable.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/AsyncManualResetEvent.cs b/projects/RabbitMQ.Client/Impl/AsyncManualResetEvent.cs index 58503d9981..b85fe6797b 100644 --- a/projects/RabbitMQ.Client/Impl/AsyncManualResetEvent.cs +++ b/projects/RabbitMQ.Client/Impl/AsyncManualResetEvent.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/AsyncRpcContinuations.cs b/projects/RabbitMQ.Client/Impl/AsyncRpcContinuations.cs index 1e0068a48c..38ba391df2 100644 --- a/projects/RabbitMQ.Client/Impl/AsyncRpcContinuations.cs +++ b/projects/RabbitMQ.Client/Impl/AsyncRpcContinuations.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/AutorecoveringChannel.cs b/projects/RabbitMQ.Client/Impl/AutorecoveringChannel.cs index d98734f19a..26d77f8ea9 100644 --- a/projects/RabbitMQ.Client/Impl/AutorecoveringChannel.cs +++ b/projects/RabbitMQ.Client/Impl/AutorecoveringChannel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recording.cs b/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recording.cs index ef8f21c358..e3e8622335 100644 --- a/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recording.cs +++ b/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recording.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recovery.cs b/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recovery.cs index 7eaed04796..7f3439fa6a 100644 --- a/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recovery.cs +++ b/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.Recovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.cs b/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.cs index f38de44a13..61df604f76 100644 --- a/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.cs +++ b/projects/RabbitMQ.Client/Impl/AutorecoveringConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Channel.BasicPublish.cs b/projects/RabbitMQ.Client/Impl/Channel.BasicPublish.cs index 491d32796d..47c87a1774 100644 --- a/projects/RabbitMQ.Client/Impl/Channel.BasicPublish.cs +++ b/projects/RabbitMQ.Client/Impl/Channel.BasicPublish.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Channel.PublisherConfirms.cs b/projects/RabbitMQ.Client/Impl/Channel.PublisherConfirms.cs index dff4504d10..e168369658 100644 --- a/projects/RabbitMQ.Client/Impl/Channel.PublisherConfirms.cs +++ b/projects/RabbitMQ.Client/Impl/Channel.PublisherConfirms.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Channel.cs b/projects/RabbitMQ.Client/Impl/Channel.cs index 4e73a9a087..4acc3da629 100644 --- a/projects/RabbitMQ.Client/Impl/Channel.cs +++ b/projects/RabbitMQ.Client/Impl/Channel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/CommandAssembler.cs b/projects/RabbitMQ.Client/Impl/CommandAssembler.cs index 3d6331db82..33cfc27763 100644 --- a/projects/RabbitMQ.Client/Impl/CommandAssembler.cs +++ b/projects/RabbitMQ.Client/Impl/CommandAssembler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Connection.Commands.cs b/projects/RabbitMQ.Client/Impl/Connection.Commands.cs index 2b9f114120..ed79e6ea0a 100644 --- a/projects/RabbitMQ.Client/Impl/Connection.Commands.cs +++ b/projects/RabbitMQ.Client/Impl/Connection.Commands.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs b/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs index ee76db9aee..07e4bca5a4 100644 --- a/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs +++ b/projects/RabbitMQ.Client/Impl/Connection.Heartbeat.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Connection.Receive.cs b/projects/RabbitMQ.Client/Impl/Connection.Receive.cs index 9a3ad49b16..a5d90ff7be 100644 --- a/projects/RabbitMQ.Client/Impl/Connection.Receive.cs +++ b/projects/RabbitMQ.Client/Impl/Connection.Receive.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Connection.cs b/projects/RabbitMQ.Client/Impl/Connection.cs index af26bb7acc..68cadcfd71 100644 --- a/projects/RabbitMQ.Client/Impl/Connection.cs +++ b/projects/RabbitMQ.Client/Impl/Connection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/ConnectionSecureOrTune.cs b/projects/RabbitMQ.Client/Impl/ConnectionSecureOrTune.cs index 505f430b0a..2656c72992 100644 --- a/projects/RabbitMQ.Client/Impl/ConnectionSecureOrTune.cs +++ b/projects/RabbitMQ.Client/Impl/ConnectionSecureOrTune.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Impl diff --git a/projects/RabbitMQ.Client/Impl/ConnectionStartDetails.cs b/projects/RabbitMQ.Client/Impl/ConnectionStartDetails.cs index 91cf5b4a36..18ccaf910c 100644 --- a/projects/RabbitMQ.Client/Impl/ConnectionStartDetails.cs +++ b/projects/RabbitMQ.Client/Impl/ConnectionStartDetails.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/Impl/EmptyBasicProperty.cs b/projects/RabbitMQ.Client/Impl/EmptyBasicProperty.cs index 20cc3d4ca2..be46868a46 100644 --- a/projects/RabbitMQ.Client/Impl/EmptyBasicProperty.cs +++ b/projects/RabbitMQ.Client/Impl/EmptyBasicProperty.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Frame.cs b/projects/RabbitMQ.Client/Impl/Frame.cs index 52802de905..c39c080726 100644 --- a/projects/RabbitMQ.Client/Impl/Frame.cs +++ b/projects/RabbitMQ.Client/Impl/Frame.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/IFrameHandler.cs b/projects/RabbitMQ.Client/Impl/IFrameHandler.cs index 672f6a3bb4..c8b7de7f22 100644 --- a/projects/RabbitMQ.Client/Impl/IFrameHandler.cs +++ b/projects/RabbitMQ.Client/Impl/IFrameHandler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/IRpcContinuation.cs b/projects/RabbitMQ.Client/Impl/IRpcContinuation.cs index 5af80fba0f..1d51008c96 100644 --- a/projects/RabbitMQ.Client/Impl/IRpcContinuation.cs +++ b/projects/RabbitMQ.Client/Impl/IRpcContinuation.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/ISession.cs b/projects/RabbitMQ.Client/Impl/ISession.cs index 535f2b7725..c2b0768755 100644 --- a/projects/RabbitMQ.Client/Impl/ISession.cs +++ b/projects/RabbitMQ.Client/Impl/ISession.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/IncomingCommand.cs b/projects/RabbitMQ.Client/Impl/IncomingCommand.cs index 7f3cd9da9a..fba7a498d9 100644 --- a/projects/RabbitMQ.Client/Impl/IncomingCommand.cs +++ b/projects/RabbitMQ.Client/Impl/IncomingCommand.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/MainSession.cs b/projects/RabbitMQ.Client/Impl/MainSession.cs index 74baa36d97..80abd9899b 100644 --- a/projects/RabbitMQ.Client/Impl/MainSession.cs +++ b/projects/RabbitMQ.Client/Impl/MainSession.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- // We use spec version 0-9 for common constants such as frame types, diff --git a/projects/RabbitMQ.Client/Impl/ProtocolBase.cs b/projects/RabbitMQ.Client/Impl/ProtocolBase.cs index 65c108b739..1cdc82be06 100644 --- a/projects/RabbitMQ.Client/Impl/ProtocolBase.cs +++ b/projects/RabbitMQ.Client/Impl/ProtocolBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/RecordedBinding.cs b/projects/RabbitMQ.Client/Impl/RecordedBinding.cs index 684f33200d..6307a06871 100644 --- a/projects/RabbitMQ.Client/Impl/RecordedBinding.cs +++ b/projects/RabbitMQ.Client/Impl/RecordedBinding.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/RecordedConsumer.cs b/projects/RabbitMQ.Client/Impl/RecordedConsumer.cs index bc672034ec..db5d7be46c 100644 --- a/projects/RabbitMQ.Client/Impl/RecordedConsumer.cs +++ b/projects/RabbitMQ.Client/Impl/RecordedConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/RecordedExchange.cs b/projects/RabbitMQ.Client/Impl/RecordedExchange.cs index a70e178b8f..a5d2616587 100644 --- a/projects/RabbitMQ.Client/Impl/RecordedExchange.cs +++ b/projects/RabbitMQ.Client/Impl/RecordedExchange.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/Impl/RecordedQueue.cs b/projects/RabbitMQ.Client/Impl/RecordedQueue.cs index c3b929c679..d0527a9afe 100644 --- a/projects/RabbitMQ.Client/Impl/RecordedQueue.cs +++ b/projects/RabbitMQ.Client/Impl/RecordedQueue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/Impl/RecoveryAwareChannel.cs b/projects/RabbitMQ.Client/Impl/RecoveryAwareChannel.cs index 33f1b2e738..45a484909d 100644 --- a/projects/RabbitMQ.Client/Impl/RecoveryAwareChannel.cs +++ b/projects/RabbitMQ.Client/Impl/RecoveryAwareChannel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client/Impl/RpcContinuationQueue.cs b/projects/RabbitMQ.Client/Impl/RpcContinuationQueue.cs index f5ec4dc12f..2a017328d9 100644 --- a/projects/RabbitMQ.Client/Impl/RpcContinuationQueue.cs +++ b/projects/RabbitMQ.Client/Impl/RpcContinuationQueue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/Session.cs b/projects/RabbitMQ.Client/Impl/Session.cs index 4c160987df..e8deecac29 100644 --- a/projects/RabbitMQ.Client/Impl/Session.cs +++ b/projects/RabbitMQ.Client/Impl/Session.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client/Impl/SessionBase.cs b/projects/RabbitMQ.Client/Impl/SessionBase.cs index 0e0c363eda..b252850a3e 100644 --- a/projects/RabbitMQ.Client/Impl/SessionBase.cs +++ b/projects/RabbitMQ.Client/Impl/SessionBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/SessionManager.cs b/projects/RabbitMQ.Client/Impl/SessionManager.cs index 28d28dada7..7c6e356355 100644 --- a/projects/RabbitMQ.Client/Impl/SessionManager.cs +++ b/projects/RabbitMQ.Client/Impl/SessionManager.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/Impl/SocketFactory.cs b/projects/RabbitMQ.Client/Impl/SocketFactory.cs index fcfffe82a3..1005bf590c 100644 --- a/projects/RabbitMQ.Client/Impl/SocketFactory.cs +++ b/projects/RabbitMQ.Client/Impl/SocketFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/SocketFrameHandler.cs b/projects/RabbitMQ.Client/Impl/SocketFrameHandler.cs index 850a5d8c0c..b39b953708 100644 --- a/projects/RabbitMQ.Client/Impl/SocketFrameHandler.cs +++ b/projects/RabbitMQ.Client/Impl/SocketFrameHandler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/SslHelper.cs b/projects/RabbitMQ.Client/Impl/SslHelper.cs index 9eaca2b6cd..ebe309d037 100644 --- a/projects/RabbitMQ.Client/Impl/SslHelper.cs +++ b/projects/RabbitMQ.Client/Impl/SslHelper.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/WireFormatting.Read.cs b/projects/RabbitMQ.Client/Impl/WireFormatting.Read.cs index 859968ff60..f8de21ed5a 100644 --- a/projects/RabbitMQ.Client/Impl/WireFormatting.Read.cs +++ b/projects/RabbitMQ.Client/Impl/WireFormatting.Read.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/WireFormatting.Write.cs b/projects/RabbitMQ.Client/Impl/WireFormatting.Write.cs index 77712d18d9..9ec9c9d614 100644 --- a/projects/RabbitMQ.Client/Impl/WireFormatting.Write.cs +++ b/projects/RabbitMQ.Client/Impl/WireFormatting.Write.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Impl/WireFormatting.cs b/projects/RabbitMQ.Client/Impl/WireFormatting.cs index 3a43a7b578..9af474dafb 100644 --- a/projects/RabbitMQ.Client/Impl/WireFormatting.cs +++ b/projects/RabbitMQ.Client/Impl/WireFormatting.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Text; diff --git a/projects/RabbitMQ.Client/InternalConstants.cs b/projects/RabbitMQ.Client/InternalConstants.cs index f61e0bb4ae..105ce297b7 100644 --- a/projects/RabbitMQ.Client/InternalConstants.cs +++ b/projects/RabbitMQ.Client/InternalConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Logging/ESLog.cs b/projects/RabbitMQ.Client/Logging/ESLog.cs index f3eee8e893..6221b3689d 100644 --- a/projects/RabbitMQ.Client/Logging/ESLog.cs +++ b/projects/RabbitMQ.Client/Logging/ESLog.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.Counters.cs b/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.Counters.cs index 9f63db3031..3bfac0185c 100644 --- a/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.Counters.cs +++ b/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.Counters.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Diagnostics.Tracing; diff --git a/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.cs b/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.cs index 87b628acb7..8cee14323f 100644 --- a/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.cs +++ b/projects/RabbitMQ.Client/Logging/RabbitMqClientEventSource.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Logging/RabbitMqExceptionDetail.cs b/projects/RabbitMQ.Client/Logging/RabbitMqExceptionDetail.cs index ecb46d52f3..294ab53481 100644 --- a/projects/RabbitMQ.Client/Logging/RabbitMqExceptionDetail.cs +++ b/projects/RabbitMQ.Client/Logging/RabbitMqExceptionDetail.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/PlainMechanism.cs b/projects/RabbitMQ.Client/PlainMechanism.cs index 30f45b045c..b5ca9b2f22 100644 --- a/projects/RabbitMQ.Client/PlainMechanism.cs +++ b/projects/RabbitMQ.Client/PlainMechanism.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Text; diff --git a/projects/RabbitMQ.Client/PlainMechanismFactory.cs b/projects/RabbitMQ.Client/PlainMechanismFactory.cs index 4eebf39704..aaf47bf94e 100644 --- a/projects/RabbitMQ.Client/PlainMechanismFactory.cs +++ b/projects/RabbitMQ.Client/PlainMechanismFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/Protocols.cs b/projects/RabbitMQ.Client/Protocols.cs index 504858a791..9c4da91a67 100644 --- a/projects/RabbitMQ.Client/Protocols.cs +++ b/projects/RabbitMQ.Client/Protocols.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/PublicationAddress.cs b/projects/RabbitMQ.Client/PublicationAddress.cs index 73afff532b..c2b99d6b82 100644 --- a/projects/RabbitMQ.Client/PublicationAddress.cs +++ b/projects/RabbitMQ.Client/PublicationAddress.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Diagnostics.CodeAnalysis; diff --git a/projects/RabbitMQ.Client/QueueDeclareOk.cs b/projects/RabbitMQ.Client/QueueDeclareOk.cs index bf7770a1cb..ad334162c8 100644 --- a/projects/RabbitMQ.Client/QueueDeclareOk.cs +++ b/projects/RabbitMQ.Client/QueueDeclareOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/RabbitMQ.Client.csproj b/projects/RabbitMQ.Client/RabbitMQ.Client.csproj index 1ddf4cad9b..d552e63244 100644 --- a/projects/RabbitMQ.Client/RabbitMQ.Client.csproj +++ b/projects/RabbitMQ.Client/RabbitMQ.Client.csproj @@ -9,7 +9,7 @@ RabbitMQ Client Library for .NET Broadcom Broadcom, Inc. or its subsidiaries. - Copyright (c) 2007-2024 Broadcom. All Rights Reserved. The term "Broadcom" refers to Broadcom Inc. and/or its subsidiaries. + Copyright (c) 2007-2025 Broadcom. All Rights Reserved. The term "Broadcom" refers to Broadcom Inc. and/or its subsidiaries. The RabbitMQ .NET client is the official client library for C# (and, implicitly, other .NET languages) true icon.png diff --git a/projects/RabbitMQ.Client/ReadonlyBasicProperties.cs b/projects/RabbitMQ.Client/ReadonlyBasicProperties.cs index a0651473a5..4d66fd3775 100644 --- a/projects/RabbitMQ.Client/ReadonlyBasicProperties.cs +++ b/projects/RabbitMQ.Client/ReadonlyBasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/RentedMemory.cs b/projects/RabbitMQ.Client/RentedMemory.cs index c78955731c..66f16d53c1 100644 --- a/projects/RabbitMQ.Client/RentedMemory.cs +++ b/projects/RabbitMQ.Client/RentedMemory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ShutdownInitiator.cs b/projects/RabbitMQ.Client/ShutdownInitiator.cs index 5fb231483e..9fc3685ac5 100644 --- a/projects/RabbitMQ.Client/ShutdownInitiator.cs +++ b/projects/RabbitMQ.Client/ShutdownInitiator.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/ShutdownReportEntry.cs b/projects/RabbitMQ.Client/ShutdownReportEntry.cs index 104286a793..5f8693790a 100644 --- a/projects/RabbitMQ.Client/ShutdownReportEntry.cs +++ b/projects/RabbitMQ.Client/ShutdownReportEntry.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/SslOption.cs b/projects/RabbitMQ.Client/SslOption.cs index 682c00ba83..cb067cccb4 100644 --- a/projects/RabbitMQ.Client/SslOption.cs +++ b/projects/RabbitMQ.Client/SslOption.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- diff --git a/projects/RabbitMQ.Client/TaskExtensions.cs b/projects/RabbitMQ.Client/TaskExtensions.cs index 458957217d..1dc042de7d 100644 --- a/projects/RabbitMQ.Client/TaskExtensions.cs +++ b/projects/RabbitMQ.Client/TaskExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/ThrottlingRateLimiter.cs b/projects/RabbitMQ.Client/ThrottlingRateLimiter.cs index 71dc2fd059..b6bd998027 100644 --- a/projects/RabbitMQ.Client/ThrottlingRateLimiter.cs +++ b/projects/RabbitMQ.Client/ThrottlingRateLimiter.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/TypeExtensions.cs b/projects/RabbitMQ.Client/TypeExtensions.cs index 97f913911b..9df5be2979 100644 --- a/projects/RabbitMQ.Client/TypeExtensions.cs +++ b/projects/RabbitMQ.Client/TypeExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Util/IntAllocator.cs b/projects/RabbitMQ.Client/Util/IntAllocator.cs index ed8bf0a170..1476988346 100644 --- a/projects/RabbitMQ.Client/Util/IntAllocator.cs +++ b/projects/RabbitMQ.Client/Util/IntAllocator.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Util/NetworkOrderDeserializer.cs b/projects/RabbitMQ.Client/Util/NetworkOrderDeserializer.cs index 77e0791704..d124a22b61 100644 --- a/projects/RabbitMQ.Client/Util/NetworkOrderDeserializer.cs +++ b/projects/RabbitMQ.Client/Util/NetworkOrderDeserializer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/Util/NetworkOrderSerializer.cs b/projects/RabbitMQ.Client/Util/NetworkOrderSerializer.cs index 5dad955b19..205cb09e1f 100644 --- a/projects/RabbitMQ.Client/Util/NetworkOrderSerializer.cs +++ b/projects/RabbitMQ.Client/Util/NetworkOrderSerializer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/IntegrationFixture.cs b/projects/Test/Common/IntegrationFixture.cs index 8adfbdae9e..3251fd7f73 100644 --- a/projects/Test/Common/IntegrationFixture.cs +++ b/projects/Test/Common/IntegrationFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/ProcessUtil.cs b/projects/Test/Common/ProcessUtil.cs index c1bc25b9b7..bf973f5c41 100644 --- a/projects/Test/Common/ProcessUtil.cs +++ b/projects/Test/Common/ProcessUtil.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/RabbitMQCtl.cs b/projects/Test/Common/RabbitMQCtl.cs index fbb204af3b..058dc72eae 100644 --- a/projects/Test/Common/RabbitMQCtl.cs +++ b/projects/Test/Common/RabbitMQCtl.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/SslEnv.cs b/projects/Test/Common/SslEnv.cs index aa5b6e8b10..a855cf0e26 100644 --- a/projects/Test/Common/SslEnv.cs +++ b/projects/Test/Common/SslEnv.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TestConnectionRecoveryBase.cs b/projects/Test/Common/TestConnectionRecoveryBase.cs index c6b3fbf2c6..4de9f871a0 100644 --- a/projects/Test/Common/TestConnectionRecoveryBase.cs +++ b/projects/Test/Common/TestConnectionRecoveryBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TestOutputWriter.cs b/projects/Test/Common/TestOutputWriter.cs index d2c3ee63ca..4290cea053 100644 --- a/projects/Test/Common/TestOutputWriter.cs +++ b/projects/Test/Common/TestOutputWriter.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TestOutputWriterEventListener.cs b/projects/Test/Common/TestOutputWriterEventListener.cs index 43d18f57af..3d5ae580de 100644 --- a/projects/Test/Common/TestOutputWriterEventListener.cs +++ b/projects/Test/Common/TestOutputWriterEventListener.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TimingFixture.cs b/projects/Test/Common/TimingFixture.cs index bd4a7d7bbf..73bb3e819a 100644 --- a/projects/Test/Common/TimingFixture.cs +++ b/projects/Test/Common/TimingFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestRecoveryEventHandlers.cs b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestRecoveryEventHandlers.cs index a68c786b53..5a0f2fadaf 100644 --- a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestRecoveryEventHandlers.cs +++ b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestRecoveryEventHandlers.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestShutdownEventHandlers.cs b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestShutdownEventHandlers.cs index 98c1c70903..7b300a3758 100644 --- a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestShutdownEventHandlers.cs +++ b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Channel/TestShutdownEventHandlers.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoveringConsumerEventHandlers.cs b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoveringConsumerEventHandlers.cs index fb5d50c738..884cce25b7 100644 --- a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoveringConsumerEventHandlers.cs +++ b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoveringConsumerEventHandlers.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoverySucceededEventHandlers.cs b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoverySucceededEventHandlers.cs index 0d5c09b4c7..0ec85fc25c 100644 --- a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoverySucceededEventHandlers.cs +++ b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestRecoverySucceededEventHandlers.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestShutdownEventHandlers.cs b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestShutdownEventHandlers.cs index b4b509a45b..54436a17e3 100644 --- a/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestShutdownEventHandlers.cs +++ b/projects/Test/Integration/ConnectionRecovery/EventHandlerRecovery/Connection/TestShutdownEventHandlers.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/Test/Integration/ConnectionRecovery/TestBasicAckAndBasicNack.cs b/projects/Test/Integration/ConnectionRecovery/TestBasicAckAndBasicNack.cs index b45c7271e8..36499d6d0b 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestBasicAckAndBasicNack.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestBasicAckAndBasicNack.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/ConnectionRecovery/TestBasicConnectionRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestBasicConnectionRecovery.cs index 0f5b5da5be..58da7d2881 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestBasicConnectionRecovery.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestBasicConnectionRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/ConnectionRecovery/TestConnectionRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestConnectionRecovery.cs index 4e516bbbfd..bb99e04525 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestConnectionRecovery.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestConnectionRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/ConnectionRecovery/TestConsumerRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestConsumerRecovery.cs index 60735445b3..02ece50308 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestConsumerRecovery.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestConsumerRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/ConnectionRecovery/TestDeclaration.cs b/projects/Test/Integration/ConnectionRecovery/TestDeclaration.cs index af65cc5940..e6dc150dd8 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestDeclaration.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestDeclaration.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/ConnectionRecovery/TestExchangeRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestExchangeRecovery.cs index a2aac17c35..22cfeb4331 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestExchangeRecovery.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestExchangeRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/ConnectionRecovery/TestQueueRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestQueueRecovery.cs index 2795836cc5..fe7b30cec1 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestQueueRecovery.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestQueueRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/ConnectionRecovery/TestQueueRecoveryWithArguments.cs b/projects/Test/Integration/ConnectionRecovery/TestQueueRecoveryWithArguments.cs index c04b550722..d6941ae81c 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestQueueRecoveryWithArguments.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestQueueRecoveryWithArguments.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/ConnectionRecovery/TestRecoveryWithDeletedEntities.cs b/projects/Test/Integration/ConnectionRecovery/TestRecoveryWithDeletedEntities.cs index 8f7ea095e4..eca786000a 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestRecoveryWithDeletedEntities.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestRecoveryWithDeletedEntities.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/ConnectionRecovery/TestRpcAfterRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestRpcAfterRecovery.cs index 874b39f20f..badbac6049 100644 --- a/projects/Test/Integration/ConnectionRecovery/TestRpcAfterRecovery.cs +++ b/projects/Test/Integration/ConnectionRecovery/TestRpcAfterRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAsyncConsumer.cs b/projects/Test/Integration/TestAsyncConsumer.cs index 2b658de6c4..6210509b38 100644 --- a/projects/Test/Integration/TestAsyncConsumer.cs +++ b/projects/Test/Integration/TestAsyncConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAsyncConsumerCancelNotify.cs b/projects/Test/Integration/TestAsyncConsumerCancelNotify.cs index 793f054ce5..55ebff8f36 100644 --- a/projects/Test/Integration/TestAsyncConsumerCancelNotify.cs +++ b/projects/Test/Integration/TestAsyncConsumerCancelNotify.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Linq; diff --git a/projects/Test/Integration/TestAsyncConsumerCount.cs b/projects/Test/Integration/TestAsyncConsumerCount.cs index c83e916fe3..42d8b1b1b1 100644 --- a/projects/Test/Integration/TestAsyncConsumerCount.cs +++ b/projects/Test/Integration/TestAsyncConsumerCount.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestAsyncConsumerExceptions.cs b/projects/Test/Integration/TestAsyncConsumerExceptions.cs index b3d2386974..9d5db16440 100644 --- a/projects/Test/Integration/TestAsyncConsumerExceptions.cs +++ b/projects/Test/Integration/TestAsyncConsumerExceptions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAsyncConsumerOperationDispatch.cs b/projects/Test/Integration/TestAsyncConsumerOperationDispatch.cs index 0b3234822a..b55cc76bb7 100644 --- a/projects/Test/Integration/TestAsyncConsumerOperationDispatch.cs +++ b/projects/Test/Integration/TestAsyncConsumerOperationDispatch.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs b/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs index e20c7ceb83..d714433fd9 100644 --- a/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs +++ b/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAuth.cs b/projects/Test/Integration/TestAuth.cs index 57aff7d821..fa90f5a256 100644 --- a/projects/Test/Integration/TestAuth.cs +++ b/projects/Test/Integration/TestAuth.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestBasicGet.cs b/projects/Test/Integration/TestBasicGet.cs index 6afcef81db..9f81fecc3d 100644 --- a/projects/Test/Integration/TestBasicGet.cs +++ b/projects/Test/Integration/TestBasicGet.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestBasicPublish.cs b/projects/Test/Integration/TestBasicPublish.cs index 139029bd37..f97632e528 100644 --- a/projects/Test/Integration/TestBasicPublish.cs +++ b/projects/Test/Integration/TestBasicPublish.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestBasicPublishAsync.cs b/projects/Test/Integration/TestBasicPublishAsync.cs index 072e2a6323..25de62eb70 100644 --- a/projects/Test/Integration/TestBasicPublishAsync.cs +++ b/projects/Test/Integration/TestBasicPublishAsync.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestChannelAllocation.cs b/projects/Test/Integration/TestChannelAllocation.cs index ddd43b4872..b061edb357 100644 --- a/projects/Test/Integration/TestChannelAllocation.cs +++ b/projects/Test/Integration/TestChannelAllocation.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/TestChannelShutdown.cs b/projects/Test/Integration/TestChannelShutdown.cs index 37af0ec193..1774555b30 100644 --- a/projects/Test/Integration/TestChannelShutdown.cs +++ b/projects/Test/Integration/TestChannelShutdown.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestChannelSoftErrors.cs b/projects/Test/Integration/TestChannelSoftErrors.cs index 1ab02d84fe..2cefd12cc8 100644 --- a/projects/Test/Integration/TestChannelSoftErrors.cs +++ b/projects/Test/Integration/TestChannelSoftErrors.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestConcurrentAccessBase.cs.cs b/projects/Test/Integration/TestConcurrentAccessBase.cs.cs index 0aa538c998..4353c48313 100644 --- a/projects/Test/Integration/TestConcurrentAccessBase.cs.cs +++ b/projects/Test/Integration/TestConcurrentAccessBase.cs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConcurrentAccessWithSharedChannel.cs b/projects/Test/Integration/TestConcurrentAccessWithSharedChannel.cs index 71fd7bfaf3..b033839a15 100644 --- a/projects/Test/Integration/TestConcurrentAccessWithSharedChannel.cs +++ b/projects/Test/Integration/TestConcurrentAccessWithSharedChannel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs b/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs index 348477cd56..0bc3b043f0 100644 --- a/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs +++ b/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConfirmSelect.cs b/projects/Test/Integration/TestConfirmSelect.cs index 3db7e37a1f..514a01a351 100644 --- a/projects/Test/Integration/TestConfirmSelect.cs +++ b/projects/Test/Integration/TestConfirmSelect.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConfirmSelectAsync.cs b/projects/Test/Integration/TestConfirmSelectAsync.cs index 0502185e2d..1903f90e97 100644 --- a/projects/Test/Integration/TestConfirmSelectAsync.cs +++ b/projects/Test/Integration/TestConfirmSelectAsync.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionFactory.cs b/projects/Test/Integration/TestConnectionFactory.cs index dd5a5cd236..3a17efcd9f 100644 --- a/projects/Test/Integration/TestConnectionFactory.cs +++ b/projects/Test/Integration/TestConnectionFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs b/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs index 7930cb9963..f034af2c73 100644 --- a/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs +++ b/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs b/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs index d37936eada..9990d99f55 100644 --- a/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs +++ b/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionShutdown.cs b/projects/Test/Integration/TestConnectionShutdown.cs index 78abffd0ab..0a7a380b87 100644 --- a/projects/Test/Integration/TestConnectionShutdown.cs +++ b/projects/Test/Integration/TestConnectionShutdown.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionTopologyRecovery.cs b/projects/Test/Integration/TestConnectionTopologyRecovery.cs index 2faafeb6d3..048879d622 100644 --- a/projects/Test/Integration/TestConnectionTopologyRecovery.cs +++ b/projects/Test/Integration/TestConnectionTopologyRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestExceptionMessages.cs b/projects/Test/Integration/TestExceptionMessages.cs index 36180f19d3..8ee6bc621e 100644 --- a/projects/Test/Integration/TestExceptionMessages.cs +++ b/projects/Test/Integration/TestExceptionMessages.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestExchangeDeclare.cs b/projects/Test/Integration/TestExchangeDeclare.cs index ef21255f24..351a0e230b 100644 --- a/projects/Test/Integration/TestExchangeDeclare.cs +++ b/projects/Test/Integration/TestExchangeDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestExtensions.cs b/projects/Test/Integration/TestExtensions.cs index c72f49d4a4..1258c36a7f 100644 --- a/projects/Test/Integration/TestExtensions.cs +++ b/projects/Test/Integration/TestExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestFloodPublishing.cs b/projects/Test/Integration/TestFloodPublishing.cs index 3d587d6d2c..5b700ed519 100644 --- a/projects/Test/Integration/TestFloodPublishing.cs +++ b/projects/Test/Integration/TestFloodPublishing.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestInitialConnection.cs b/projects/Test/Integration/TestInitialConnection.cs index d488ce40d2..a78c5beb13 100644 --- a/projects/Test/Integration/TestInitialConnection.cs +++ b/projects/Test/Integration/TestInitialConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/TestInvalidAck.cs b/projects/Test/Integration/TestInvalidAck.cs index 82688f8939..ff439cff14 100644 --- a/projects/Test/Integration/TestInvalidAck.cs +++ b/projects/Test/Integration/TestInvalidAck.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestMainLoop.cs b/projects/Test/Integration/TestMainLoop.cs index 321f26bac6..54f5805b37 100644 --- a/projects/Test/Integration/TestMainLoop.cs +++ b/projects/Test/Integration/TestMainLoop.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestMessageCount.cs b/projects/Test/Integration/TestMessageCount.cs index 363328374a..50e64d02c4 100644 --- a/projects/Test/Integration/TestMessageCount.cs +++ b/projects/Test/Integration/TestMessageCount.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestNowait.cs b/projects/Test/Integration/TestNowait.cs index 3114009885..1199262302 100644 --- a/projects/Test/Integration/TestNowait.cs +++ b/projects/Test/Integration/TestNowait.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestPassiveDeclare.cs b/projects/Test/Integration/TestPassiveDeclare.cs index 67738cfbd6..205d9ad8be 100644 --- a/projects/Test/Integration/TestPassiveDeclare.cs +++ b/projects/Test/Integration/TestPassiveDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestPublishSharedChannelAsync.cs b/projects/Test/Integration/TestPublishSharedChannelAsync.cs index 1378c7bc0c..0849a69915 100644 --- a/projects/Test/Integration/TestPublishSharedChannelAsync.cs +++ b/projects/Test/Integration/TestPublishSharedChannelAsync.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestPublisherConfirms.cs b/projects/Test/Integration/TestPublisherConfirms.cs index d6a551b309..b5cb7bd71c 100644 --- a/projects/Test/Integration/TestPublisherConfirms.cs +++ b/projects/Test/Integration/TestPublisherConfirms.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/TestQueueDeclare.cs b/projects/Test/Integration/TestQueueDeclare.cs index 79d0c9106d..94e758a64d 100644 --- a/projects/Test/Integration/TestQueueDeclare.cs +++ b/projects/Test/Integration/TestQueueDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestSsl.cs b/projects/Test/Integration/TestSsl.cs index 676b317af5..0a06ecc4be 100644 --- a/projects/Test/Integration/TestSsl.cs +++ b/projects/Test/Integration/TestSsl.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.IO; diff --git a/projects/Test/Integration/TestToxiproxy.cs b/projects/Test/Integration/TestToxiproxy.cs index 1629dc69bd..4aeb219eca 100644 --- a/projects/Test/Integration/TestToxiproxy.cs +++ b/projects/Test/Integration/TestToxiproxy.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestUpdateSecret.cs b/projects/Test/Integration/TestUpdateSecret.cs index f4ebd65c3b..b87ca15d0f 100644 --- a/projects/Test/Integration/TestUpdateSecret.cs +++ b/projects/Test/Integration/TestUpdateSecret.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/OAuth2/MockOAuth2Client.cs b/projects/Test/OAuth2/MockOAuth2Client.cs index 0daecca708..9532d7f6d7 100644 --- a/projects/Test/OAuth2/MockOAuth2Client.cs +++ b/projects/Test/OAuth2/MockOAuth2Client.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/OAuth2/RequestFormMatcher.cs b/projects/Test/OAuth2/RequestFormMatcher.cs index ab6e47ba5c..b9b87c4a9c 100644 --- a/projects/Test/OAuth2/RequestFormMatcher.cs +++ b/projects/Test/OAuth2/RequestFormMatcher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/OAuth2/TestCredentialsRefresher.cs b/projects/Test/OAuth2/TestCredentialsRefresher.cs index d5c46b8918..dea26dfb25 100644 --- a/projects/Test/OAuth2/TestCredentialsRefresher.cs +++ b/projects/Test/OAuth2/TestCredentialsRefresher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/OAuth2/TestOAuth2.cs b/projects/Test/OAuth2/TestOAuth2.cs index b10ae8ccac..1f2fa1bca0 100644 --- a/projects/Test/OAuth2/TestOAuth2.cs +++ b/projects/Test/OAuth2/TestOAuth2.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/OAuth2/TestOAuth2Client.cs b/projects/Test/OAuth2/TestOAuth2Client.cs index 6f02b6136a..69612609b9 100644 --- a/projects/Test/OAuth2/TestOAuth2Client.cs +++ b/projects/Test/OAuth2/TestOAuth2Client.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs b/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs index 98ac2acf7f..9002f58e53 100644 --- a/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs +++ b/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs b/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs index 5eb8eca28c..153e164886 100644 --- a/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs +++ b/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestActivitySource.cs b/projects/Test/SequentialIntegration/TestActivitySource.cs index ec9cdcf31f..af84b39e75 100644 --- a/projects/Test/SequentialIntegration/TestActivitySource.cs +++ b/projects/Test/SequentialIntegration/TestActivitySource.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestConnectionBlocked.cs b/projects/Test/SequentialIntegration/TestConnectionBlocked.cs index 92c095768b..af630da45a 100644 --- a/projects/Test/SequentialIntegration/TestConnectionBlocked.cs +++ b/projects/Test/SequentialIntegration/TestConnectionBlocked.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs b/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs index 83641e2ace..30c252699b 100644 --- a/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs +++ b/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestConnectionRecovery.cs b/projects/Test/SequentialIntegration/TestConnectionRecovery.cs index 4c25108d26..e1e603b4c6 100644 --- a/projects/Test/SequentialIntegration/TestConnectionRecovery.cs +++ b/projects/Test/SequentialIntegration/TestConnectionRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestHeartbeats.cs b/projects/Test/SequentialIntegration/TestHeartbeats.cs index 7ef20b865a..976ccbb1d7 100644 --- a/projects/Test/SequentialIntegration/TestHeartbeats.cs +++ b/projects/Test/SequentialIntegration/TestHeartbeats.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestOpenTelemetry.cs b/projects/Test/SequentialIntegration/TestOpenTelemetry.cs index 4bfc541048..020c4ffd2d 100644 --- a/projects/Test/SequentialIntegration/TestOpenTelemetry.cs +++ b/projects/Test/SequentialIntegration/TestOpenTelemetry.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/DebugUtil.cs b/projects/Test/Unit/DebugUtil.cs index e7feb897a2..95eff06871 100644 --- a/projects/Test/Unit/DebugUtil.cs +++ b/projects/Test/Unit/DebugUtil.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs b/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs index f974991e21..6f29c58483 100644 --- a/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs +++ b/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestAmqpUri.cs b/projects/Test/Unit/TestAmqpUri.cs index 86b57b98a7..23cc012327 100644 --- a/projects/Test/Unit/TestAmqpUri.cs +++ b/projects/Test/Unit/TestAmqpUri.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestBasicProperties.cs b/projects/Test/Unit/TestBasicProperties.cs index 7e52af87a8..94dd53a0a3 100644 --- a/projects/Test/Unit/TestBasicProperties.cs +++ b/projects/Test/Unit/TestBasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestContentHeaderCodec.cs b/projects/Test/Unit/TestContentHeaderCodec.cs index dd57481a13..9c951b2fb9 100644 --- a/projects/Test/Unit/TestContentHeaderCodec.cs +++ b/projects/Test/Unit/TestContentHeaderCodec.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestFieldTableFormatting.cs b/projects/Test/Unit/TestFieldTableFormatting.cs index c65cc6bfb1..aac975b457 100644 --- a/projects/Test/Unit/TestFieldTableFormatting.cs +++ b/projects/Test/Unit/TestFieldTableFormatting.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestFieldTableFormattingGeneric.cs b/projects/Test/Unit/TestFieldTableFormattingGeneric.cs index d0a917ab96..ef37cba3c1 100644 --- a/projects/Test/Unit/TestFieldTableFormattingGeneric.cs +++ b/projects/Test/Unit/TestFieldTableFormattingGeneric.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- diff --git a/projects/Test/Unit/TestFrameFormatting.cs b/projects/Test/Unit/TestFrameFormatting.cs index d4ebcc993a..12e1a49e96 100644 --- a/projects/Test/Unit/TestFrameFormatting.cs +++ b/projects/Test/Unit/TestFrameFormatting.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestIEndpointResolverExtensions.cs b/projects/Test/Unit/TestIEndpointResolverExtensions.cs index 5e4bf40726..54606cfb1f 100644 --- a/projects/Test/Unit/TestIEndpointResolverExtensions.cs +++ b/projects/Test/Unit/TestIEndpointResolverExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestIntAllocator.cs b/projects/Test/Unit/TestIntAllocator.cs index a190d864ce..3dce15103a 100644 --- a/projects/Test/Unit/TestIntAllocator.cs +++ b/projects/Test/Unit/TestIntAllocator.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestMethodArgumentCodec.cs b/projects/Test/Unit/TestMethodArgumentCodec.cs index 4e91a23448..be1081cccf 100644 --- a/projects/Test/Unit/TestMethodArgumentCodec.cs +++ b/projects/Test/Unit/TestMethodArgumentCodec.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestNetworkByteOrderSerialization.cs b/projects/Test/Unit/TestNetworkByteOrderSerialization.cs index 97d38e7baa..235f265d1d 100644 --- a/projects/Test/Unit/TestNetworkByteOrderSerialization.cs +++ b/projects/Test/Unit/TestNetworkByteOrderSerialization.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestPublicationAddress.cs b/projects/Test/Unit/TestPublicationAddress.cs index 87f8a7cfbb..d4815b0eb6 100644 --- a/projects/Test/Unit/TestPublicationAddress.cs +++ b/projects/Test/Unit/TestPublicationAddress.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestRpcContinuationQueue.cs b/projects/Test/Unit/TestRpcContinuationQueue.cs index c84409f4b5..bb5d819a69 100644 --- a/projects/Test/Unit/TestRpcContinuationQueue.cs +++ b/projects/Test/Unit/TestRpcContinuationQueue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestTcpClientAdapter.cs b/projects/Test/Unit/TestTcpClientAdapter.cs index faeaeb4341..6aeff3fbb0 100644 --- a/projects/Test/Unit/TestTcpClientAdapter.cs +++ b/projects/Test/Unit/TestTcpClientAdapter.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Net; diff --git a/projects/Test/Unit/TimingFixture.cs b/projects/Test/Unit/TimingFixture.cs index d061251a75..10ab3ed361 100644 --- a/projects/Test/Unit/TimingFixture.cs +++ b/projects/Test/Unit/TimingFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/WireFormattingFixture.cs b/projects/Test/Unit/WireFormattingFixture.cs index e47e1ec295..2b89ce570c 100644 --- a/projects/Test/Unit/WireFormattingFixture.cs +++ b/projects/Test/Unit/WireFormattingFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. +// Copyright (c) 2007-2025 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System;