From 7c532d95f354502a87c01d1af5314246b829faf6 Mon Sep 17 00:00:00 2001 From: Luke Bakken Date: Mon, 3 Jun 2024 19:33:42 -0700 Subject: [PATCH 1/2] Update copyright message --- projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs | 4 ++-- .../RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs | 4 ++-- .../RabbitMQ.Client.OAuth2/RabbitMQ.Client.OAuth2.csproj | 2 +- .../FrameworkExtension/DictionaryExtension.cs | 4 ++-- projects/RabbitMQ.Client/RabbitMQ.Client.csproj | 2 +- projects/RabbitMQ.Client/client/RentedMemory.cs | 4 ++-- projects/RabbitMQ.Client/client/TaskExtensions.cs | 4 ++-- projects/RabbitMQ.Client/client/api/AmqpTcpEndpoint.cs | 4 ++-- projects/RabbitMQ.Client/client/api/AmqpTimestamp.cs | 4 ++-- .../RabbitMQ.Client/client/api/BasicCredentialsProvider.cs | 4 ++-- projects/RabbitMQ.Client/client/api/BasicGetResult.cs | 4 ++-- projects/RabbitMQ.Client/client/api/BasicProperties.cs | 4 ++-- projects/RabbitMQ.Client/client/api/BinaryTableValue.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ConnectionConfig.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ConnectionFactory.cs | 6 +++--- .../RabbitMQ.Client/client/api/ConnectionFactoryBase.cs | 4 ++-- projects/RabbitMQ.Client/client/api/DefaultBasicConsumer.cs | 4 ++-- .../RabbitMQ.Client/client/api/DefaultEndpointResolver.cs | 4 ++-- projects/RabbitMQ.Client/client/api/DeliveryModes.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ExchangeType.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ExternalMechanism.cs | 4 ++-- .../RabbitMQ.Client/client/api/ExternalMechanismFactory.cs | 4 ++-- projects/RabbitMQ.Client/client/api/Headers.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IAmqpHeader.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IAmqpWriteable.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IAuthMechanism.cs | 4 ++-- .../RabbitMQ.Client/client/api/IAuthMechanismFactory.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IBasicConsumer.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IBasicProperties.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IChannel.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IChannelExtensions.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IConnection.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IConnectionFactory.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ICredentialsProvider.cs | 4 ++-- .../RabbitMQ.Client/client/api/ICredentialsRefresher.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IEndpointResolver.cs | 4 ++-- .../client/api/IEndpointResolverExtensions.cs | 4 ++-- projects/RabbitMQ.Client/client/api/INetworkConnection.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IProtocol.cs | 4 ++-- projects/RabbitMQ.Client/client/api/IRecoverable.cs | 4 ++-- projects/RabbitMQ.Client/client/api/InternalConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/api/PlainMechanism.cs | 4 ++-- .../RabbitMQ.Client/client/api/PlainMechanismFactory.cs | 4 ++-- projects/RabbitMQ.Client/client/api/Protocols.cs | 4 ++-- projects/RabbitMQ.Client/client/api/PublicationAddress.cs | 4 ++-- projects/RabbitMQ.Client/client/api/QueueDeclareOk.cs | 4 ++-- .../RabbitMQ.Client/client/api/ReadonlyBasicProperties.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ShutdownEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ShutdownInitiator.cs | 4 ++-- projects/RabbitMQ.Client/client/api/ShutdownReportEntry.cs | 4 ++-- projects/RabbitMQ.Client/client/api/SslOption.cs | 4 ++-- projects/RabbitMQ.Client/client/events/AsyncEventHandler.cs | 4 ++-- projects/RabbitMQ.Client/client/events/BasicAckEventArgs.cs | 4 ++-- .../RabbitMQ.Client/client/events/BasicDeliverEventArgs.cs | 4 ++-- .../RabbitMQ.Client/client/events/BasicNackEventArgs.cs | 4 ++-- .../RabbitMQ.Client/client/events/BasicReturnEventArgs.cs | 4 ++-- .../client/events/CallbackExceptionEventArgs.cs | 4 ++-- .../client/events/ConnectionBlockedEventArgs.cs | 4 ++-- .../client/events/ConnectionRecoveryErrorEventArgs.cs | 4 ++-- projects/RabbitMQ.Client/client/events/ConsumerEventArgs.cs | 4 ++-- .../events/ConsumerTagChangedAfterRecoveryEventArgs.cs | 4 ++-- .../RabbitMQ.Client/client/events/EventingBasicConsumer.cs | 4 ++-- .../RabbitMQ.Client/client/events/FlowControlEventArgs.cs | 4 ++-- .../client/events/QueueNameChangedAfterRecoveryEventArgs.cs | 4 ++-- .../client/events/RecoveringConsumerEventArgs.cs | 4 ++-- .../client/exceptions/AlreadyClosedException.cs | 4 ++-- .../client/exceptions/AuthenticationFailureException.cs | 4 ++-- .../client/exceptions/BrokerUnreachableException.cs | 4 ++-- .../client/exceptions/ChannelAllocationException.cs | 4 ++-- .../client/exceptions/ConnectFailureException.cs | 4 ++-- .../client/exceptions/HardProtocolException.cs | 4 ++-- .../client/exceptions/MalformedFrameException.cs | 4 ++-- .../client/exceptions/OperationInterruptedException.cs | 4 ++-- .../client/exceptions/PacketNotRecognizedException.cs | 4 ++-- .../exceptions/PossibleAuthenticationFailureException.cs | 4 ++-- .../RabbitMQ.Client/client/exceptions/ProtocolException.cs | 4 ++-- .../client/exceptions/ProtocolVersionMismatchException.cs | 4 ++-- .../client/exceptions/ProtocolViolationException.cs | 4 ++-- .../client/exceptions/RabbitMQClientException.cs | 4 ++-- .../client/exceptions/SyntaxErrorException.cs | 4 ++-- .../client/exceptions/TopologyRecoveryException.cs | 4 ++-- .../client/exceptions/UnexpectedFrameException.cs | 4 ++-- .../client/exceptions/UnexpectedMethodException.cs | 4 ++-- .../client/exceptions/UnknownClassOrMethodException.cs | 4 ++-- .../client/exceptions/WireFormattingException.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicAck.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicCancel.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicCancelOk.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicConsume.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicConsumeOk.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicDeliver.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicGet.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicGetOk.cs | 4 ++-- .../RabbitMQ.Client/client/framing/BasicMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicNack.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicPublish.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicQos.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicReject.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/BasicReturn.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/Channel.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ChannelClose.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ChannelCloseOk.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ChannelFlow.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ChannelFlowOk.cs | 4 ++-- .../client/framing/ChannelMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ChannelOpen.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ClassConstants.cs | 4 ++-- .../client/framing/ConfirmMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ConfirmSelect.cs | 4 ++-- .../RabbitMQ.Client/client/framing/ConnectionBlocked.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ConnectionClose.cs | 4 ++-- .../RabbitMQ.Client/client/framing/ConnectionCloseOk.cs | 4 ++-- .../client/framing/ConnectionMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ConnectionOpen.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ConnectionSecure.cs | 4 ++-- .../RabbitMQ.Client/client/framing/ConnectionSecureOk.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ConnectionStart.cs | 4 ++-- .../RabbitMQ.Client/client/framing/ConnectionStartOk.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ConnectionTune.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ConnectionTuneOk.cs | 4 ++-- .../client/framing/ConnectionUpdateSecret.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/Constants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ExchangeBind.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ExchangeDeclare.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ExchangeDelete.cs | 4 ++-- .../client/framing/ExchangeMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/ExchangeUnbind.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/Protocol.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueueBind.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueueDeclare.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueueDeclareOk.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueueDelete.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueueDeleteOk.cs | 4 ++-- .../RabbitMQ.Client/client/framing/QueueMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueuePurge.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueuePurgeOk.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/QueueUnbind.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/TxCommit.cs | 4 ++-- .../RabbitMQ.Client/client/framing/TxMethodConstants.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/TxRollback.cs | 4 ++-- projects/RabbitMQ.Client/client/framing/TxSelect.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/AmqpVersion.cs | 4 ++-- .../RabbitMQ.Client/client/impl/AsyncRpcContinuations.cs | 4 ++-- .../RabbitMQ.Client/client/impl/AutorecoveringChannel.cs | 4 ++-- .../client/impl/AutorecoveringConnection.Recording.cs | 4 ++-- .../client/impl/AutorecoveringConnection.Recovery.cs | 4 ++-- .../RabbitMQ.Client/client/impl/AutorecoveringConnection.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/ChannelBase.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/CommandAssembler.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/Connection.Commands.cs | 4 ++-- .../RabbitMQ.Client/client/impl/Connection.Heartbeat.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/Connection.Receive.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/Connection.cs | 4 ++-- .../RabbitMQ.Client/client/impl/ConnectionSecureOrTune.cs | 4 ++-- .../RabbitMQ.Client/client/impl/ConnectionStartDetails.cs | 4 ++-- .../client/impl/ConsumerDispatching/IConsumerDispatcher.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/Frame.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/IFrameHandler.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/IRpcContinuation.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/ISession.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/IncomingCommand.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/MainSession.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/ProtocolBase.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/RecordedBinding.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/RecordedConsumer.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/RecordedExchange.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/RecordedQueue.cs | 4 ++-- .../RabbitMQ.Client/client/impl/RecoveryAwareChannel.cs | 4 ++-- .../RabbitMQ.Client/client/impl/RpcContinuationQueue.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/Session.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/SessionBase.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/SessionManager.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/SocketFrameHandler.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/SslHelper.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/WireFormatting.Read.cs | 4 ++-- .../RabbitMQ.Client/client/impl/WireFormatting.Write.cs | 4 ++-- projects/RabbitMQ.Client/client/impl/WireFormatting.cs | 4 ++-- projects/RabbitMQ.Client/client/logging/ESLog.cs | 4 ++-- .../client/logging/RabbitMqClientEventSource.Counters.cs | 4 ++-- .../client/logging/RabbitMqClientEventSource.cs | 4 ++-- .../client/logging/RabbitMqExceptionDetail.cs | 4 ++-- projects/RabbitMQ.Client/util/IntAllocator.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 ++-- .../Channel/TestRecoveryEventHandlers.cs | 4 ++-- .../Channel/TestShutdownEventHandlers.cs | 4 ++-- .../Connection/TestRecoveringConsumerEventHandlers.cs | 4 ++-- .../Connection/TestRecoverySucceededEventHandlers.cs | 4 ++-- .../Connection/TestShutdownEventHandlers.cs | 4 ++-- .../ConnectionRecovery/TestBasicAckAndBasicNack.cs | 4 ++-- .../ConnectionRecovery/TestBasicConnectionRecovery.cs | 4 ++-- .../ConnectionRecovery/TestConnectionRecovery.cs | 4 ++-- .../Integration/ConnectionRecovery/TestConsumerRecovery.cs | 4 ++-- .../Test/Integration/ConnectionRecovery/TestDeclaration.cs | 4 ++-- .../Integration/ConnectionRecovery/TestExchangeRecovery.cs | 4 ++-- .../Integration/ConnectionRecovery/TestQueueRecovery.cs | 4 ++-- .../ConnectionRecovery/TestRecoveryWithDeletedEntities.cs | 4 ++-- .../Integration/ConnectionRecovery/TestRpcAfterRecovery.cs | 4 ++-- projects/Test/Integration/TestAsyncConsumer.cs | 4 ++-- projects/Test/Integration/TestAsyncConsumerExceptions.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 ++-- .../Integration/TestConcurrentAccessWithSharedConnection.cs | 4 ++-- .../TestConcurrentAccessWithSharedConnectionAsync.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/TestConsumer.cs | 4 ++-- projects/Test/Integration/TestConsumerCancelNotify.cs | 4 ++-- projects/Test/Integration/TestConsumerCount.cs | 4 ++-- projects/Test/Integration/TestConsumerExceptions.cs | 4 ++-- projects/Test/Integration/TestConsumerOperationDispatch.cs | 4 ++-- projects/Test/Integration/TestEventingConsumer.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/RequestFormMatcher.cs | 4 ++-- projects/Test/OAuth2/TestOAuth2Client.cs | 4 ++-- projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs | 4 ++-- .../SequentialIntegration/SequentialIntegrationFixture.cs | 4 ++-- projects/Test/SequentialIntegration/TestActivitySource.cs | 4 ++-- .../Test/SequentialIntegration/TestConnectionBlocked.cs | 4 ++-- .../TestConnectionBlockedChannelLeak.cs | 4 ++-- .../Test/SequentialIntegration/TestConnectionRecovery.cs | 4 ++-- projects/Test/SequentialIntegration/TestHeartbeats.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/TestTimerBasedCredentialRefresher.cs | 4 ++-- projects/Test/Unit/TimingFixture.cs | 4 ++-- projects/Test/Unit/WireFormattingFixture.cs | 4 ++-- 272 files changed, 543 insertions(+), 543 deletions(-) diff --git a/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs b/projects/RabbitMQ.Client.OAuth2/OAuth2Client.cs index e6066b7d16..2598d3a4e7 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs b/projects/RabbitMQ.Client.OAuth2/OAuth2CredentialsProvider.cs index 08972f4e2f..f59b577a9b 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 a84837b455..0ef41ed346 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 VMware VMware, Inc. or its affiliates. - Copyright © 2007-2023 VMware, Inc. or its affiliates. + Copyright (c) 2007-2024 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/FrameworkExtension/DictionaryExtension.cs b/projects/RabbitMQ.Client/FrameworkExtension/DictionaryExtension.cs index 6b64c6242a..73f3bcce44 100644 --- a/projects/RabbitMQ.Client/FrameworkExtension/DictionaryExtension.cs +++ b/projects/RabbitMQ.Client/FrameworkExtension/DictionaryExtension.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/RabbitMQ.Client.csproj b/projects/RabbitMQ.Client/RabbitMQ.Client.csproj index 56cceae989..a0a0fca7e3 100644 --- a/projects/RabbitMQ.Client/RabbitMQ.Client.csproj +++ b/projects/RabbitMQ.Client/RabbitMQ.Client.csproj @@ -8,7 +8,7 @@ RabbitMQ Client Library for .NET VMware VMware, Inc. or its affiliates. - Copyright © 2007-2022 VMware, Inc. or its affiliates. + Copyright (c) 2007-2024 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/client/RentedMemory.cs b/projects/RabbitMQ.Client/client/RentedMemory.cs index 1c8d5059ad..d5a2684a85 100644 --- a/projects/RabbitMQ.Client/client/RentedMemory.cs +++ b/projects/RabbitMQ.Client/client/RentedMemory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/TaskExtensions.cs b/projects/RabbitMQ.Client/client/TaskExtensions.cs index 99d7511b82..1d28ac2c49 100644 --- a/projects/RabbitMQ.Client/client/TaskExtensions.cs +++ b/projects/RabbitMQ.Client/client/TaskExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/AmqpTcpEndpoint.cs b/projects/RabbitMQ.Client/client/api/AmqpTcpEndpoint.cs index 0e8b5934a2..ab10b21677 100644 --- a/projects/RabbitMQ.Client/client/api/AmqpTcpEndpoint.cs +++ b/projects/RabbitMQ.Client/client/api/AmqpTcpEndpoint.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/AmqpTimestamp.cs b/projects/RabbitMQ.Client/client/api/AmqpTimestamp.cs index e540f837ab..c908615af1 100644 --- a/projects/RabbitMQ.Client/client/api/AmqpTimestamp.cs +++ b/projects/RabbitMQ.Client/client/api/AmqpTimestamp.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/BasicCredentialsProvider.cs b/projects/RabbitMQ.Client/client/api/BasicCredentialsProvider.cs index 5357897529..28c1c9ac63 100644 --- a/projects/RabbitMQ.Client/client/api/BasicCredentialsProvider.cs +++ b/projects/RabbitMQ.Client/client/api/BasicCredentialsProvider.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/BasicGetResult.cs b/projects/RabbitMQ.Client/client/api/BasicGetResult.cs index aef3d51750..3e227f9666 100644 --- a/projects/RabbitMQ.Client/client/api/BasicGetResult.cs +++ b/projects/RabbitMQ.Client/client/api/BasicGetResult.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/BasicProperties.cs b/projects/RabbitMQ.Client/client/api/BasicProperties.cs index 9133b8b8be..f93128ed8c 100644 --- a/projects/RabbitMQ.Client/client/api/BasicProperties.cs +++ b/projects/RabbitMQ.Client/client/api/BasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/BinaryTableValue.cs b/projects/RabbitMQ.Client/client/api/BinaryTableValue.cs index a2abc1f424..d70ed52330 100644 --- a/projects/RabbitMQ.Client/client/api/BinaryTableValue.cs +++ b/projects/RabbitMQ.Client/client/api/BinaryTableValue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/ConnectionConfig.cs b/projects/RabbitMQ.Client/client/api/ConnectionConfig.cs index 7aeb12ce7d..bf3512a8fc 100644 --- a/projects/RabbitMQ.Client/client/api/ConnectionConfig.cs +++ b/projects/RabbitMQ.Client/client/api/ConnectionConfig.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs b/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs index 93c62e561e..06851fd532 100644 --- a/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs +++ b/projects/RabbitMQ.Client/client/api/ConnectionFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; @@ -306,7 +306,7 @@ public AmqpTcpEndpoint Endpoint ["product"] = Encoding.UTF8.GetBytes("RabbitMQ"), ["version"] = Encoding.UTF8.GetBytes(typeof(ConnectionFactory).Assembly.GetCustomAttribute().InformationalVersion), ["platform"] = Encoding.UTF8.GetBytes(".NET"), - ["copyright"] = Encoding.UTF8.GetBytes("Copyright (c) 2007-2020 VMware, Inc."), + ["copyright"] = Encoding.UTF8.GetBytes("Copyright (c) 2007-2023 Broadcom."), ["information"] = Encoding.UTF8.GetBytes("Licensed under the MPL. See https://www.rabbitmq.com/") }; diff --git a/projects/RabbitMQ.Client/client/api/ConnectionFactoryBase.cs b/projects/RabbitMQ.Client/client/api/ConnectionFactoryBase.cs index e9cddde907..e6d07e5ab1 100644 --- a/projects/RabbitMQ.Client/client/api/ConnectionFactoryBase.cs +++ b/projects/RabbitMQ.Client/client/api/ConnectionFactoryBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/DefaultBasicConsumer.cs b/projects/RabbitMQ.Client/client/api/DefaultBasicConsumer.cs index 6d7e6c5b9a..ef39d104ad 100644 --- a/projects/RabbitMQ.Client/client/api/DefaultBasicConsumer.cs +++ b/projects/RabbitMQ.Client/client/api/DefaultBasicConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/DefaultEndpointResolver.cs b/projects/RabbitMQ.Client/client/api/DefaultEndpointResolver.cs index 00c7fc3375..7da6b103e0 100644 --- a/projects/RabbitMQ.Client/client/api/DefaultEndpointResolver.cs +++ b/projects/RabbitMQ.Client/client/api/DefaultEndpointResolver.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/DeliveryModes.cs b/projects/RabbitMQ.Client/client/api/DeliveryModes.cs index 6dbfb7e9c7..094fde31ac 100644 --- a/projects/RabbitMQ.Client/client/api/DeliveryModes.cs +++ b/projects/RabbitMQ.Client/client/api/DeliveryModes.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/ExchangeType.cs b/projects/RabbitMQ.Client/client/api/ExchangeType.cs index b4e1035088..d2a16923a1 100644 --- a/projects/RabbitMQ.Client/client/api/ExchangeType.cs +++ b/projects/RabbitMQ.Client/client/api/ExchangeType.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/api/ExternalMechanism.cs b/projects/RabbitMQ.Client/client/api/ExternalMechanism.cs index 38b7d243f2..76bb9f14e4 100644 --- a/projects/RabbitMQ.Client/client/api/ExternalMechanism.cs +++ b/projects/RabbitMQ.Client/client/api/ExternalMechanism.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/ExternalMechanismFactory.cs b/projects/RabbitMQ.Client/client/api/ExternalMechanismFactory.cs index ade28631c8..d1f53476bf 100644 --- a/projects/RabbitMQ.Client/client/api/ExternalMechanismFactory.cs +++ b/projects/RabbitMQ.Client/client/api/ExternalMechanismFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/Headers.cs b/projects/RabbitMQ.Client/client/api/Headers.cs index e7fa505abe..4c896f8bb4 100644 --- a/projects/RabbitMQ.Client/client/api/Headers.cs +++ b/projects/RabbitMQ.Client/client/api/Headers.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/IAmqpHeader.cs b/projects/RabbitMQ.Client/client/api/IAmqpHeader.cs index 319de11ace..5925a2b84b 100644 --- a/projects/RabbitMQ.Client/client/api/IAmqpHeader.cs +++ b/projects/RabbitMQ.Client/client/api/IAmqpHeader.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/IAmqpWriteable.cs b/projects/RabbitMQ.Client/client/api/IAmqpWriteable.cs index db72f2813b..ec317b5c0b 100644 --- a/projects/RabbitMQ.Client/client/api/IAmqpWriteable.cs +++ b/projects/RabbitMQ.Client/client/api/IAmqpWriteable.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/IAuthMechanism.cs b/projects/RabbitMQ.Client/client/api/IAuthMechanism.cs index bae25110dd..963c6b4358 100644 --- a/projects/RabbitMQ.Client/client/api/IAuthMechanism.cs +++ b/projects/RabbitMQ.Client/client/api/IAuthMechanism.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/IAuthMechanismFactory.cs b/projects/RabbitMQ.Client/client/api/IAuthMechanismFactory.cs index 2863465193..fc848b1676 100644 --- a/projects/RabbitMQ.Client/client/api/IAuthMechanismFactory.cs +++ b/projects/RabbitMQ.Client/client/api/IAuthMechanismFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/IBasicConsumer.cs b/projects/RabbitMQ.Client/client/api/IBasicConsumer.cs index 7c796911db..e137415d4d 100644 --- a/projects/RabbitMQ.Client/client/api/IBasicConsumer.cs +++ b/projects/RabbitMQ.Client/client/api/IBasicConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/IBasicProperties.cs b/projects/RabbitMQ.Client/client/api/IBasicProperties.cs index c69670f55c..14610638c6 100644 --- a/projects/RabbitMQ.Client/client/api/IBasicProperties.cs +++ b/projects/RabbitMQ.Client/client/api/IBasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/api/IChannel.cs b/projects/RabbitMQ.Client/client/api/IChannel.cs index 175c1ccfd9..27facd5248 100644 --- a/projects/RabbitMQ.Client/client/api/IChannel.cs +++ b/projects/RabbitMQ.Client/client/api/IChannel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/IChannelExtensions.cs b/projects/RabbitMQ.Client/client/api/IChannelExtensions.cs index c71478a23b..38374d146f 100644 --- a/projects/RabbitMQ.Client/client/api/IChannelExtensions.cs +++ b/projects/RabbitMQ.Client/client/api/IChannelExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/IConnection.cs b/projects/RabbitMQ.Client/client/api/IConnection.cs index e47cc57f17..a699b9ce27 100644 --- a/projects/RabbitMQ.Client/client/api/IConnection.cs +++ b/projects/RabbitMQ.Client/client/api/IConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs b/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs index f80391d969..eb138ceab6 100644 --- a/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs +++ b/projects/RabbitMQ.Client/client/api/IConnectionFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/ICredentialsProvider.cs b/projects/RabbitMQ.Client/client/api/ICredentialsProvider.cs index 2bb365f80d..9cd57a3991 100644 --- a/projects/RabbitMQ.Client/client/api/ICredentialsProvider.cs +++ b/projects/RabbitMQ.Client/client/api/ICredentialsProvider.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/ICredentialsRefresher.cs b/projects/RabbitMQ.Client/client/api/ICredentialsRefresher.cs index 2d648f1f87..ac1d7f6427 100644 --- a/projects/RabbitMQ.Client/client/api/ICredentialsRefresher.cs +++ b/projects/RabbitMQ.Client/client/api/ICredentialsRefresher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/IEndpointResolver.cs b/projects/RabbitMQ.Client/client/api/IEndpointResolver.cs index 6cfbb70cbd..4838468267 100644 --- a/projects/RabbitMQ.Client/client/api/IEndpointResolver.cs +++ b/projects/RabbitMQ.Client/client/api/IEndpointResolver.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/api/IEndpointResolverExtensions.cs b/projects/RabbitMQ.Client/client/api/IEndpointResolverExtensions.cs index 75c4da2d6f..138928ff6f 100644 --- a/projects/RabbitMQ.Client/client/api/IEndpointResolverExtensions.cs +++ b/projects/RabbitMQ.Client/client/api/IEndpointResolverExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/INetworkConnection.cs b/projects/RabbitMQ.Client/client/api/INetworkConnection.cs index 04fdc3ff59..ee4d8e30e3 100644 --- a/projects/RabbitMQ.Client/client/api/INetworkConnection.cs +++ b/projects/RabbitMQ.Client/client/api/INetworkConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/IProtocol.cs b/projects/RabbitMQ.Client/client/api/IProtocol.cs index 10897ef2a7..0140abcc1f 100644 --- a/projects/RabbitMQ.Client/client/api/IProtocol.cs +++ b/projects/RabbitMQ.Client/client/api/IProtocol.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/IRecoverable.cs b/projects/RabbitMQ.Client/client/api/IRecoverable.cs index 86f086812c..6d8651c365 100644 --- a/projects/RabbitMQ.Client/client/api/IRecoverable.cs +++ b/projects/RabbitMQ.Client/client/api/IRecoverable.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/InternalConstants.cs b/projects/RabbitMQ.Client/client/api/InternalConstants.cs index ac611e4090..d70900def4 100644 --- a/projects/RabbitMQ.Client/client/api/InternalConstants.cs +++ b/projects/RabbitMQ.Client/client/api/InternalConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/PlainMechanism.cs b/projects/RabbitMQ.Client/client/api/PlainMechanism.cs index 964e624c29..7c4b374dff 100644 --- a/projects/RabbitMQ.Client/client/api/PlainMechanism.cs +++ b/projects/RabbitMQ.Client/client/api/PlainMechanism.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Text; diff --git a/projects/RabbitMQ.Client/client/api/PlainMechanismFactory.cs b/projects/RabbitMQ.Client/client/api/PlainMechanismFactory.cs index 5da08b3eac..4eebf39704 100644 --- a/projects/RabbitMQ.Client/client/api/PlainMechanismFactory.cs +++ b/projects/RabbitMQ.Client/client/api/PlainMechanismFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/Protocols.cs b/projects/RabbitMQ.Client/client/api/Protocols.cs index 507ea25127..504858a791 100644 --- a/projects/RabbitMQ.Client/client/api/Protocols.cs +++ b/projects/RabbitMQ.Client/client/api/Protocols.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/PublicationAddress.cs b/projects/RabbitMQ.Client/client/api/PublicationAddress.cs index 6af9dce657..44cd45d65d 100644 --- a/projects/RabbitMQ.Client/client/api/PublicationAddress.cs +++ b/projects/RabbitMQ.Client/client/api/PublicationAddress.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Text.RegularExpressions; diff --git a/projects/RabbitMQ.Client/client/api/QueueDeclareOk.cs b/projects/RabbitMQ.Client/client/api/QueueDeclareOk.cs index cfe2f6fa5e..bf7770a1cb 100644 --- a/projects/RabbitMQ.Client/client/api/QueueDeclareOk.cs +++ b/projects/RabbitMQ.Client/client/api/QueueDeclareOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/ReadonlyBasicProperties.cs b/projects/RabbitMQ.Client/client/api/ReadonlyBasicProperties.cs index 8b3623ef23..db03a79167 100644 --- a/projects/RabbitMQ.Client/client/api/ReadonlyBasicProperties.cs +++ b/projects/RabbitMQ.Client/client/api/ReadonlyBasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/ShutdownEventArgs.cs b/projects/RabbitMQ.Client/client/api/ShutdownEventArgs.cs index b076b9a346..f55686ecfa 100644 --- a/projects/RabbitMQ.Client/client/api/ShutdownEventArgs.cs +++ b/projects/RabbitMQ.Client/client/api/ShutdownEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/ShutdownInitiator.cs b/projects/RabbitMQ.Client/client/api/ShutdownInitiator.cs index 2a4226e63a..5fb231483e 100644 --- a/projects/RabbitMQ.Client/client/api/ShutdownInitiator.cs +++ b/projects/RabbitMQ.Client/client/api/ShutdownInitiator.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/api/ShutdownReportEntry.cs b/projects/RabbitMQ.Client/client/api/ShutdownReportEntry.cs index c4935c9ed3..09df9c29c0 100644 --- a/projects/RabbitMQ.Client/client/api/ShutdownReportEntry.cs +++ b/projects/RabbitMQ.Client/client/api/ShutdownReportEntry.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/api/SslOption.cs b/projects/RabbitMQ.Client/client/api/SslOption.cs index e72727c494..dae675be2b 100644 --- a/projects/RabbitMQ.Client/client/api/SslOption.cs +++ b/projects/RabbitMQ.Client/client/api/SslOption.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- diff --git a/projects/RabbitMQ.Client/client/events/AsyncEventHandler.cs b/projects/RabbitMQ.Client/client/events/AsyncEventHandler.cs index f172922eda..014d035c65 100644 --- a/projects/RabbitMQ.Client/client/events/AsyncEventHandler.cs +++ b/projects/RabbitMQ.Client/client/events/AsyncEventHandler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/RabbitMQ.Client/client/events/BasicAckEventArgs.cs b/projects/RabbitMQ.Client/client/events/BasicAckEventArgs.cs index b7a7cfe990..6919a2622a 100644 --- a/projects/RabbitMQ.Client/client/events/BasicAckEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/BasicAckEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/BasicDeliverEventArgs.cs b/projects/RabbitMQ.Client/client/events/BasicDeliverEventArgs.cs index 9d0585cc24..72cbc3567f 100644 --- a/projects/RabbitMQ.Client/client/events/BasicDeliverEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/BasicDeliverEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/BasicNackEventArgs.cs b/projects/RabbitMQ.Client/client/events/BasicNackEventArgs.cs index 60f4d9cfc9..292e42cfbc 100644 --- a/projects/RabbitMQ.Client/client/events/BasicNackEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/BasicNackEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/BasicReturnEventArgs.cs b/projects/RabbitMQ.Client/client/events/BasicReturnEventArgs.cs index 2a0bea1e13..585b1b6729 100644 --- a/projects/RabbitMQ.Client/client/events/BasicReturnEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/BasicReturnEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/CallbackExceptionEventArgs.cs b/projects/RabbitMQ.Client/client/events/CallbackExceptionEventArgs.cs index 145e4255c5..f0c04b44fe 100644 --- a/projects/RabbitMQ.Client/client/events/CallbackExceptionEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/CallbackExceptionEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/ConnectionBlockedEventArgs.cs b/projects/RabbitMQ.Client/client/events/ConnectionBlockedEventArgs.cs index 9ea17c6d9f..bbb0a28a40 100644 --- a/projects/RabbitMQ.Client/client/events/ConnectionBlockedEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/ConnectionBlockedEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/ConnectionRecoveryErrorEventArgs.cs b/projects/RabbitMQ.Client/client/events/ConnectionRecoveryErrorEventArgs.cs index 8252036a84..39559641c3 100644 --- a/projects/RabbitMQ.Client/client/events/ConnectionRecoveryErrorEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/ConnectionRecoveryErrorEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/ConsumerEventArgs.cs b/projects/RabbitMQ.Client/client/events/ConsumerEventArgs.cs index 13b354174c..4274be57cb 100644 --- a/projects/RabbitMQ.Client/client/events/ConsumerEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/ConsumerEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/ConsumerTagChangedAfterRecoveryEventArgs.cs b/projects/RabbitMQ.Client/client/events/ConsumerTagChangedAfterRecoveryEventArgs.cs index 864b89cd14..2c22593352 100644 --- a/projects/RabbitMQ.Client/client/events/ConsumerTagChangedAfterRecoveryEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/ConsumerTagChangedAfterRecoveryEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/EventingBasicConsumer.cs b/projects/RabbitMQ.Client/client/events/EventingBasicConsumer.cs index ca57918fce..6a8d6c8fe6 100644 --- a/projects/RabbitMQ.Client/client/events/EventingBasicConsumer.cs +++ b/projects/RabbitMQ.Client/client/events/EventingBasicConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/FlowControlEventArgs.cs b/projects/RabbitMQ.Client/client/events/FlowControlEventArgs.cs index 2d3ecd156b..5c246ab191 100644 --- a/projects/RabbitMQ.Client/client/events/FlowControlEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/FlowControlEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/QueueNameChangedAfterRecoveryEventArgs.cs b/projects/RabbitMQ.Client/client/events/QueueNameChangedAfterRecoveryEventArgs.cs index 3edc891368..bdeabcc77f 100644 --- a/projects/RabbitMQ.Client/client/events/QueueNameChangedAfterRecoveryEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/QueueNameChangedAfterRecoveryEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/events/RecoveringConsumerEventArgs.cs b/projects/RabbitMQ.Client/client/events/RecoveringConsumerEventArgs.cs index 54082ff018..16d11cf5e0 100644 --- a/projects/RabbitMQ.Client/client/events/RecoveringConsumerEventArgs.cs +++ b/projects/RabbitMQ.Client/client/events/RecoveringConsumerEventArgs.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2023 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2023 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/exceptions/AlreadyClosedException.cs b/projects/RabbitMQ.Client/client/exceptions/AlreadyClosedException.cs index 43776cb61d..726c16ca5f 100644 --- a/projects/RabbitMQ.Client/client/exceptions/AlreadyClosedException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/AlreadyClosedException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/AuthenticationFailureException.cs b/projects/RabbitMQ.Client/client/exceptions/AuthenticationFailureException.cs index 7b04d7d42a..4f7b736f19 100644 --- a/projects/RabbitMQ.Client/client/exceptions/AuthenticationFailureException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/AuthenticationFailureException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2013-2020 VMware, Inc. or its affiliates. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/BrokerUnreachableException.cs b/projects/RabbitMQ.Client/client/exceptions/BrokerUnreachableException.cs index ab80e25702..caa06ac9c4 100644 --- a/projects/RabbitMQ.Client/client/exceptions/BrokerUnreachableException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/BrokerUnreachableException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/ChannelAllocationException.cs b/projects/RabbitMQ.Client/client/exceptions/ChannelAllocationException.cs index a28acbe59e..9af300fbb3 100644 --- a/projects/RabbitMQ.Client/client/exceptions/ChannelAllocationException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/ChannelAllocationException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/ConnectFailureException.cs b/projects/RabbitMQ.Client/client/exceptions/ConnectFailureException.cs index 5d0599617a..e8f6e197cd 100644 --- a/projects/RabbitMQ.Client/client/exceptions/ConnectFailureException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/ConnectFailureException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/HardProtocolException.cs b/projects/RabbitMQ.Client/client/exceptions/HardProtocolException.cs index aa8010f612..e055f04215 100644 --- a/projects/RabbitMQ.Client/client/exceptions/HardProtocolException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/HardProtocolException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/client/exceptions/MalformedFrameException.cs b/projects/RabbitMQ.Client/client/exceptions/MalformedFrameException.cs index a1eac6ac47..3a52926958 100644 --- a/projects/RabbitMQ.Client/client/exceptions/MalformedFrameException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/MalformedFrameException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/client/exceptions/OperationInterruptedException.cs b/projects/RabbitMQ.Client/client/exceptions/OperationInterruptedException.cs index 5c5587bf62..83a2528afc 100644 --- a/projects/RabbitMQ.Client/client/exceptions/OperationInterruptedException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/OperationInterruptedException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/PacketNotRecognizedException.cs b/projects/RabbitMQ.Client/client/exceptions/PacketNotRecognizedException.cs index 487792ee60..7d212542ef 100644 --- a/projects/RabbitMQ.Client/client/exceptions/PacketNotRecognizedException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/PacketNotRecognizedException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/PossibleAuthenticationFailureException.cs b/projects/RabbitMQ.Client/client/exceptions/PossibleAuthenticationFailureException.cs index e6b2ec481b..feeb54a036 100644 --- a/projects/RabbitMQ.Client/client/exceptions/PossibleAuthenticationFailureException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/PossibleAuthenticationFailureException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/ProtocolException.cs b/projects/RabbitMQ.Client/client/exceptions/ProtocolException.cs index f24d297029..f0fd153271 100644 --- a/projects/RabbitMQ.Client/client/exceptions/ProtocolException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/ProtocolException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/client/exceptions/ProtocolVersionMismatchException.cs b/projects/RabbitMQ.Client/client/exceptions/ProtocolVersionMismatchException.cs index dc430a0660..a87fd0d988 100644 --- a/projects/RabbitMQ.Client/client/exceptions/ProtocolVersionMismatchException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/ProtocolVersionMismatchException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/ProtocolViolationException.cs b/projects/RabbitMQ.Client/client/exceptions/ProtocolViolationException.cs index b5bc9826ec..249ab78b65 100644 --- a/projects/RabbitMQ.Client/client/exceptions/ProtocolViolationException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/ProtocolViolationException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/RabbitMQClientException.cs b/projects/RabbitMQ.Client/client/exceptions/RabbitMQClientException.cs index 99f1a3a7b3..c8a5371154 100644 --- a/projects/RabbitMQ.Client/client/exceptions/RabbitMQClientException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/RabbitMQClientException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/SyntaxErrorException.cs b/projects/RabbitMQ.Client/client/exceptions/SyntaxErrorException.cs index 61f3688dd9..37f6611a63 100644 --- a/projects/RabbitMQ.Client/client/exceptions/SyntaxErrorException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/SyntaxErrorException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/client/exceptions/TopologyRecoveryException.cs b/projects/RabbitMQ.Client/client/exceptions/TopologyRecoveryException.cs index 0c494c7213..e4ffc1b614 100644 --- a/projects/RabbitMQ.Client/client/exceptions/TopologyRecoveryException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/TopologyRecoveryException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/UnexpectedFrameException.cs b/projects/RabbitMQ.Client/client/exceptions/UnexpectedFrameException.cs index e04f874429..e7dc8d48e8 100644 --- a/projects/RabbitMQ.Client/client/exceptions/UnexpectedFrameException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/UnexpectedFrameException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using RabbitMQ.Client.Impl; diff --git a/projects/RabbitMQ.Client/client/exceptions/UnexpectedMethodException.cs b/projects/RabbitMQ.Client/client/exceptions/UnexpectedMethodException.cs index 6b397e1d0f..cf2cf6d350 100644 --- a/projects/RabbitMQ.Client/client/exceptions/UnexpectedMethodException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/UnexpectedMethodException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/exceptions/UnknownClassOrMethodException.cs b/projects/RabbitMQ.Client/client/exceptions/UnknownClassOrMethodException.cs index 999d71c6a8..3f796c7e78 100644 --- a/projects/RabbitMQ.Client/client/exceptions/UnknownClassOrMethodException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/UnknownClassOrMethodException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Exceptions diff --git a/projects/RabbitMQ.Client/client/exceptions/WireFormattingException.cs b/projects/RabbitMQ.Client/client/exceptions/WireFormattingException.cs index 3d879f19ec..229805624b 100644 --- a/projects/RabbitMQ.Client/client/exceptions/WireFormattingException.cs +++ b/projects/RabbitMQ.Client/client/exceptions/WireFormattingException.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicAck.cs b/projects/RabbitMQ.Client/client/framing/BasicAck.cs index 027257e525..aa7bc7f745 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicAck.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicAck.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicCancel.cs b/projects/RabbitMQ.Client/client/framing/BasicCancel.cs index bec131c4e7..7eae54d0b4 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicCancel.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicCancel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicCancelOk.cs b/projects/RabbitMQ.Client/client/framing/BasicCancelOk.cs index a6fa8df152..7266679235 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicCancelOk.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicCancelOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicConsume.cs b/projects/RabbitMQ.Client/client/framing/BasicConsume.cs index 05e0234704..b44b6ec25e 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicConsume.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicConsume.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicConsumeOk.cs b/projects/RabbitMQ.Client/client/framing/BasicConsumeOk.cs index c8e325adec..77ae494a9d 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicConsumeOk.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicConsumeOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicDeliver.cs b/projects/RabbitMQ.Client/client/framing/BasicDeliver.cs index ebc49cd4da..aa1cfe51b9 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicDeliver.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicDeliver.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicGet.cs b/projects/RabbitMQ.Client/client/framing/BasicGet.cs index 52e7cf2088..310e68070d 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicGet.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicGet.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicGetOk.cs b/projects/RabbitMQ.Client/client/framing/BasicGetOk.cs index 3885727956..9b67c6f807 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicGetOk.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicGetOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicMethodConstants.cs b/projects/RabbitMQ.Client/client/framing/BasicMethodConstants.cs index 32008fc9b1..2d5dd4d580 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicMethodConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/BasicNack.cs b/projects/RabbitMQ.Client/client/framing/BasicNack.cs index 6f8a54aa5b..be254a61c5 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicNack.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicNack.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicPublish.cs b/projects/RabbitMQ.Client/client/framing/BasicPublish.cs index 9969a6a0c5..f084894e7e 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicPublish.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicPublish.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicQos.cs b/projects/RabbitMQ.Client/client/framing/BasicQos.cs index eea6d1f581..203d0aa978 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicQos.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicQos.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicReject.cs b/projects/RabbitMQ.Client/client/framing/BasicReject.cs index 74fb7b5283..2969b78bbd 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicReject.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicReject.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/BasicReturn.cs b/projects/RabbitMQ.Client/client/framing/BasicReturn.cs index 7d5b737c1d..e09e6a2895 100644 --- a/projects/RabbitMQ.Client/client/framing/BasicReturn.cs +++ b/projects/RabbitMQ.Client/client/framing/BasicReturn.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/Channel.cs b/projects/RabbitMQ.Client/client/framing/Channel.cs index f27f1b3765..c6291eb503 100644 --- a/projects/RabbitMQ.Client/client/framing/Channel.cs +++ b/projects/RabbitMQ.Client/client/framing/Channel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client/client/framing/ChannelClose.cs b/projects/RabbitMQ.Client/client/framing/ChannelClose.cs index 3d39bd6df1..3d30faf9c5 100644 --- a/projects/RabbitMQ.Client/client/framing/ChannelClose.cs +++ b/projects/RabbitMQ.Client/client/framing/ChannelClose.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ChannelCloseOk.cs b/projects/RabbitMQ.Client/client/framing/ChannelCloseOk.cs index bb4ebf80cf..4c2dfe3706 100644 --- a/projects/RabbitMQ.Client/client/framing/ChannelCloseOk.cs +++ b/projects/RabbitMQ.Client/client/framing/ChannelCloseOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ChannelFlow.cs b/projects/RabbitMQ.Client/client/framing/ChannelFlow.cs index e12f674bd2..7cade44007 100644 --- a/projects/RabbitMQ.Client/client/framing/ChannelFlow.cs +++ b/projects/RabbitMQ.Client/client/framing/ChannelFlow.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ChannelFlowOk.cs b/projects/RabbitMQ.Client/client/framing/ChannelFlowOk.cs index 45fc55d42a..4a4ce7a140 100644 --- a/projects/RabbitMQ.Client/client/framing/ChannelFlowOk.cs +++ b/projects/RabbitMQ.Client/client/framing/ChannelFlowOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ChannelMethodConstants.cs b/projects/RabbitMQ.Client/client/framing/ChannelMethodConstants.cs index b249e9e2b4..49cc0940ac 100644 --- a/projects/RabbitMQ.Client/client/framing/ChannelMethodConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/ChannelMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/ChannelOpen.cs b/projects/RabbitMQ.Client/client/framing/ChannelOpen.cs index 88d3fb42dd..30e5632a3f 100644 --- a/projects/RabbitMQ.Client/client/framing/ChannelOpen.cs +++ b/projects/RabbitMQ.Client/client/framing/ChannelOpen.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ClassConstants.cs b/projects/RabbitMQ.Client/client/framing/ClassConstants.cs index af6b612ead..3d7b540ce4 100644 --- a/projects/RabbitMQ.Client/client/framing/ClassConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/ClassConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/ConfirmMethodConstants.cs b/projects/RabbitMQ.Client/client/framing/ConfirmMethodConstants.cs index 26af360347..9639004403 100644 --- a/projects/RabbitMQ.Client/client/framing/ConfirmMethodConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/ConfirmMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/ConfirmSelect.cs b/projects/RabbitMQ.Client/client/framing/ConfirmSelect.cs index e3e558a35f..e0c629ad9d 100644 --- a/projects/RabbitMQ.Client/client/framing/ConfirmSelect.cs +++ b/projects/RabbitMQ.Client/client/framing/ConfirmSelect.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionBlocked.cs b/projects/RabbitMQ.Client/client/framing/ConnectionBlocked.cs index 04385bb0d6..590139385b 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionBlocked.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionBlocked.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionClose.cs b/projects/RabbitMQ.Client/client/framing/ConnectionClose.cs index fb9fcfc7c9..d037b1d203 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionClose.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionClose.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionCloseOk.cs b/projects/RabbitMQ.Client/client/framing/ConnectionCloseOk.cs index 321f7b8c3d..061a8686e1 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionCloseOk.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionCloseOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionMethodConstants.cs b/projects/RabbitMQ.Client/client/framing/ConnectionMethodConstants.cs index 6ec63cf72b..2ae5f9a74f 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionMethodConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionOpen.cs b/projects/RabbitMQ.Client/client/framing/ConnectionOpen.cs index 599ab9022d..95b5ee2c3e 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionOpen.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionOpen.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionSecure.cs b/projects/RabbitMQ.Client/client/framing/ConnectionSecure.cs index 517e970903..42cb3b483a 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionSecure.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionSecure.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionSecureOk.cs b/projects/RabbitMQ.Client/client/framing/ConnectionSecureOk.cs index 70c53119b3..9da24af2dc 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionSecureOk.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionSecureOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionStart.cs b/projects/RabbitMQ.Client/client/framing/ConnectionStart.cs index 841474c943..4b11e146df 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionStart.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionStart.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionStartOk.cs b/projects/RabbitMQ.Client/client/framing/ConnectionStartOk.cs index 66c322108b..67a95f245e 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionStartOk.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionStartOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionTune.cs b/projects/RabbitMQ.Client/client/framing/ConnectionTune.cs index e7813333ae..e75ac8bbaf 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionTune.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionTune.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionTuneOk.cs b/projects/RabbitMQ.Client/client/framing/ConnectionTuneOk.cs index f17ec31dc6..26e4c41a71 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionTuneOk.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionTuneOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ConnectionUpdateSecret.cs b/projects/RabbitMQ.Client/client/framing/ConnectionUpdateSecret.cs index c318136f3e..997c9f30fb 100644 --- a/projects/RabbitMQ.Client/client/framing/ConnectionUpdateSecret.cs +++ b/projects/RabbitMQ.Client/client/framing/ConnectionUpdateSecret.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/Constants.cs b/projects/RabbitMQ.Client/client/framing/Constants.cs index 949ab1e2f0..b1f78236ee 100644 --- a/projects/RabbitMQ.Client/client/framing/Constants.cs +++ b/projects/RabbitMQ.Client/client/framing/Constants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client diff --git a/projects/RabbitMQ.Client/client/framing/ExchangeBind.cs b/projects/RabbitMQ.Client/client/framing/ExchangeBind.cs index 3fd120e8fa..908fd6a627 100644 --- a/projects/RabbitMQ.Client/client/framing/ExchangeBind.cs +++ b/projects/RabbitMQ.Client/client/framing/ExchangeBind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ExchangeDeclare.cs b/projects/RabbitMQ.Client/client/framing/ExchangeDeclare.cs index 25e730a218..caea19aad3 100644 --- a/projects/RabbitMQ.Client/client/framing/ExchangeDeclare.cs +++ b/projects/RabbitMQ.Client/client/framing/ExchangeDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ExchangeDelete.cs b/projects/RabbitMQ.Client/client/framing/ExchangeDelete.cs index 4943798866..6d2142b8fc 100644 --- a/projects/RabbitMQ.Client/client/framing/ExchangeDelete.cs +++ b/projects/RabbitMQ.Client/client/framing/ExchangeDelete.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/ExchangeMethodConstants.cs b/projects/RabbitMQ.Client/client/framing/ExchangeMethodConstants.cs index eb056cd632..d63584473b 100644 --- a/projects/RabbitMQ.Client/client/framing/ExchangeMethodConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/ExchangeMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/ExchangeUnbind.cs b/projects/RabbitMQ.Client/client/framing/ExchangeUnbind.cs index fdd768e8d3..f9af0857fc 100644 --- a/projects/RabbitMQ.Client/client/framing/ExchangeUnbind.cs +++ b/projects/RabbitMQ.Client/client/framing/ExchangeUnbind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/Protocol.cs b/projects/RabbitMQ.Client/client/framing/Protocol.cs index 9f4a8d900e..0485005149 100644 --- a/projects/RabbitMQ.Client/client/framing/Protocol.cs +++ b/projects/RabbitMQ.Client/client/framing/Protocol.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueueBind.cs b/projects/RabbitMQ.Client/client/framing/QueueBind.cs index 1f0246b806..95a7b5a42e 100644 --- a/projects/RabbitMQ.Client/client/framing/QueueBind.cs +++ b/projects/RabbitMQ.Client/client/framing/QueueBind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueueDeclare.cs b/projects/RabbitMQ.Client/client/framing/QueueDeclare.cs index 1fe6307bcf..a9533f31d4 100644 --- a/projects/RabbitMQ.Client/client/framing/QueueDeclare.cs +++ b/projects/RabbitMQ.Client/client/framing/QueueDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueueDeclareOk.cs b/projects/RabbitMQ.Client/client/framing/QueueDeclareOk.cs index 7380051330..de0f9cf1bb 100644 --- a/projects/RabbitMQ.Client/client/framing/QueueDeclareOk.cs +++ b/projects/RabbitMQ.Client/client/framing/QueueDeclareOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueueDelete.cs b/projects/RabbitMQ.Client/client/framing/QueueDelete.cs index 7a776a5336..d33a0c83d2 100644 --- a/projects/RabbitMQ.Client/client/framing/QueueDelete.cs +++ b/projects/RabbitMQ.Client/client/framing/QueueDelete.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueueDeleteOk.cs b/projects/RabbitMQ.Client/client/framing/QueueDeleteOk.cs index ff4b1612fa..c762d88a65 100644 --- a/projects/RabbitMQ.Client/client/framing/QueueDeleteOk.cs +++ b/projects/RabbitMQ.Client/client/framing/QueueDeleteOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueueMethodConstants.cs b/projects/RabbitMQ.Client/client/framing/QueueMethodConstants.cs index 6395e8aab9..5dcf468d90 100644 --- a/projects/RabbitMQ.Client/client/framing/QueueMethodConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/QueueMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/QueuePurge.cs b/projects/RabbitMQ.Client/client/framing/QueuePurge.cs index d589d8ee24..a2c62b4ced 100644 --- a/projects/RabbitMQ.Client/client/framing/QueuePurge.cs +++ b/projects/RabbitMQ.Client/client/framing/QueuePurge.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueuePurgeOk.cs b/projects/RabbitMQ.Client/client/framing/QueuePurgeOk.cs index 465181bf74..c0575ae99b 100644 --- a/projects/RabbitMQ.Client/client/framing/QueuePurgeOk.cs +++ b/projects/RabbitMQ.Client/client/framing/QueuePurgeOk.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/QueueUnbind.cs b/projects/RabbitMQ.Client/client/framing/QueueUnbind.cs index 40fc505ed0..94262db1f2 100644 --- a/projects/RabbitMQ.Client/client/framing/QueueUnbind.cs +++ b/projects/RabbitMQ.Client/client/framing/QueueUnbind.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/TxCommit.cs b/projects/RabbitMQ.Client/client/framing/TxCommit.cs index 013999fa5f..e353fe00b5 100644 --- a/projects/RabbitMQ.Client/client/framing/TxCommit.cs +++ b/projects/RabbitMQ.Client/client/framing/TxCommit.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/TxMethodConstants.cs b/projects/RabbitMQ.Client/client/framing/TxMethodConstants.cs index 1497b49246..58c2c24f85 100644 --- a/projects/RabbitMQ.Client/client/framing/TxMethodConstants.cs +++ b/projects/RabbitMQ.Client/client/framing/TxMethodConstants.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Framing.Impl diff --git a/projects/RabbitMQ.Client/client/framing/TxRollback.cs b/projects/RabbitMQ.Client/client/framing/TxRollback.cs index 027713b6e4..30236f3994 100644 --- a/projects/RabbitMQ.Client/client/framing/TxRollback.cs +++ b/projects/RabbitMQ.Client/client/framing/TxRollback.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/framing/TxSelect.cs b/projects/RabbitMQ.Client/client/framing/TxSelect.cs index dd0ea866fe..7a32db4fef 100644 --- a/projects/RabbitMQ.Client/client/framing/TxSelect.cs +++ b/projects/RabbitMQ.Client/client/framing/TxSelect.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/AmqpVersion.cs b/projects/RabbitMQ.Client/client/impl/AmqpVersion.cs index f0d10d80a3..e5977ba07c 100644 --- a/projects/RabbitMQ.Client/client/impl/AmqpVersion.cs +++ b/projects/RabbitMQ.Client/client/impl/AmqpVersion.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/AsyncRpcContinuations.cs b/projects/RabbitMQ.Client/client/impl/AsyncRpcContinuations.cs index 4f73677e44..7f1e1a375c 100644 --- a/projects/RabbitMQ.Client/client/impl/AsyncRpcContinuations.cs +++ b/projects/RabbitMQ.Client/client/impl/AsyncRpcContinuations.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/AutorecoveringChannel.cs b/projects/RabbitMQ.Client/client/impl/AutorecoveringChannel.cs index 879ac51b38..050e42c48f 100644 --- a/projects/RabbitMQ.Client/client/impl/AutorecoveringChannel.cs +++ b/projects/RabbitMQ.Client/client/impl/AutorecoveringChannel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recording.cs b/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recording.cs index 8a873749c9..301fdb8263 100644 --- a/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recording.cs +++ b/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recording.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recovery.cs b/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recovery.cs index 4d95a395e5..801457c5d6 100644 --- a/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recovery.cs +++ b/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.Recovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.cs b/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.cs index 40bc9a1960..d09becd74f 100644 --- a/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.cs +++ b/projects/RabbitMQ.Client/client/impl/AutorecoveringConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/ChannelBase.cs b/projects/RabbitMQ.Client/client/impl/ChannelBase.cs index fa4f4d2f50..2ac20152ee 100644 --- a/projects/RabbitMQ.Client/client/impl/ChannelBase.cs +++ b/projects/RabbitMQ.Client/client/impl/ChannelBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/CommandAssembler.cs b/projects/RabbitMQ.Client/client/impl/CommandAssembler.cs index 7a9cb9c519..76f4d7efde 100644 --- a/projects/RabbitMQ.Client/client/impl/CommandAssembler.cs +++ b/projects/RabbitMQ.Client/client/impl/CommandAssembler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/Connection.Commands.cs b/projects/RabbitMQ.Client/client/impl/Connection.Commands.cs index fb940ff863..086fd489e3 100644 --- a/projects/RabbitMQ.Client/client/impl/Connection.Commands.cs +++ b/projects/RabbitMQ.Client/client/impl/Connection.Commands.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/Connection.Heartbeat.cs b/projects/RabbitMQ.Client/client/impl/Connection.Heartbeat.cs index d045555ab4..600e46c89c 100644 --- a/projects/RabbitMQ.Client/client/impl/Connection.Heartbeat.cs +++ b/projects/RabbitMQ.Client/client/impl/Connection.Heartbeat.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/Connection.Receive.cs b/projects/RabbitMQ.Client/client/impl/Connection.Receive.cs index eaa31ec37c..3789208fd1 100644 --- a/projects/RabbitMQ.Client/client/impl/Connection.Receive.cs +++ b/projects/RabbitMQ.Client/client/impl/Connection.Receive.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/Connection.cs b/projects/RabbitMQ.Client/client/impl/Connection.cs index 7536a1d339..54a84fe062 100644 --- a/projects/RabbitMQ.Client/client/impl/Connection.cs +++ b/projects/RabbitMQ.Client/client/impl/Connection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/ConnectionSecureOrTune.cs b/projects/RabbitMQ.Client/client/impl/ConnectionSecureOrTune.cs index addc36e00c..daf85f6be0 100644 --- a/projects/RabbitMQ.Client/client/impl/ConnectionSecureOrTune.cs +++ b/projects/RabbitMQ.Client/client/impl/ConnectionSecureOrTune.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- namespace RabbitMQ.Client.Impl diff --git a/projects/RabbitMQ.Client/client/impl/ConnectionStartDetails.cs b/projects/RabbitMQ.Client/client/impl/ConnectionStartDetails.cs index bb540c045a..4e604d1415 100644 --- a/projects/RabbitMQ.Client/client/impl/ConnectionStartDetails.cs +++ b/projects/RabbitMQ.Client/client/impl/ConnectionStartDetails.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/impl/ConsumerDispatching/IConsumerDispatcher.cs b/projects/RabbitMQ.Client/client/impl/ConsumerDispatching/IConsumerDispatcher.cs index 3c1646af46..5ab31f170b 100644 --- a/projects/RabbitMQ.Client/client/impl/ConsumerDispatching/IConsumerDispatcher.cs +++ b/projects/RabbitMQ.Client/client/impl/ConsumerDispatching/IConsumerDispatcher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/Frame.cs b/projects/RabbitMQ.Client/client/impl/Frame.cs index 2b252127e4..d9695fd1ac 100644 --- a/projects/RabbitMQ.Client/client/impl/Frame.cs +++ b/projects/RabbitMQ.Client/client/impl/Frame.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/IFrameHandler.cs b/projects/RabbitMQ.Client/client/impl/IFrameHandler.cs index f0667ed551..ed59a9a286 100644 --- a/projects/RabbitMQ.Client/client/impl/IFrameHandler.cs +++ b/projects/RabbitMQ.Client/client/impl/IFrameHandler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/IRpcContinuation.cs b/projects/RabbitMQ.Client/client/impl/IRpcContinuation.cs index 792e096bfc..c29e4ce696 100644 --- a/projects/RabbitMQ.Client/client/impl/IRpcContinuation.cs +++ b/projects/RabbitMQ.Client/client/impl/IRpcContinuation.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/ISession.cs b/projects/RabbitMQ.Client/client/impl/ISession.cs index 500dfbcfa0..bf715e756f 100644 --- a/projects/RabbitMQ.Client/client/impl/ISession.cs +++ b/projects/RabbitMQ.Client/client/impl/ISession.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/IncomingCommand.cs b/projects/RabbitMQ.Client/client/impl/IncomingCommand.cs index d5fb43d016..fdfb2534af 100644 --- a/projects/RabbitMQ.Client/client/impl/IncomingCommand.cs +++ b/projects/RabbitMQ.Client/client/impl/IncomingCommand.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/MainSession.cs b/projects/RabbitMQ.Client/client/impl/MainSession.cs index f18c86d14b..2e01349a66 100644 --- a/projects/RabbitMQ.Client/client/impl/MainSession.cs +++ b/projects/RabbitMQ.Client/client/impl/MainSession.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- // We use spec version 0-9 for common constants such as frame types, diff --git a/projects/RabbitMQ.Client/client/impl/ProtocolBase.cs b/projects/RabbitMQ.Client/client/impl/ProtocolBase.cs index a8d6e16c2e..9d4890751d 100644 --- a/projects/RabbitMQ.Client/client/impl/ProtocolBase.cs +++ b/projects/RabbitMQ.Client/client/impl/ProtocolBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/RecordedBinding.cs b/projects/RabbitMQ.Client/client/impl/RecordedBinding.cs index 153f4699b8..ab2d72a1a3 100644 --- a/projects/RabbitMQ.Client/client/impl/RecordedBinding.cs +++ b/projects/RabbitMQ.Client/client/impl/RecordedBinding.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/RecordedConsumer.cs b/projects/RabbitMQ.Client/client/impl/RecordedConsumer.cs index 888635f0a9..a2c789c72d 100644 --- a/projects/RabbitMQ.Client/client/impl/RecordedConsumer.cs +++ b/projects/RabbitMQ.Client/client/impl/RecordedConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/RecordedExchange.cs b/projects/RabbitMQ.Client/client/impl/RecordedExchange.cs index 0e6350d62f..a5650c81a1 100644 --- a/projects/RabbitMQ.Client/client/impl/RecordedExchange.cs +++ b/projects/RabbitMQ.Client/client/impl/RecordedExchange.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/impl/RecordedQueue.cs b/projects/RabbitMQ.Client/client/impl/RecordedQueue.cs index 2ae2ddd8c5..d4148a2b9c 100644 --- a/projects/RabbitMQ.Client/client/impl/RecordedQueue.cs +++ b/projects/RabbitMQ.Client/client/impl/RecordedQueue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/impl/RecoveryAwareChannel.cs b/projects/RabbitMQ.Client/client/impl/RecoveryAwareChannel.cs index bb6bb6fc91..b2d44c824d 100644 --- a/projects/RabbitMQ.Client/client/impl/RecoveryAwareChannel.cs +++ b/projects/RabbitMQ.Client/client/impl/RecoveryAwareChannel.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client/client/impl/RpcContinuationQueue.cs b/projects/RabbitMQ.Client/client/impl/RpcContinuationQueue.cs index ceaea16847..680bdd43db 100644 --- a/projects/RabbitMQ.Client/client/impl/RpcContinuationQueue.cs +++ b/projects/RabbitMQ.Client/client/impl/RpcContinuationQueue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/Session.cs b/projects/RabbitMQ.Client/client/impl/Session.cs index 4f32a81097..0631226ffd 100644 --- a/projects/RabbitMQ.Client/client/impl/Session.cs +++ b/projects/RabbitMQ.Client/client/impl/Session.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/RabbitMQ.Client/client/impl/SessionBase.cs b/projects/RabbitMQ.Client/client/impl/SessionBase.cs index 962dc81e34..1980d09053 100644 --- a/projects/RabbitMQ.Client/client/impl/SessionBase.cs +++ b/projects/RabbitMQ.Client/client/impl/SessionBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/SessionManager.cs b/projects/RabbitMQ.Client/client/impl/SessionManager.cs index 8181f9641a..8c60bc1396 100644 --- a/projects/RabbitMQ.Client/client/impl/SessionManager.cs +++ b/projects/RabbitMQ.Client/client/impl/SessionManager.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/RabbitMQ.Client/client/impl/SocketFrameHandler.cs b/projects/RabbitMQ.Client/client/impl/SocketFrameHandler.cs index 6ae1681071..6393b7efc0 100644 --- a/projects/RabbitMQ.Client/client/impl/SocketFrameHandler.cs +++ b/projects/RabbitMQ.Client/client/impl/SocketFrameHandler.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/SslHelper.cs b/projects/RabbitMQ.Client/client/impl/SslHelper.cs index 40d068db7b..493e41ed44 100644 --- a/projects/RabbitMQ.Client/client/impl/SslHelper.cs +++ b/projects/RabbitMQ.Client/client/impl/SslHelper.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/WireFormatting.Read.cs b/projects/RabbitMQ.Client/client/impl/WireFormatting.Read.cs index 1149b97b97..1bd950a805 100644 --- a/projects/RabbitMQ.Client/client/impl/WireFormatting.Read.cs +++ b/projects/RabbitMQ.Client/client/impl/WireFormatting.Read.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/WireFormatting.Write.cs b/projects/RabbitMQ.Client/client/impl/WireFormatting.Write.cs index d9a92f252b..08cb7a172e 100644 --- a/projects/RabbitMQ.Client/client/impl/WireFormatting.Write.cs +++ b/projects/RabbitMQ.Client/client/impl/WireFormatting.Write.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/impl/WireFormatting.cs b/projects/RabbitMQ.Client/client/impl/WireFormatting.cs index 0d48a07791..3a43a7b578 100644 --- a/projects/RabbitMQ.Client/client/impl/WireFormatting.cs +++ b/projects/RabbitMQ.Client/client/impl/WireFormatting.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Text; diff --git a/projects/RabbitMQ.Client/client/logging/ESLog.cs b/projects/RabbitMQ.Client/client/logging/ESLog.cs index 42eb1fa40f..f3eee8e893 100644 --- a/projects/RabbitMQ.Client/client/logging/ESLog.cs +++ b/projects/RabbitMQ.Client/client/logging/ESLog.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.Counters.cs b/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.Counters.cs index fb7c0a32ac..9f63db3031 100644 --- a/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.Counters.cs +++ b/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.Counters.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Diagnostics.Tracing; diff --git a/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.cs b/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.cs index d5aebc8013..ce187509da 100644 --- a/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.cs +++ b/projects/RabbitMQ.Client/client/logging/RabbitMqClientEventSource.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/client/logging/RabbitMqExceptionDetail.cs b/projects/RabbitMQ.Client/client/logging/RabbitMqExceptionDetail.cs index e61814569d..a02e97e6bf 100644 --- a/projects/RabbitMQ.Client/client/logging/RabbitMqExceptionDetail.cs +++ b/projects/RabbitMQ.Client/client/logging/RabbitMqExceptionDetail.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/RabbitMQ.Client/util/IntAllocator.cs b/projects/RabbitMQ.Client/util/IntAllocator.cs index 707838f6d8..f0e36aeac9 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/IntegrationFixture.cs b/projects/Test/Common/IntegrationFixture.cs index b27de42eb8..7a92378ce6 100644 --- a/projects/Test/Common/IntegrationFixture.cs +++ b/projects/Test/Common/IntegrationFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/ProcessUtil.cs b/projects/Test/Common/ProcessUtil.cs index 73c418c20c..c1bc25b9b7 100644 --- a/projects/Test/Common/ProcessUtil.cs +++ b/projects/Test/Common/ProcessUtil.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/RabbitMQCtl.cs b/projects/Test/Common/RabbitMQCtl.cs index dbf0864b08..fbb204af3b 100644 --- a/projects/Test/Common/RabbitMQCtl.cs +++ b/projects/Test/Common/RabbitMQCtl.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/SslEnv.cs b/projects/Test/Common/SslEnv.cs index 773b9951e0..aa5b6e8b10 100644 --- a/projects/Test/Common/SslEnv.cs +++ b/projects/Test/Common/SslEnv.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TestConnectionRecoveryBase.cs b/projects/Test/Common/TestConnectionRecoveryBase.cs index e8eb2884e7..40c45df147 100644 --- a/projects/Test/Common/TestConnectionRecoveryBase.cs +++ b/projects/Test/Common/TestConnectionRecoveryBase.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TestOutputWriter.cs b/projects/Test/Common/TestOutputWriter.cs index a9fe3d5cb0..d2c3ee63ca 100644 --- a/projects/Test/Common/TestOutputWriter.cs +++ b/projects/Test/Common/TestOutputWriter.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TestOutputWriterEventListener.cs b/projects/Test/Common/TestOutputWriterEventListener.cs index 4b6cbe1d0e..d359d1d37c 100644 --- a/projects/Test/Common/TestOutputWriterEventListener.cs +++ b/projects/Test/Common/TestOutputWriterEventListener.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Common/TimingFixture.cs b/projects/Test/Common/TimingFixture.cs index 23ce3a31ce..bd4a7d7bbf 100644 --- a/projects/Test/Common/TimingFixture.cs +++ b/projects/Test/Common/TimingFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 9c3dd76ffb..8bb46de1be 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 41faeb3cb0..6d8541faad 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 a3fc5ee383..66d08e9b03 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 eaed0913e9..ef7ba04cea 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 9f08cae5d6..03d5ad34b9 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading; diff --git a/projects/Test/Integration/ConnectionRecovery/TestBasicAckAndBasicNack.cs b/projects/Test/Integration/ConnectionRecovery/TestBasicAckAndBasicNack.cs index c1d178b358..eef47faa77 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/ConnectionRecovery/TestBasicConnectionRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestBasicConnectionRecovery.cs index 4cd9948023..0f5b5da5be 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 359f612c3e..65884f6c80 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/ConnectionRecovery/TestConsumerRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestConsumerRecovery.cs index b1d18991f7..aedde71fd1 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 e5e4137998..89f83a2761 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/ConnectionRecovery/TestExchangeRecovery.cs b/projects/Test/Integration/ConnectionRecovery/TestExchangeRecovery.cs index d989fca6f1..cb83177c07 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 0bf459c468..a759611630 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 82f5461b84..8f7ea095e4 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 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 92b2d8a22e..647932c4fd 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-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAsyncConsumer.cs b/projects/Test/Integration/TestAsyncConsumer.cs index e6ca9403f7..646b83ed05 100644 --- a/projects/Test/Integration/TestAsyncConsumer.cs +++ b/projects/Test/Integration/TestAsyncConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAsyncConsumerExceptions.cs b/projects/Test/Integration/TestAsyncConsumerExceptions.cs index 9262474d09..5270aef230 100644 --- a/projects/Test/Integration/TestAsyncConsumerExceptions.cs +++ b/projects/Test/Integration/TestAsyncConsumerExceptions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs b/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs index 4c07f9bd2d..0dc5db573e 100644 --- a/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs +++ b/projects/Test/Integration/TestAsyncEventingBasicConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestAuth.cs b/projects/Test/Integration/TestAuth.cs index 6b0f9d534c..57aff7d821 100644 --- a/projects/Test/Integration/TestAuth.cs +++ b/projects/Test/Integration/TestAuth.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestBasicGet.cs b/projects/Test/Integration/TestBasicGet.cs index b616e81192..1935af56da 100644 --- a/projects/Test/Integration/TestBasicGet.cs +++ b/projects/Test/Integration/TestBasicGet.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestBasicPublish.cs b/projects/Test/Integration/TestBasicPublish.cs index 0fa55617b9..0b61d0edc6 100644 --- a/projects/Test/Integration/TestBasicPublish.cs +++ b/projects/Test/Integration/TestBasicPublish.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2011-2020 VMware, Inc. or its affiliates. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestBasicPublishAsync.cs b/projects/Test/Integration/TestBasicPublishAsync.cs index f2a67ab6ea..ad4650e2a5 100644 --- a/projects/Test/Integration/TestBasicPublishAsync.cs +++ b/projects/Test/Integration/TestBasicPublishAsync.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2011-2020 VMware, Inc. or its affiliates. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestChannelAllocation.cs b/projects/Test/Integration/TestChannelAllocation.cs index 3f246457dd..42b495c491 100644 --- a/projects/Test/Integration/TestChannelAllocation.cs +++ b/projects/Test/Integration/TestChannelAllocation.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/TestChannelShutdown.cs b/projects/Test/Integration/TestChannelShutdown.cs index f9fbd7831f..e51da67fc2 100644 --- a/projects/Test/Integration/TestChannelShutdown.cs +++ b/projects/Test/Integration/TestChannelShutdown.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestChannelSoftErrors.cs b/projects/Test/Integration/TestChannelSoftErrors.cs index 81fb062130..402c09bad7 100644 --- a/projects/Test/Integration/TestChannelSoftErrors.cs +++ b/projects/Test/Integration/TestChannelSoftErrors.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs b/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs index 5b3ff5729a..ff831517fa 100644 --- a/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs +++ b/projects/Test/Integration/TestConcurrentAccessWithSharedConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConcurrentAccessWithSharedConnectionAsync.cs b/projects/Test/Integration/TestConcurrentAccessWithSharedConnectionAsync.cs index 30afc4acda..b441152f6e 100644 --- a/projects/Test/Integration/TestConcurrentAccessWithSharedConnectionAsync.cs +++ b/projects/Test/Integration/TestConcurrentAccessWithSharedConnectionAsync.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConfirmSelect.cs b/projects/Test/Integration/TestConfirmSelect.cs index 1aa3c164aa..f73e00c3af 100644 --- a/projects/Test/Integration/TestConfirmSelect.cs +++ b/projects/Test/Integration/TestConfirmSelect.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConfirmSelectAsync.cs b/projects/Test/Integration/TestConfirmSelectAsync.cs index e82b82c703..bfbd7fa2a4 100644 --- a/projects/Test/Integration/TestConfirmSelectAsync.cs +++ b/projects/Test/Integration/TestConfirmSelectAsync.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionFactory.cs b/projects/Test/Integration/TestConnectionFactory.cs index 6a8d383912..dd21fd85ff 100644 --- a/projects/Test/Integration/TestConnectionFactory.cs +++ b/projects/Test/Integration/TestConnectionFactory.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2011-2020 VMware, Inc. or its affiliates. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs b/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs index 8d9d4890e9..dc6892ab27 100644 --- a/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs +++ b/projects/Test/Integration/TestConnectionFactoryContinuationTimeout.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs b/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs index fe2edab8e8..fce8dbed88 100644 --- a/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs +++ b/projects/Test/Integration/TestConnectionRecoveryWithoutSetup.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionShutdown.cs b/projects/Test/Integration/TestConnectionShutdown.cs index b0d88c80ba..2aaa078c74 100644 --- a/projects/Test/Integration/TestConnectionShutdown.cs +++ b/projects/Test/Integration/TestConnectionShutdown.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConnectionTopologyRecovery.cs b/projects/Test/Integration/TestConnectionTopologyRecovery.cs index 8abf11b4fc..e6883b03d4 100644 --- a/projects/Test/Integration/TestConnectionTopologyRecovery.cs +++ b/projects/Test/Integration/TestConnectionTopologyRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConsumer.cs b/projects/Test/Integration/TestConsumer.cs index e2175a404f..d747a51b3e 100644 --- a/projects/Test/Integration/TestConsumer.cs +++ b/projects/Test/Integration/TestConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConsumerCancelNotify.cs b/projects/Test/Integration/TestConsumerCancelNotify.cs index 3924908b3b..1491039877 100644 --- a/projects/Test/Integration/TestConsumerCancelNotify.cs +++ b/projects/Test/Integration/TestConsumerCancelNotify.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Linq; diff --git a/projects/Test/Integration/TestConsumerCount.cs b/projects/Test/Integration/TestConsumerCount.cs index ab4bb3703f..076f9c282d 100644 --- a/projects/Test/Integration/TestConsumerCount.cs +++ b/projects/Test/Integration/TestConsumerCount.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestConsumerExceptions.cs b/projects/Test/Integration/TestConsumerExceptions.cs index d5961871e5..848ed0d92b 100644 --- a/projects/Test/Integration/TestConsumerExceptions.cs +++ b/projects/Test/Integration/TestConsumerExceptions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestConsumerOperationDispatch.cs b/projects/Test/Integration/TestConsumerOperationDispatch.cs index 264a300440..b189171c27 100644 --- a/projects/Test/Integration/TestConsumerOperationDispatch.cs +++ b/projects/Test/Integration/TestConsumerOperationDispatch.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestEventingConsumer.cs b/projects/Test/Integration/TestEventingConsumer.cs index 1721d5cb08..5072dcdbc1 100644 --- a/projects/Test/Integration/TestEventingConsumer.cs +++ b/projects/Test/Integration/TestEventingConsumer.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestExceptionMessages.cs b/projects/Test/Integration/TestExceptionMessages.cs index fdf3a55785..36180f19d3 100644 --- a/projects/Test/Integration/TestExceptionMessages.cs +++ b/projects/Test/Integration/TestExceptionMessages.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestExchangeDeclare.cs b/projects/Test/Integration/TestExchangeDeclare.cs index 41850ac996..cdaa067451 100644 --- a/projects/Test/Integration/TestExchangeDeclare.cs +++ b/projects/Test/Integration/TestExchangeDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestExtensions.cs b/projects/Test/Integration/TestExtensions.cs index 3d0cfe672d..673eff3923 100644 --- a/projects/Test/Integration/TestExtensions.cs +++ b/projects/Test/Integration/TestExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestFloodPublishing.cs b/projects/Test/Integration/TestFloodPublishing.cs index 27cd24e02a..3abe0e8f88 100644 --- a/projects/Test/Integration/TestFloodPublishing.cs +++ b/projects/Test/Integration/TestFloodPublishing.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestInitialConnection.cs b/projects/Test/Integration/TestInitialConnection.cs index 6aecda6928..0900585e0b 100644 --- a/projects/Test/Integration/TestInitialConnection.cs +++ b/projects/Test/Integration/TestInitialConnection.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Collections.Generic; diff --git a/projects/Test/Integration/TestInvalidAck.cs b/projects/Test/Integration/TestInvalidAck.cs index 4a349e2916..073a57880b 100644 --- a/projects/Test/Integration/TestInvalidAck.cs +++ b/projects/Test/Integration/TestInvalidAck.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestMainLoop.cs b/projects/Test/Integration/TestMainLoop.cs index 22efb8c7df..42eec3d7df 100644 --- a/projects/Test/Integration/TestMainLoop.cs +++ b/projects/Test/Integration/TestMainLoop.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestMessageCount.cs b/projects/Test/Integration/TestMessageCount.cs index 845dce6461..beca50f6d2 100644 --- a/projects/Test/Integration/TestMessageCount.cs +++ b/projects/Test/Integration/TestMessageCount.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/Integration/TestNowait.cs b/projects/Test/Integration/TestNowait.cs index e865ede5ea..3114009885 100644 --- a/projects/Test/Integration/TestNowait.cs +++ b/projects/Test/Integration/TestNowait.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestPassiveDeclare.cs b/projects/Test/Integration/TestPassiveDeclare.cs index 3f62505d22..67738cfbd6 100644 --- a/projects/Test/Integration/TestPassiveDeclare.cs +++ b/projects/Test/Integration/TestPassiveDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestPublishSharedChannelAsync.cs b/projects/Test/Integration/TestPublishSharedChannelAsync.cs index d132d51339..4723cdb8d9 100644 --- a/projects/Test/Integration/TestPublishSharedChannelAsync.cs +++ b/projects/Test/Integration/TestPublishSharedChannelAsync.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestPublisherConfirms.cs b/projects/Test/Integration/TestPublisherConfirms.cs index 5afd88f3fb..64714b7693 100644 --- a/projects/Test/Integration/TestPublisherConfirms.cs +++ b/projects/Test/Integration/TestPublisherConfirms.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestQueueDeclare.cs b/projects/Test/Integration/TestQueueDeclare.cs index 9927bffdbf..5b4f8ae4d3 100644 --- a/projects/Test/Integration/TestQueueDeclare.cs +++ b/projects/Test/Integration/TestQueueDeclare.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestSsl.cs b/projects/Test/Integration/TestSsl.cs index aa7f8ed965..48925f6df4 100644 --- a/projects/Test/Integration/TestSsl.cs +++ b/projects/Test/Integration/TestSsl.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.IO; diff --git a/projects/Test/Integration/TestToxiproxy.cs b/projects/Test/Integration/TestToxiproxy.cs index 72b5597e70..b6f2557575 100644 --- a/projects/Test/Integration/TestToxiproxy.cs +++ b/projects/Test/Integration/TestToxiproxy.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Integration/TestUpdateSecret.cs b/projects/Test/Integration/TestUpdateSecret.cs index 3f65d79d64..f4ebd65c3b 100644 --- a/projects/Test/Integration/TestUpdateSecret.cs +++ b/projects/Test/Integration/TestUpdateSecret.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Threading.Tasks; diff --git a/projects/Test/OAuth2/RequestFormMatcher.cs b/projects/Test/OAuth2/RequestFormMatcher.cs index 595ed24a90..9d3e518069 100644 --- a/projects/Test/OAuth2/RequestFormMatcher.cs +++ b/projects/Test/OAuth2/RequestFormMatcher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/OAuth2/TestOAuth2Client.cs b/projects/Test/OAuth2/TestOAuth2Client.cs index 2d39f5c276..3633b6fab1 100644 --- a/projects/Test/OAuth2/TestOAuth2Client.cs +++ b/projects/Test/OAuth2/TestOAuth2Client.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs b/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs index 4e637e70ec..6c2604f960 100644 --- a/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs +++ b/projects/Test/OAuth2/TestOAuth2ClientCredentialsProvider.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs b/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs index d03bb30ba2..cc7a962417 100644 --- a/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs +++ b/projects/Test/SequentialIntegration/SequentialIntegrationFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestActivitySource.cs b/projects/Test/SequentialIntegration/TestActivitySource.cs index 5b60e03e37..a25be68de2 100644 --- a/projects/Test/SequentialIntegration/TestActivitySource.cs +++ b/projects/Test/SequentialIntegration/TestActivitySource.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestConnectionBlocked.cs b/projects/Test/SequentialIntegration/TestConnectionBlocked.cs index f3415af09e..591b39ba94 100644 --- a/projects/Test/SequentialIntegration/TestConnectionBlocked.cs +++ b/projects/Test/SequentialIntegration/TestConnectionBlocked.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs b/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs index db12fc45d8..2ed94e3c64 100644 --- a/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs +++ b/projects/Test/SequentialIntegration/TestConnectionBlockedChannelLeak.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestConnectionRecovery.cs b/projects/Test/SequentialIntegration/TestConnectionRecovery.cs index 2eb2f73800..c9766164af 100644 --- a/projects/Test/SequentialIntegration/TestConnectionRecovery.cs +++ b/projects/Test/SequentialIntegration/TestConnectionRecovery.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/SequentialIntegration/TestHeartbeats.cs b/projects/Test/SequentialIntegration/TestHeartbeats.cs index ea9e8f0299..38882e5694 100644 --- a/projects/Test/SequentialIntegration/TestHeartbeats.cs +++ b/projects/Test/SequentialIntegration/TestHeartbeats.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/DebugUtil.cs b/projects/Test/Unit/DebugUtil.cs index 34d44ce90d..e7feb897a2 100644 --- a/projects/Test/Unit/DebugUtil.cs +++ b/projects/Test/Unit/DebugUtil.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs b/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs index 379a5b34d0..f974991e21 100644 --- a/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs +++ b/projects/Test/Unit/TestAmqpTcpEndpointParsing.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestAmqpUri.cs b/projects/Test/Unit/TestAmqpUri.cs index 823f41205b..a949b813d1 100644 --- a/projects/Test/Unit/TestAmqpUri.cs +++ b/projects/Test/Unit/TestAmqpUri.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2011-2020 VMware, Inc. or its affiliates. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestBasicProperties.cs b/projects/Test/Unit/TestBasicProperties.cs index 0eb2cc04c4..7e52af87a8 100644 --- a/projects/Test/Unit/TestBasicProperties.cs +++ b/projects/Test/Unit/TestBasicProperties.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2011-2020 VMware, Inc. or its affiliates. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestContentHeaderCodec.cs b/projects/Test/Unit/TestContentHeaderCodec.cs index 4429b468eb..dd57481a13 100644 --- a/projects/Test/Unit/TestContentHeaderCodec.cs +++ b/projects/Test/Unit/TestContentHeaderCodec.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestFieldTableFormatting.cs b/projects/Test/Unit/TestFieldTableFormatting.cs index 87232c2b87..c65cc6bfb1 100644 --- a/projects/Test/Unit/TestFieldTableFormatting.cs +++ b/projects/Test/Unit/TestFieldTableFormatting.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestFieldTableFormattingGeneric.cs b/projects/Test/Unit/TestFieldTableFormattingGeneric.cs index 03ca347c89..d0a917ab96 100644 --- a/projects/Test/Unit/TestFieldTableFormattingGeneric.cs +++ b/projects/Test/Unit/TestFieldTableFormattingGeneric.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- diff --git a/projects/Test/Unit/TestFrameFormatting.cs b/projects/Test/Unit/TestFrameFormatting.cs index dc56a2bce2..82266852e2 100644 --- a/projects/Test/Unit/TestFrameFormatting.cs +++ b/projects/Test/Unit/TestFrameFormatting.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestIEndpointResolverExtensions.cs b/projects/Test/Unit/TestIEndpointResolverExtensions.cs index 953776b668..81b8fc13f2 100644 --- a/projects/Test/Unit/TestIEndpointResolverExtensions.cs +++ b/projects/Test/Unit/TestIEndpointResolverExtensions.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestIntAllocator.cs b/projects/Test/Unit/TestIntAllocator.cs index 18c41bcce5..23ad202393 100644 --- a/projects/Test/Unit/TestIntAllocator.cs +++ b/projects/Test/Unit/TestIntAllocator.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2013-2020 VMware, Inc. or its affiliates. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestMethodArgumentCodec.cs b/projects/Test/Unit/TestMethodArgumentCodec.cs index 7c8f279c9e..21e773998b 100644 --- a/projects/Test/Unit/TestMethodArgumentCodec.cs +++ b/projects/Test/Unit/TestMethodArgumentCodec.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestNetworkByteOrderSerialization.cs b/projects/Test/Unit/TestNetworkByteOrderSerialization.cs index a0d0e5cf95..a428ff7ceb 100644 --- a/projects/Test/Unit/TestNetworkByteOrderSerialization.cs +++ b/projects/Test/Unit/TestNetworkByteOrderSerialization.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestPublicationAddress.cs b/projects/Test/Unit/TestPublicationAddress.cs index 2d570bcf7f..87f8a7cfbb 100644 --- a/projects/Test/Unit/TestPublicationAddress.cs +++ b/projects/Test/Unit/TestPublicationAddress.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestRpcContinuationQueue.cs b/projects/Test/Unit/TestRpcContinuationQueue.cs index 4d1dfef054..d02342197f 100644 --- a/projects/Test/Unit/TestRpcContinuationQueue.cs +++ b/projects/Test/Unit/TestRpcContinuationQueue.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TestTcpClientAdapter.cs b/projects/Test/Unit/TestTcpClientAdapter.cs index 9e522bc6ee..faeaeb4341 100644 --- a/projects/Test/Unit/TestTcpClientAdapter.cs +++ b/projects/Test/Unit/TestTcpClientAdapter.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System.Net; diff --git a/projects/Test/Unit/TestTimerBasedCredentialRefresher.cs b/projects/Test/Unit/TestTimerBasedCredentialRefresher.cs index 4887eaad47..faed6f03f7 100644 --- a/projects/Test/Unit/TestTimerBasedCredentialRefresher.cs +++ b/projects/Test/Unit/TestTimerBasedCredentialRefresher.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/TimingFixture.cs b/projects/Test/Unit/TimingFixture.cs index fff7d4b031..d061251a75 100644 --- a/projects/Test/Unit/TimingFixture.cs +++ b/projects/Test/Unit/TimingFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; diff --git a/projects/Test/Unit/WireFormattingFixture.cs b/projects/Test/Unit/WireFormattingFixture.cs index 36986070c8..e47e1ec295 100644 --- a/projects/Test/Unit/WireFormattingFixture.cs +++ b/projects/Test/Unit/WireFormattingFixture.cs @@ -4,7 +4,7 @@ // The APL v2.0: // //--------------------------------------------------------------------------- -// Copyright (c) 2007-2020 VMware, Inc. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. // // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. @@ -26,7 +26,7 @@ // License, v. 2.0. If a copy of the MPL was not distributed with this // file, You can obtain one at https://mozilla.org/MPL/2.0/. // -// Copyright (c) 2007-2020 VMware, Inc. All rights reserved. +// Copyright (c) 2007-2024 Broadcom. All Rights Reserved. //--------------------------------------------------------------------------- using System; From ae679f4b2380f9f0d56efe7bab6ef0c73df212bb Mon Sep 17 00:00:00 2001 From: Luke Bakken Date: Mon, 3 Jun 2024 19:36:56 -0700 Subject: [PATCH 2/2] Add commit that updates copyright to git-blame-ignore-revs --- .git-blame-ignore-revs | 2 ++ 1 file changed, 2 insertions(+) diff --git a/.git-blame-ignore-revs b/.git-blame-ignore-revs index a9209d0db8..30d1eb5ca8 100644 --- a/.git-blame-ignore-revs +++ b/.git-blame-ignore-revs @@ -3,3 +3,5 @@ 67c02d79d3ae48fea7de93c758dce91a51d14988 # Revert the above 6b1a06bd429f395891a3230cad92e674dcbbb0d2 +# Update copyright to Broadcom +7c532d95f354502a87c01d1af5314246b829faf6