Advertisement
Not a member of Pastebin yet?
Sign Up,
it unlocks many cool features!
- ## The following types are no longer available
- ### NServiceBus.BinarySerializer
- No upgrade instructions provided.
- ### NServiceBus.BsonSerializer
- No upgrade instructions provided.
- ### NServiceBus.CircuitBreakers.RepeatedFailuresOverTimeCircuitBreaker
- No upgrade instructions provided.
- ### NServiceBus.ConfigurationBuilderExtensions
- No upgrade instructions provided.
- ### NServiceBus.ConfigureHandlerSettings
- No upgrade instructions provided.
- ### NServiceBus.Encryption.IEncryptionService
- No upgrade instructions provided.
- ### NServiceBus.EndpointNameAttribute
- No upgrade instructions provided.
- ### NServiceBus.EndpointSLAAttribute
- No upgrade instructions provided.
- ### NServiceBus.Features.BinarySerialization
- No upgrade instructions provided.
- ### NServiceBus.Features.BsonSerialization
- No upgrade instructions provided.
- ### NServiceBus.Features.InstallationSupport
- No upgrade instructions provided.
- ### NServiceBus.Features.JsonSerialization
- No upgrade instructions provided.
- ### NServiceBus.Features.MsmqTransportConfigurator
- No upgrade instructions provided.
- ### NServiceBus.Features.XmlSerialization
- No upgrade instructions provided.
- ### NServiceBus.IConfigureThisEndpoint
- No upgrade instructions provided.
- ### NServiceBus.IInMemoryOperations
- Removed to reduce complexity and API confusion.
- ### NServiceBus.Pipeline.BehaviorContext
- No upgrade instructions provided.
- ### NServiceBus.Pipeline.Contexts.IncomingContext
- No upgrade instructions provided.
- ### NServiceBus.Pipeline.PipelineNotifications
- No upgrade instructions provided.
- ### NServiceBus.Pipeline.StepEnded
- No upgrade instructions provided.
- ### NServiceBus.Pipeline.StepStarted
- No upgrade instructions provided.
- ### NServiceBus.Saga.ContainSagaData
- No upgrade instructions provided.
- ### NServiceBus.Saga.IAmStartedByMessages<T>
- No upgrade instructions provided.
- ### NServiceBus.Saga.IConfigureHowToFindSagaWithMessage
- No upgrade instructions provided.
- ### NServiceBus.Saga.IContainSagaData
- No upgrade instructions provided.
- ### NServiceBus.Saga.IFinder
- No upgrade instructions provided.
- ### NServiceBus.Saga.IFindSagas<T>
- No upgrade instructions provided.
- ### NServiceBus.Saga.IHandleSagaNotFound
- No upgrade instructions provided.
- ### NServiceBus.Saga.IHandleTimeouts<T>
- No upgrade instructions provided.
- ### NServiceBus.Saga.ISagaPersister
- No upgrade instructions provided.
- ### NServiceBus.Saga.Saga
- No upgrade instructions provided.
- ### NServiceBus.Saga.Saga<TSagaData>
- No upgrade instructions provided.
- ### NServiceBus.Saga.SagaPropertyMapper<TSagaData>
- No upgrade instructions provided.
- ### NServiceBus.Saga.ToSagaExpression<TSagaData, TMessage>
- No upgrade instructions provided.
- ### NServiceBus.Saga.UniqueAttribute
- No upgrade instructions provided.
- ### NServiceBus.Serializers.Binary.BinaryMessageSerializer
- No upgrade instructions provided.
- ### NServiceBus.Serializers.Binary.SimpleMessageMapper
- No upgrade instructions provided.
- ### NServiceBus.Serializers.Json.BsonMessageSerializer
- No upgrade instructions provided.
- ### NServiceBus.Serializers.Json.JsonMessageSerializerBase
- No upgrade instructions provided.
- ### NServiceBus.Timeout.Core.IPersistTimeoutsV2
- No upgrade instructions provided.
- ### NServiceBus.Timeout.Core.TimeoutPersistenceVersionCheckExtension
- No upgrade instructions provided.
- ### NServiceBus.TransactionSettingsExtentions
- No upgrade instructions provided.
- ### NServiceBus.Transports.ConfigureTransport
- No upgrade instructions provided.
- ### NServiceBus.Unicast.Messages.LogicalMessage
- No upgrade instructions provided.
- ### NServiceBus.Unicast.Messages.LogicalMessageFactory
- No upgrade instructions provided.
- ### NServiceBus.XmlSerializerConfigurationExtensions
- No upgrade instructions provided.
- ### NServiceBus.Features.FeatureDiagnosticData
- No upgrade instructions provided.
- ### NServiceBus.Features.FeaturesReport
- No upgrade instructions provided.
- ### NServiceBus.Features.PrerequisiteStatus
- No upgrade instructions provided.
- ### NServiceBus.Address
- Use the string based overloads.
- ### NServiceBus.AllAssemblies
- Please use `EndpointConfiguration.ExcludeAssemblies` instead.
- ### NServiceBus.BusAsyncResultEventArgs
- No longer used, use the new callbacks api described in the version 6 upgrade guide.
- ### NServiceBus.BusConfiguration
- Please use `EndpointConfiguration` instead.
- ### NServiceBus.BusNotifications
- Please use `Notifications` instead.
- ### NServiceBus.CompletionResult
- Replaced by NServiceBus.Callbacks package.
- ### NServiceBus.Config.IWantToRunWhenConfigurationIsComplete
- Use the feature concept instead via A class which inherits from `NServiceBus.Features.Feature` and use `configuration.EnableFeature<YourClass>()`.
- ### NServiceBus.Config.MasterNodeConfig
- Please use `EndpointConfiguration.EnlistWithLegacyMSMQDistributor` instead.
- ### NServiceBus.Configure
- This is no longer a public API.
- ### NServiceBus.ConfigureInMemoryFaultManagement
- Will be removed in version 7.0.0.
- ### NServiceBus.ExtensionMethods
- Headers are not managed via the send, reply and publishoptions.
- ### NServiceBus.Faults.IManageMessageFailures
- IManageMessageFailures is no longer an extension point. To take control of the error handling part of the message processing pipeline, review the Version 5 to 6 upgrade guide for details.
- ### NServiceBus.Features.SerializationFeatureHelper
- Use the ConfigureSerialization Feature class instead. Please use `ConfigureSerialization` instead.
- ### NServiceBus.Features.StorageDrivenPublishing
- No longer used, safe to remove.
- ### NServiceBus.Features.TimeoutManagerBasedDeferral
- No longer used, safe to remove.
- ### NServiceBus.First<T>
- Please use `EndpointConfiguration.ExecuteTheseHandlersFirst` instead.
- ### NServiceBus.IAuthorizeSubscriptions
- Please use `config.UseTransport<MsmqTransport>().SubscriptionAuthorizer(Authorizer);` instead.
- ### NServiceBus.IBus
- IHandleMessages<T> now exposes the IMessageHandlerContext parameter. Use this to access what used to be available in the IBus interface. Use the provided context in extension points like message handlers or IEndpointInstance when outside the message processing pipeline.
- ### NServiceBus.ICallback
- Replaced by NServiceBus.Callbacks package.
- ### NServiceBus.IExcludesBuilder
- Will be removed in version 7.0.0.
- ### NServiceBus.IIncludesBuilder
- Will be removed in version 7.0.0.
- ### NServiceBus.IManageMessageHeaders
- No longer used, can safely be removed.
- ### NServiceBus.IMessageContext
- Use `IMessageHandlerContext` provided to message handlers instead.
- ### NServiceBus.ISendOnlyBus
- Use IEndpointInstance to create sending session.
- ### NServiceBus.ISpecifyMessageHandlerOrdering
- Please use `EndpointConfiguration.ExecuteTheseHandlersFirst` instead.
- ### NServiceBus.IStartableBus
- Please use `IStartableEndpoint` instead.
- ### NServiceBus.IWantToRunWhenBusStartsAndStops
- `IWantToRunWhenBusStartsAndStops` has been moved to the host implementations and renamed. If you're self-hosting, instead of using this interface, you can call any startup code right before `Endpoint.Create` or any cleanup code right after `Endpoint.Stop`. When using either NServiceBus.Host or NServiceBus.Host.AzureCloudService, use the host's interface `IWantToRunWhenEndpointStartsAndStops` instead.
- ### NServiceBus.MessageMutator.IMessageMutator
- Have the mutator implement both IMutateOutgoingMessages and IMutateIncomingMessages.
- ### NServiceBus.MessageMutator.IMutateTransportMessages
- Have the mutator implement both IMutateIncomingTransportMessages and IMutateOutgoingTransportMessages.
- ### NServiceBus.ObjectBuilder.IComponentConfig
- Setting property values explicitly is no longer supported via this API. Use `.ConfigureComponent(b=> new MyMessageHandler(){ MyProperty = X})` to get full control over handler creation.
- ### NServiceBus.ObjectBuilder.IComponentConfig<T>
- Setting property values explicitly is no longer supported via this API. Use `.ConfigureComponent(b=> new MyMessageHandler(){ MyProperty = X})` to get full control over handler creation.
- ### NServiceBus.Order
- Please use `EndpointConfiguration.ExecuteTheseHandlersFirst` instead.
- ### NServiceBus.Persistence.Storage
- Please use `NServiceBus.Persistence.StorageType` instead.
- ### NServiceBus.Pipeline.Contexts.OutgoingContext
- Please use `OutgoingLogicalMessage` instead.
- ### NServiceBus.Pipeline.IBehavior<TContext>
- Please use `Behavior<T>` instead.
- ### NServiceBus.Pipeline.PipelineExecutor
- The pipeline context is no longer avaliable via dependency injection. Use a custom behavior as described in the version 6 upgrade guide.
- ### NServiceBus.Satellites.IAdvancedSatellite
- ISatellite is no longer an extension point. In order to create a satellite one must create a feature that uses AddSatellitePipeline() method and a class that inherits from SatelliteBehavior that is used for processing the messages.
- ### NServiceBus.Satellites.ISatellite
- ISatellite is no longer an extension point. In order to create a satellite one must create a feature that uses AddSatellitePipeline() method and a class that inherits from SatelliteBehavior that is used for processing the messages.
- ### NServiceBus.Schedule
- Use extension methods provided on ISendOnlyBus.
- ### NServiceBus.Serializers.Json.JsonMessageSerializer
- Built-in serializers are internal. Switch to an alternative (e.g. Json.net) or copy the serializer code.
- ### NServiceBus.Serializers.XML.XmlMessageSerializer
- Built-in serializers are internal. Switch to an alternative (e.g. XmlSerializer) or copy the serializer code.
- ### NServiceBus.TransportMessage
- Not used anymore, use `OutgoingMessage` or `IncomingMessage` instead.
- ### NServiceBus.Transports.IAuditMessages
- No longer used, safe to remove.
- ### NServiceBus.Transports.IDeferMessages
- Please use `IDispatchMessages` instead.
- ### NServiceBus.Transports.IDequeueMessages
- Please use `NServiceBus.Transport.IPushMessages` instead.
- ### NServiceBus.Transports.IPublishMessages
- Please use `IDispatchMessages` instead.
- ### NServiceBus.Transports.ISendMessages
- Please use `IDispatchMessages` instead.
- ### NServiceBus.Transports.Msmq.Config.MsmqSettings
- No longer available, see the documentation for native sends for alternative solutions.
- ### NServiceBus.Transports.Msmq.MsmqDequeueStrategy
- No longer available, resolve an instance of IPushMessages from the container instead.
- ### NServiceBus.Transports.Msmq.MsmqMessageSender
- No longer available, see the documentation for native sends for alternative solutions.
- ### NServiceBus.Transports.Msmq.MsmqUnitOfWork
- The msmq transaction is now available via the pipeline context.
- ### NServiceBus.Unicast.BusAsyncResult
- No longer used, use the new callbacks api described in the version 6 upgrade guide.
- ### NServiceBus.Unicast.DeliveryOptions
- Please use `NServiceBus.UnicastBus.DeliveryMessageOptions` instead.
- ### NServiceBus.Unicast.IMessageHandlerRegistry
- Not a public API. Please use `MessageHandlerRegistry` instead.
- ### NServiceBus.Unicast.MessageContext
- Will be removed in version 7.0.0.
- ### NServiceBus.Unicast.PublishOptions
- Use context.Intent to detect of the message is a event being published and use context.MessageType to get the actual event type.
- ### NServiceBus.Unicast.Queuing.IWantQueueCreated
- Please use `QueueBindings` instead.
- ### NServiceBus.Unicast.ReplyOptions
- Not used anymore, use the 'NServiceBus.MessageIntent' header to detect if the message is a reply.
- ### NServiceBus.Unicast.Routing.StaticMessageRouter
- No longer used, safe to remove.
- ### NServiceBus.Unicast.SendOptions
- Please use `NServiceBus.UnicastBus.SendMessageOptions` instead.
- ### NServiceBus.Unicast.Subscriptions.SubscriptionEventArgs
- No longer used, safe to remove.
- ### NServiceBus.Unicast.Transport.ControlMessage
- No longer used, can safely be removed.
- ### NServiceBus.Unicast.Transport.FailedMessageProcessingEventArgs
- Use the pipeline to catch failures.
- ### NServiceBus.Unicast.Transport.FinishedMessageProcessingEventArgs
- No longer used, can safely be removed.
- ### NServiceBus.Unicast.Transport.ITransport
- Please use `IPushMessages` instead.
- ### NServiceBus.Unicast.Transport.StartedMessageProcessingEventArgs
- No longer used, can safely be removed.
- ### NServiceBus.Unicast.Transport.TransactionSettings
- Transaction settings is no longer available via this class. See obsoletes on individual members for further details.
- ### NServiceBus.Unicast.Transport.TransportMessageAvailableEventArgs
- No longer used, can safely be removed.
- ### NServiceBus.Unicast.Transport.TransportMessageReceivedEventArgs
- No longer used, can safely be removed.
- ### NServiceBus.Unicast.Transport.TransportReceiver
- No longer used, can safely be removed.
- ### NServiceBus.Unicast.UnicastBus
- UnicastBus has been made internal. Use IEndpointInstance instead.
- ## Types with removed members
- ### NServiceBus.Address
- #### Removed fields
- * `NServiceBus.Address Self` - No upgrade instructions provided.
- * `NServiceBus.Address Undefined` - No upgrade instructions provided.
- #### Removed methods
- * `void .ctor(string, string)` - No upgrade instructions provided.
- * `bool Equals(object)` - No upgrade instructions provided.
- * `string get_Machine()` - No upgrade instructions provided.
- * `string get_Queue()` - No upgrade instructions provided.
- * `int GetHashCode()` - No upgrade instructions provided.
- * `void IgnoreMachineName()` - No upgrade instructions provided.
- * `bool op_Equality(NServiceBus.Address, NServiceBus.Address)` - No upgrade instructions provided.
- * `bool op_Inequality(NServiceBus.Address, NServiceBus.Address)` - No upgrade instructions provided.
- * `void OverrideDefaultMachine(string)` - No upgrade instructions provided.
- * `NServiceBus.Address Parse(string)` - No upgrade instructions provided.
- * `NServiceBus.Address SubScope(string)` - No upgrade instructions provided.
- * `string ToString()` - No upgrade instructions provided.
- ### NServiceBus.ContentTypes
- #### Removed fields
- * `string Binary` - No upgrade instructions provided.
- * `string Bson` - No upgrade instructions provided.
- ### NServiceBus.Headers
- #### Removed fields
- * `string InvokedSagas` - Enriching the headers for saga related information has been moved to the SagaAudit plugin in ServiceControl. Add a reference to the Saga audit plugin in your endpoint to get more information.
- ### NServiceBus.Pipeline.WellKnownStep
- #### Removed fields
- * `NServiceBus.Pipeline.WellKnownStep CreatePhysicalMessage` - No upgrade instructions provided.
- * `NServiceBus.Pipeline.WellKnownStep DeserializeMessages` - No upgrade instructions provided.
- * `NServiceBus.Pipeline.WellKnownStep EnforceBestPractices` - No upgrade instructions provided.
- * `NServiceBus.Pipeline.WellKnownStep ExecuteLogicalMessages` - No upgrade instructions provided.
- * `NServiceBus.Pipeline.WellKnownStep LoadHandlers` - No upgrade instructions provided.
- * `NServiceBus.Pipeline.WellKnownStep SerializeMessage` - No upgrade instructions provided.
- ### NServiceBus.AllAssemblies
- #### Removed methods
- * `NServiceBus.IExcludesBuilder Except(string)` - No upgrade instructions provided.
- * `IEnumerator<Assembly> GetEnumerator()` - No upgrade instructions provided.
- * `NServiceBus.IIncludesBuilder Matching(string)` - No upgrade instructions provided.
- ### NServiceBus.AutoSubscribeSettingsExtensions
- #### Removed methods
- * `NServiceBus.AutomaticSubscriptions.Config.AutoSubscribeSettings AutoSubscribe(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.Bus
- #### Removed methods
- * `NServiceBus.IStartableBus Create(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `NServiceBus.ISendOnlyBus CreateSendOnly(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.BusAsyncResultEventArgs
- #### Removed methods
- * `string get_MessageId()` - No upgrade instructions provided.
- * `NServiceBus.Unicast.BusAsyncResult get_Result()` - No upgrade instructions provided.
- * `void set_MessageId(string)` - No upgrade instructions provided.
- * `void set_Result(NServiceBus.Unicast.BusAsyncResult)` - No upgrade instructions provided.
- ### NServiceBus.BusConfiguration
- #### Removed methods
- * `void AssembliesToScan(IEnumerable<Assembly>)` - No upgrade instructions provided.
- * `void AssembliesToScan(Assembly[])` - No upgrade instructions provided.
- * `NServiceBus.ConventionsBuilder Conventions()` - No upgrade instructions provided.
- * `void CustomConfigurationSource(NServiceBus.Config.ConfigurationSource.IConfigurationSource)` - No upgrade instructions provided.
- * `void EndpointName(string)` - No upgrade instructions provided.
- * `void EndpointVersion(string)` - This api does not do anything.
- * `NServiceBus.Pipeline.PipelineSettings get_Pipeline()` - No upgrade instructions provided.
- * `void OverrideLocalAddress(string)` - No upgrade instructions provided.
- * `void OverridePublicReturnAddress(NServiceBus.Address)` - No upgrade instructions provided.
- * `void RegisterComponents(Action<NServiceBus.ObjectBuilder.IConfigureComponents>)` - No upgrade instructions provided.
- * `void ScanAssembliesInDirectory(string)` - No upgrade instructions provided.
- * `void TypesToScan(IEnumerable<Type>)` - No upgrade instructions provided.
- * `void UseContainer<T>(Action<NServiceBus.Container.ContainerCustomizations>)` - No upgrade instructions provided.
- * `void UseContainer(Type)` - No upgrade instructions provided.
- * `void UseContainer(NServiceBus.ObjectBuilder.Common.IContainer)` - No upgrade instructions provided.
- ### NServiceBus.BusNotifications
- #### Removed methods
- * `NServiceBus.Faults.ErrorsNotifications get_Errors()` - No upgrade instructions provided.
- * `NServiceBus.Pipeline.PipelineNotifications get_Pipeline()` - No upgrade instructions provided.
- ### NServiceBus.CompletionResult
- #### Removed methods
- * `int get_ErrorCode()` - No upgrade instructions provided.
- * `Object[] get_Messages()` - No upgrade instructions provided.
- * `object get_State()` - No upgrade instructions provided.
- * `void set_ErrorCode(int)` - No upgrade instructions provided.
- * `void set_Messages(Object[])` - No upgrade instructions provided.
- * `void set_State(object)` - No upgrade instructions provided.
- ### NServiceBus.Config.IWantToRunWhenConfigurationIsComplete
- #### Removed methods
- * `void Run(NServiceBus.Configure)` - No upgrade instructions provided.
- ### NServiceBus.Config.MasterNodeConfig
- #### Removed methods
- * `string get_Node()` - No upgrade instructions provided.
- * `void set_Node(string)` - No upgrade instructions provided.
- ### NServiceBus.Config.MessageEndpointMapping
- #### Removed methods
- * `void Configure(Action<Type, NServiceBus.Address>)` - No upgrade instructions provided.
- ### NServiceBus.ConfigurationTimeoutExtensions
- #### Removed methods
- * `void TimeToWaitBeforeTriggeringCriticalErrorOnTimeoutOutages(NServiceBus.BusConfiguration, TimeSpan)` - No upgrade instructions provided.
- ### NServiceBus.Configure
- #### Removed methods
- * `void .ctor(NServiceBus.Settings.SettingsHolder, NServiceBus.ObjectBuilder.Common.IContainer, List<Action<NServiceBus.ObjectBuilder.IConfigureComponents>>, NServiceBus.Pipeline.PipelineSettings)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IBuilder get_Builder()` - No upgrade instructions provided.
- * `NServiceBus.Address get_LocalAddress()` - No upgrade instructions provided.
- * `NServiceBus.Settings.SettingsHolder get_Settings()` - No upgrade instructions provided.
- * `IList<Type> get_TypesToScan()` - No upgrade instructions provided.
- ### NServiceBus.ConfigureCriticalErrorAction
- #### Removed methods
- * `void DefineCriticalErrorAction(NServiceBus.BusConfiguration, Action<string, Exception>)` - No upgrade instructions provided.
- ### NServiceBus.ConfigureInMemoryFaultManagement
- #### Removed methods
- * `void DiscardFailedMessagesInsteadOfSendingToErrorQueue(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.ConfigureLicenseExtensions
- #### Removed methods
- * `void License(NServiceBus.BusConfiguration, string)` - No upgrade instructions provided.
- * `void LicensePath(NServiceBus.BusConfiguration, string)` - No upgrade instructions provided.
- ### NServiceBus.ConfigurePurging
- #### Removed methods
- * `void PurgeOnStartup(NServiceBus.BusConfiguration, bool)` - No upgrade instructions provided.
- ### NServiceBus.ConfigureQueueCreation
- #### Removed methods
- * `void DoNotCreateQueues(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.ConfigureRijndaelEncryptionService
- #### Removed methods
- * `void RegisterEncryptionService(NServiceBus.BusConfiguration, Func<NServiceBus.ObjectBuilder.IBuilder, NServiceBus.Encryption.IEncryptionService>)` - No upgrade instructions provided.
- * `void RijndaelEncryptionService(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `void RijndaelEncryptionService(NServiceBus.BusConfiguration, string, List<string>)` - Please use `RijndaelEncryptionService(string encryptionKeyIdentifier, byte[] encryptionKey, IEnumerable<KeyValuePair<string, byte[]>> expiredKeys = null)` instead.
- * `void RijndaelEncryptionService(NServiceBus.BusConfiguration, string, Byte[], IList<Byte[]>)` - No upgrade instructions provided.
- * `void RijndaelEncryptionService(NServiceBus.BusConfiguration, string, IDictionary<string, Byte[]>, IList<Byte[]>)` - No upgrade instructions provided.
- ### NServiceBus.ConventionsBuilder
- #### Removed methods
- * `void .ctor()` - No upgrade instructions provided.
- * `NServiceBus.ConventionsBuilder DefiningExpressMessagesAs(Func<Type, bool>)` - No upgrade instructions provided.
- * `NServiceBus.ConventionsBuilder DefiningTimeToBeReceivedAs(Func<Type, TimeSpan>)` - No upgrade instructions provided.
- ### NServiceBus.CriticalError
- #### Removed methods
- * `void .ctor(Action<string, Exception>, NServiceBus.Configure)` - No upgrade instructions provided.
- ### NServiceBus.CriticalTimeMonitoringConfig
- #### Removed methods
- * `void EnableCriticalTimePerformanceCounter(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.DataBus.IDataBus
- #### Removed methods
- * `Stream Get(string)` - No upgrade instructions provided.
- * `string Put(Stream, TimeSpan)` - No upgrade instructions provided.
- * `void Start()` - No upgrade instructions provided.
- ### NServiceBus.DurableMessagesConfig
- #### Removed methods
- * `void DisableDurableMessages(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `void EnableDurableMessages(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.ExtensionMethods
- #### Removed methods
- * `void SetMessageHeader(NServiceBus.ISendOnlyBus, object, string, string)` - No upgrade instructions provided.
- ### NServiceBus.Faults.ErrorsNotifications
- #### Removed methods
- * `IObservable<NServiceBus.Faults.SecondLevelRetry> get_MessageHasBeenSentToSecondLevelRetries()` - No upgrade instructions provided.
- * `IObservable<NServiceBus.Faults.FirstLevelRetry> get_MessageHasFailedAFirstLevelRetryAttempt()` - No upgrade instructions provided.
- * `IObservable<NServiceBus.Faults.FailedMessage> get_MessageSentToErrorQueue()` - No upgrade instructions provided.
- ### NServiceBus.Faults.FailedMessage
- #### Removed methods
- * `void .ctor(Dictionary<string, string>, Byte[], Exception)` - No upgrade instructions provided.
- ### NServiceBus.Faults.FirstLevelRetry
- #### Removed methods
- * `void .ctor(Dictionary<string, string>, Byte[], Exception, int)` - No upgrade instructions provided.
- ### NServiceBus.Faults.IManageMessageFailures
- #### Removed methods
- * `void Init(NServiceBus.Address)` - No upgrade instructions provided.
- * `void ProcessingAlwaysFailsForMessage(NServiceBus.TransportMessage, Exception)` - No upgrade instructions provided.
- * `void SerializationFailedForMessage(NServiceBus.TransportMessage, Exception)` - No upgrade instructions provided.
- ### NServiceBus.Features.SerializationFeatureHelper
- #### Removed methods
- * `bool ShouldSerializationFeatureBeEnabled(NServiceBus.Features.Feature, NServiceBus.Features.FeatureConfigurationContext)` - No upgrade instructions provided.
- ### NServiceBus.First<T>
- #### Removed methods
- * `NServiceBus.First<T> AndThen<K>()` - No upgrade instructions provided.
- * `IEnumerable<Type> get_Types()` - No upgrade instructions provided.
- * `NServiceBus.First<T> Then<K>()` - No upgrade instructions provided.
- ### NServiceBus.Gateway.Deduplication.IDeduplicateMessages
- #### Removed methods
- * `bool DeduplicateMessage(string, DateTime)` - No upgrade instructions provided.
- ### NServiceBus.HostInfoConfigurationExtensions
- #### Removed methods
- * `NServiceBus.HostInfoSettings UniquelyIdentifyRunningInstance(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.IAuthorizeSubscriptions
- #### Removed methods
- * `bool AuthorizeSubscribe(string, string, IDictionary<string, string>)` - No upgrade instructions provided.
- * `bool AuthorizeUnsubscribe(string, string, IDictionary<string, string>)` - No upgrade instructions provided.
- ### NServiceBus.IBus
- #### Removed methods
- * `NServiceBus.ICallback Defer(TimeSpan, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Defer(DateTime, object)` - No upgrade instructions provided.
- * `void DoNotContinueDispatchingCurrentMessageToHandlers()` - No upgrade instructions provided.
- * `void ForwardCurrentMessageTo(string)` - No upgrade instructions provided.
- * `NServiceBus.IMessageContext get_CurrentMessageContext()` - No upgrade instructions provided.
- * `NServiceBus.IInMemoryOperations get_InMemory()` - Removed to reduce complexity and API confusion.
- * `void HandleCurrentMessageLater()` - No upgrade instructions provided.
- * `void Reply(object)` - No upgrade instructions provided.
- * `void Reply<T>(Action<T>)` - No upgrade instructions provided.
- * `void Return<T>(T)` - No upgrade instructions provided.
- * `NServiceBus.ICallback SendLocal(object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback SendLocal<T>(Action<T>)` - No upgrade instructions provided.
- * `void Subscribe(Type)` - No upgrade instructions provided.
- * `void Subscribe<T>()` - No upgrade instructions provided.
- * `void Unsubscribe(Type)` - No upgrade instructions provided.
- * `void Unsubscribe<T>()` - No upgrade instructions provided.
- ### NServiceBus.ICallback
- #### Removed methods
- * `Task<int> Register()` - No upgrade instructions provided.
- * `Task<T> Register<T>()` - No upgrade instructions provided.
- * `Task<T> Register<T>(Func<NServiceBus.CompletionResult, T>)` - No upgrade instructions provided.
- * `Task Register(Action<NServiceBus.CompletionResult>)` - No upgrade instructions provided.
- * `IAsyncResult Register(AsyncCallback, object)` - No upgrade instructions provided.
- * `void Register<T>(Action<T>)` - No upgrade instructions provided.
- * `void Register<T>(Action<T>, object)` - No upgrade instructions provided.
- ### NServiceBus.IExcludesBuilder
- #### Removed methods
- * `NServiceBus.IExcludesBuilder And(string)` - No upgrade instructions provided.
- ### NServiceBus.IHandleMessages<T>
- #### Removed methods
- * `void Handle(T)` - No upgrade instructions provided.
- ### NServiceBus.IIncludesBuilder
- #### Removed methods
- * `NServiceBus.IIncludesBuilder And(string)` - No upgrade instructions provided.
- * `NServiceBus.IExcludesBuilder Except(string)` - No upgrade instructions provided.
- ### NServiceBus.IManageMessageHeaders
- #### Removed methods
- * `Func<object, string, string> get_GetHeaderAction()` - No upgrade instructions provided.
- * `Action<object, string, string> get_SetHeaderAction()` - No upgrade instructions provided.
- ### NServiceBus.IMessageContext
- #### Removed methods
- * `IDictionary<string, string> get_Headers()` - No upgrade instructions provided.
- * `string get_Id()` - No upgrade instructions provided.
- * `NServiceBus.Address get_ReplyToAddress()` - No upgrade instructions provided.
- ### NServiceBus.INeedInitialization
- #### Removed methods
- * `void Customize(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.Installation.INeedToInstallSomething
- #### Removed methods
- * `void Install(string, NServiceBus.Configure)` - No upgrade instructions provided.
- ### NServiceBus.InstallConfigExtensions
- #### Removed methods
- * `void EnableInstallers(NServiceBus.BusConfiguration, string)` - No upgrade instructions provided.
- ### NServiceBus.ISendOnlyBus
- #### Removed methods
- * `IDictionary<string, string> get_OutgoingHeaders()` - No upgrade instructions provided.
- * `void Publish<T>(T)` - No upgrade instructions provided.
- * `void Publish<T>()` - No upgrade instructions provided.
- * `void Publish<T>(Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(string, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(NServiceBus.Address, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(string, Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(NServiceBus.Address, Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(string, string, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(NServiceBus.Address, string, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(string, string, Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(NServiceBus.Address, string, Action<T>)` - No upgrade instructions provided.
- ### NServiceBus.ISpecifyMessageHandlerOrdering
- #### Removed methods
- * `void SpecifyOrder(NServiceBus.Order)` - No upgrade instructions provided.
- ### NServiceBus.IWantToRunBeforeConfigurationIsFinalized
- #### Removed methods
- * `void Run(NServiceBus.Configure)` - No upgrade instructions provided.
- ### NServiceBus.IWantToRunWhenBusStartsAndStops
- #### Removed methods
- * `void Start()` - No upgrade instructions provided.
- * `void Stop()` - No upgrade instructions provided.
- ### NServiceBus.LoadMessageHandlersExtentions
- #### Removed methods
- * `void LoadMessageHandlers<TFirst>(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `void LoadMessageHandlers<T>(NServiceBus.BusConfiguration, NServiceBus.First<T>)` - No upgrade instructions provided.
- ### NServiceBus.MessageMutator.IMutateIncomingMessages
- #### Removed methods
- * `object MutateIncoming(object)` - No upgrade instructions provided.
- ### NServiceBus.MessageMutator.IMutateIncomingTransportMessages
- #### Removed methods
- * `void MutateIncoming(NServiceBus.TransportMessage)` - No upgrade instructions provided.
- ### NServiceBus.MessageMutator.IMutateOutgoingMessages
- #### Removed methods
- * `object MutateOutgoing(object)` - No upgrade instructions provided.
- ### NServiceBus.MessageMutator.IMutateOutgoingTransportMessages
- #### Removed methods
- * `void MutateOutgoing(NServiceBus.Unicast.Messages.LogicalMessage, NServiceBus.TransportMessage)` - No upgrade instructions provided.
- ### NServiceBus.ObjectBuilder.Common.IContainer
- #### Removed methods
- * `void ConfigureProperty(Type, string, object)` - No upgrade instructions provided.
- ### NServiceBus.ObjectBuilder.IComponentConfig
- #### Removed methods
- * `NServiceBus.ObjectBuilder.IComponentConfig ConfigureProperty(string, object)` - No upgrade instructions provided.
- ### NServiceBus.ObjectBuilder.IComponentConfig<T>
- #### Removed methods
- * `NServiceBus.ObjectBuilder.IComponentConfig<T> ConfigureProperty(Expression<Func<T, object>>, object)` - No upgrade instructions provided.
- ### NServiceBus.ObjectBuilder.IConfigureComponents
- #### Removed methods
- * `NServiceBus.ObjectBuilder.IComponentConfig ConfigureComponent(Type, NServiceBus.DependencyLifecycle)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IComponentConfig<T> ConfigureComponent<T>(NServiceBus.DependencyLifecycle)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IComponentConfig<T> ConfigureComponent<T>(Func<T>, NServiceBus.DependencyLifecycle)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IComponentConfig<T> ConfigureComponent<T>(Func<NServiceBus.ObjectBuilder.IBuilder, T>, NServiceBus.DependencyLifecycle)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IConfigureComponents ConfigureProperty<T>(Expression<Func<T, object>>, object)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IConfigureComponents ConfigureProperty<T>(string, object)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IConfigureComponents RegisterSingleton(Type, object)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IConfigureComponents RegisterSingleton<T>(T)` - No upgrade instructions provided.
- ### NServiceBus.Order
- #### Removed methods
- * `IEnumerable<Type> get_Types()` - No upgrade instructions provided.
- * `void set_Types(IEnumerable<Type>)` - No upgrade instructions provided.
- * `void Specify<T>(NServiceBus.First<T>)` - No upgrade instructions provided.
- * `void Specify(Type[])` - No upgrade instructions provided.
- * `void SpecifyFirst<T>()` - No upgrade instructions provided.
- ### NServiceBus.Outbox.IOutboxStorage
- #### Removed methods
- * `void SetAsDispatched(string)` - No upgrade instructions provided.
- * `void Store(string, IEnumerable<NServiceBus.Outbox.TransportOperation>)` - No upgrade instructions provided.
- * `bool TryGet(string, NServiceBus.Outbox.OutboxMessage&)` - No upgrade instructions provided.
- ### NServiceBus.Outbox.OutboxMessage
- #### Removed methods
- * `void .ctor(string)` - No upgrade instructions provided.
- * `List<NServiceBus.Outbox.TransportOperation> get_TransportOperations()` - No upgrade instructions provided.
- ### NServiceBus.OutboxConfigExtensions
- #### Removed methods
- * `NServiceBus.Outbox.OutboxSettings EnableOutbox(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.PersistenceConfig
- #### Removed methods
- * `NServiceBus.PersistenceExtentions<T> UsePersistence<T>(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `NServiceBus.PersistenceExtentions<T, S> UsePersistence<T, S>(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `NServiceBus.PersistenceExtentions UsePersistence(NServiceBus.BusConfiguration, Type)` - No upgrade instructions provided.
- ### NServiceBus.Pipeline.Contexts.OutgoingContext
- #### Removed methods
- * `void .ctor(NServiceBus.Pipeline.BehaviorContext, NServiceBus.Unicast.DeliveryOptions, NServiceBus.Unicast.Messages.LogicalMessage)` - No upgrade instructions provided.
- * `NServiceBus.Unicast.DeliveryOptions get_DeliveryOptions()` - No upgrade instructions provided.
- * `NServiceBus.TransportMessage get_IncomingMessage()` - No upgrade instructions provided.
- * `NServiceBus.Unicast.Messages.LogicalMessage get_OutgoingLogicalMessage()` - No upgrade instructions provided.
- * `NServiceBus.TransportMessage get_OutgoingMessage()` - No upgrade instructions provided.
- ### NServiceBus.Pipeline.IBehavior<TContext>
- #### Removed methods
- * `void Invoke(TContext, Action)` - No upgrade instructions provided.
- ### NServiceBus.Pipeline.PipelineExecutor
- #### Removed methods
- * `void .ctor(NServiceBus.Settings.ReadOnlySettings, NServiceBus.ObjectBuilder.IBuilder, NServiceBus.BusNotifications)` - No upgrade instructions provided.
- * `void Dispose()` - No upgrade instructions provided.
- * `NServiceBus.Pipeline.BehaviorContext get_CurrentContext()` - No upgrade instructions provided.
- * `IList<NServiceBus.Pipeline.RegisterStep> get_Incoming()` - No upgrade instructions provided.
- * `IList<NServiceBus.Pipeline.RegisterStep> get_Outgoing()` - No upgrade instructions provided.
- * `void InvokePipeline<TContext>(IEnumerable<Type>, TContext)` - No upgrade instructions provided.
- ### NServiceBus.Pipeline.PipelineSettings
- #### Removed methods
- * `void .ctor(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `void Register(string, Type, string)` - No upgrade instructions provided.
- * `void Register(NServiceBus.Pipeline.WellKnownStep, Type, string)` - No upgrade instructions provided.
- ### NServiceBus.Sagas.ActiveSagaInstance
- #### Removed methods
- * `void AttachNewEntity(NServiceBus.Saga.IContainSagaData)` - No upgrade instructions provided.
- * `NServiceBus.Saga.Saga get_Instance()` - Please use `context.MessageHandler.Instance` instead.
- ### NServiceBus.Satellites.IAdvancedSatellite
- #### Removed methods
- * `Action<NServiceBus.Unicast.Transport.TransportReceiver> GetReceiverCustomization()` - No upgrade instructions provided.
- ### NServiceBus.Satellites.ISatellite
- #### Removed methods
- * `bool get_Disabled()` - No upgrade instructions provided.
- * `NServiceBus.Address get_InputAddress()` - No upgrade instructions provided.
- * `bool Handle(NServiceBus.TransportMessage)` - No upgrade instructions provided.
- * `void Start()` - No upgrade instructions provided.
- * `void Stop()` - No upgrade instructions provided.
- ### NServiceBus.ScaleOutExtentions
- #### Removed methods
- * `NServiceBus.Settings.ScaleOutSettings ScaleOut(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.Schedule
- #### Removed methods
- * `void .ctor(NServiceBus.ObjectBuilder.IBuilder)` - No upgrade instructions provided.
- * `void Every(TimeSpan, Action)` - No upgrade instructions provided.
- * `void Every(TimeSpan, string, Action)` - No upgrade instructions provided.
- ### NServiceBus.SecondLevelRetriesConfigExtensions
- #### Removed methods
- * `NServiceBus.SecondLevelRetries.Config.SecondLevelRetriesSettings SecondLevelRetries(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.SerializationConfigExtensions
- #### Removed methods
- * `NServiceBus.Serialization.SerializationExtentions<T> UseSerialization<T>(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `void UseSerialization(NServiceBus.BusConfiguration, Type)` - No upgrade instructions provided.
- ### NServiceBus.Serializers.Json.JsonMessageSerializer
- #### Removed methods
- * `void .ctor(NServiceBus.MessageInterfaces.IMessageMapper)` - No upgrade instructions provided.
- * `object DeserializeObject(string, Type)` - No upgrade instructions provided.
- * `Encoding get_Encoding()` - No upgrade instructions provided.
- * `string SerializeObject(object)` - No upgrade instructions provided.
- * `void set_Encoding(Encoding)` - No upgrade instructions provided.
- ### NServiceBus.Serializers.XML.XmlMessageSerializer
- #### Removed methods
- * `void .ctor(NServiceBus.MessageInterfaces.IMessageMapper, NServiceBus.Conventions)` - No upgrade instructions provided.
- * `Object[] Deserialize(Stream, IList<Type>)` - No upgrade instructions provided.
- * `string get_ContentType()` - No upgrade instructions provided.
- * `string get_Namespace()` - No upgrade instructions provided.
- * `bool get_SanitizeInput()` - No upgrade instructions provided.
- * `bool get_SkipWrappingRawXml()` - No upgrade instructions provided.
- * `void Initialize(IEnumerable<Type>)` - No upgrade instructions provided.
- * `void InitType(Type)` - No upgrade instructions provided.
- * `void Serialize(object, Stream)` - No upgrade instructions provided.
- * `void set_Namespace(string)` - No upgrade instructions provided.
- * `void set_SanitizeInput(bool)` - No upgrade instructions provided.
- * `void set_SkipWrappingRawXml(bool)` - No upgrade instructions provided.
- ### NServiceBus.Settings.ReadOnlySettings
- #### Removed methods
- * `void ApplyTo<T>(NServiceBus.ObjectBuilder.IComponentConfig)` - No upgrade instructions provided.
- ### NServiceBus.SettingsExtentions
- #### Removed methods
- * `string EndpointName(NServiceBus.Settings.ReadOnlySettings)` - No upgrade instructions provided.
- * `NServiceBus.Address LocalAddress(NServiceBus.Settings.ReadOnlySettings)` - No upgrade instructions provided.
- ### NServiceBus.SLAMonitoringConfig
- #### Removed methods
- * `void EnableSLAPerformanceCounter(NServiceBus.BusConfiguration, TimeSpan)` - No upgrade instructions provided.
- * `void EnableSLAPerformanceCounter(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- ### NServiceBus.Timeout.Core.IPersistTimeouts
- #### Removed methods
- * `void Add(NServiceBus.Timeout.Core.TimeoutData)` - No upgrade instructions provided.
- * `IEnumerable<Tuple<string, DateTime>> GetNextChunk(DateTime, DateTime&)` - No upgrade instructions provided.
- * `void RemoveTimeoutBy(Guid)` - No upgrade instructions provided.
- * `bool TryRemove(string, NServiceBus.Timeout.Core.TimeoutData&)` - No upgrade instructions provided.
- ### NServiceBus.Timeout.Core.TimeoutData
- #### Removed methods
- * `NServiceBus.Address get_Destination()` - No upgrade instructions provided.
- * `void set_Destination(NServiceBus.Address)` - No upgrade instructions provided.
- ### NServiceBus.TransportExtensions<T>
- #### Removed methods
- * `NServiceBus.TransportExtensions ConnectionString(string)` - No upgrade instructions provided.
- * `NServiceBus.TransportExtensions ConnectionString(Func<string>)` - No upgrade instructions provided.
- * `NServiceBus.TransportExtensions ConnectionStringName(string)` - No upgrade instructions provided.
- ### NServiceBus.TransportMessage
- #### Removed methods
- * `void .ctor(string, Dictionary<string, string>)` - No upgrade instructions provided.
- * `void .ctor(string, Dictionary<string, string>, NServiceBus.Address)` - Use `headers[Headers.ReplyToAddress]=replyToAddress; var tm = new TransportMessage(id,headers)` instead.
- * `NServiceBus.Address get_ReplyToAddress()` - No upgrade instructions provided.
- * `void set_MessageIntent(NServiceBus.MessageIntentEnum)` - No upgrade instructions provided.
- ### NServiceBus.Transports.IAuditMessages
- #### Removed methods
- * `void Audit(NServiceBus.Unicast.SendOptions, NServiceBus.TransportMessage)` - No upgrade instructions provided.
- ### NServiceBus.Transports.ICreateQueues
- #### Removed methods
- * `void CreateQueueIfNecessary(NServiceBus.Address, string)` - No upgrade instructions provided.
- ### NServiceBus.Transports.IDeferMessages
- #### Removed methods
- * `void Defer(NServiceBus.TransportMessage, NServiceBus.Unicast.SendOptions)` - No upgrade instructions provided.
- ### NServiceBus.Transports.IManageSubscriptions
- #### Removed methods
- * `void Subscribe(Type, NServiceBus.Address)` - No upgrade instructions provided.
- * `void Unsubscribe(Type, NServiceBus.Address)` - No upgrade instructions provided.
- ### NServiceBus.Transports.IPublishMessages
- #### Removed methods
- * `void Publish(NServiceBus.TransportMessage, NServiceBus.Unicast.PublishOptions)` - No upgrade instructions provided.
- ### NServiceBus.Transports.Msmq.Config.MsmqSettings
- #### Removed methods
- * `TimeSpan get_TimeToReachQueue()` - No upgrade instructions provided.
- * `bool get_UseConnectionCache()` - No upgrade instructions provided.
- * `bool get_UseDeadLetterQueue()` - No upgrade instructions provided.
- * `bool get_UseJournalQueue()` - No upgrade instructions provided.
- * `bool get_UseTransactionalQueues()` - No upgrade instructions provided.
- * `void set_TimeToReachQueue(TimeSpan)` - No upgrade instructions provided.
- * `void set_UseConnectionCache(bool)` - No upgrade instructions provided.
- * `void set_UseDeadLetterQueue(bool)` - No upgrade instructions provided.
- * `void set_UseJournalQueue(bool)` - No upgrade instructions provided.
- * `void set_UseTransactionalQueues(bool)` - No upgrade instructions provided.
- ### NServiceBus.Transports.Msmq.MsmqDequeueStrategy
- #### Removed methods
- * `void .ctor(NServiceBus.Configure, NServiceBus.CriticalError, NServiceBus.Transports.Msmq.MsmqUnitOfWork)` - No upgrade instructions provided.
- * `void Dispose()` - No upgrade instructions provided.
- * `NServiceBus.Address get_ErrorQueue()` - No upgrade instructions provided.
- * `void Init(NServiceBus.Address, NServiceBus.Unicast.Transport.TransactionSettings, Func<NServiceBus.TransportMessage, bool>, Action<NServiceBus.TransportMessage, Exception>)` - No upgrade instructions provided.
- * `void set_ErrorQueue(NServiceBus.Address)` - No upgrade instructions provided.
- * `void Start(int)` - No upgrade instructions provided.
- * `void Stop()` - No upgrade instructions provided.
- ### NServiceBus.Transports.Msmq.MsmqMessageSender
- #### Removed methods
- * `NServiceBus.Transports.Msmq.Config.MsmqSettings get_Settings()` - No upgrade instructions provided.
- * `bool get_SuppressDistributedTransactions()` - No upgrade instructions provided.
- * `NServiceBus.Transports.Msmq.MsmqUnitOfWork get_UnitOfWork()` - No upgrade instructions provided.
- * `void Send(NServiceBus.TransportMessage, NServiceBus.Unicast.SendOptions)` - No upgrade instructions provided.
- * `void set_Settings(NServiceBus.Transports.Msmq.Config.MsmqSettings)` - No upgrade instructions provided.
- * `void set_SuppressDistributedTransactions(bool)` - No upgrade instructions provided.
- * `void set_UnitOfWork(NServiceBus.Transports.Msmq.MsmqUnitOfWork)` - No upgrade instructions provided.
- ### NServiceBus.Transports.Msmq.MsmqUnitOfWork
- #### Removed methods
- * `void Dispose()` - No upgrade instructions provided.
- * `System.Messaging.MessageQueueTransaction get_Transaction()` - No upgrade instructions provided.
- * `bool HasActiveTransaction()` - No upgrade instructions provided.
- ### NServiceBus.Transports.TransportDefinition
- #### Removed methods
- * `bool get_RequireOutboxConsent()` - No upgrade instructions provided.
- * `void set_RequireOutboxConsent(bool)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Behaviors.MessageHandler
- #### Removed methods
- * `object get_Instance()` - No upgrade instructions provided.
- * `void set_Instance(object)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.BusAsyncResult
- #### Removed methods
- * `void .ctor(AsyncCallback, object)` - No upgrade instructions provided.
- * `void Complete(int, Object[])` - No upgrade instructions provided.
- * `object get_AsyncState()` - No upgrade instructions provided.
- * `WaitHandle get_AsyncWaitHandle()` - No upgrade instructions provided.
- * `bool get_CompletedSynchronously()` - No upgrade instructions provided.
- * `bool get_IsCompleted()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.DeliveryOptions
- #### Removed methods
- * `bool get_EnlistInReceiveTransaction()` - No upgrade instructions provided.
- * `NServiceBus.Address get_ReplyToAddress()` - No upgrade instructions provided.
- * `void set_EnlistInReceiveTransaction(bool)` - No upgrade instructions provided.
- * `void set_ReplyToAddress(NServiceBus.Address)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.IMessageHandlerRegistry
- #### Removed methods
- * `IEnumerable<Type> GetHandlerTypes(Type)` - No upgrade instructions provided.
- * `IEnumerable<Type> GetMessageTypes()` - No upgrade instructions provided.
- * `void InvokeHandle(object, object)` - No upgrade instructions provided.
- * `void InvokeTimeout(object, object)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.MessageContext
- #### Removed methods
- * `void .ctor(NServiceBus.TransportMessage)` - No upgrade instructions provided.
- * `DateTime get_TimeSent()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Messages.MessageMetadata
- #### Removed methods
- * `string ToString()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.PublishOptions
- #### Removed methods
- * `void .ctor(Type)` - No upgrade instructions provided.
- * `Type get_EventType()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Queuing.IWantQueueCreated
- #### Removed methods
- * `NServiceBus.Address get_Address()` - No upgrade instructions provided.
- * `bool ShouldCreateQueue()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Queuing.QueueNotFoundException
- #### Removed methods
- * `NServiceBus.Address get_Queue()` - No upgrade instructions provided.
- * `void set_Queue(NServiceBus.Address)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.ReplyOptions
- #### Removed methods
- * `void .ctor(NServiceBus.Address, string)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Routing.StaticMessageRouter
- #### Removed methods
- * `void .ctor(IEnumerable<Type>)` - No upgrade instructions provided.
- * `List<NServiceBus.Address> GetDestinationFor(Type)` - No upgrade instructions provided.
- * `void RegisterEventRoute(Type, NServiceBus.Address)` - No upgrade instructions provided.
- * `void RegisterMessageRoute(Type, NServiceBus.Address)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.SendOptions
- #### Removed methods
- * `void .ctor(string)` - No upgrade instructions provided.
- * `Nullable<DateTime> get_DeliverAt()` - No upgrade instructions provided.
- * `NServiceBus.Address get_Destination()` - No upgrade instructions provided.
- * `Nullable<TimeSpan> get_TimeToBeReceived()` - No upgrade instructions provided.
- * `void set_DeliverAt(Nullable<DateTime>)` - No upgrade instructions provided.
- * `void set_Destination(NServiceBus.Address)` - No upgrade instructions provided.
- * `void set_TimeToBeReceived(Nullable<TimeSpan>)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Subscriptions.MessageDrivenSubscriptions.ISubscriptionStorage
- #### Removed methods
- * `IEnumerable<NServiceBus.Address> GetSubscriberAddressesForMessage(IEnumerable<NServiceBus.Unicast.Subscriptions.MessageType>)` - No upgrade instructions provided.
- * `void Init()` - No upgrade instructions provided.
- * `void Subscribe(NServiceBus.Address, IEnumerable<NServiceBus.Unicast.Subscriptions.MessageType>)` - No upgrade instructions provided.
- * `void Unsubscribe(NServiceBus.Address, IEnumerable<NServiceBus.Unicast.Subscriptions.MessageType>)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Subscriptions.SubscriptionEventArgs
- #### Removed methods
- * `string get_MessageType()` - No upgrade instructions provided.
- * `NServiceBus.Address get_SubscriberReturnAddress()` - No upgrade instructions provided.
- * `void set_MessageType(string)` - No upgrade instructions provided.
- * `void set_SubscriberReturnAddress(NServiceBus.Address)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.ControlMessage
- #### Removed methods
- * `NServiceBus.TransportMessage Create()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.FailedMessageProcessingEventArgs
- #### Removed methods
- * `void .ctor(NServiceBus.TransportMessage, Exception)` - No upgrade instructions provided.
- * `NServiceBus.TransportMessage get_Message()` - No upgrade instructions provided.
- * `Exception get_Reason()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.FinishedMessageProcessingEventArgs
- #### Removed methods
- * `void .ctor(NServiceBus.TransportMessage)` - No upgrade instructions provided.
- * `NServiceBus.TransportMessage get_Message()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.ITransport
- #### Removed methods
- * `void AbortHandlingCurrentMessage()` - No upgrade instructions provided.
- * `void add_FailedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FailedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void add_FinishedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FinishedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void add_StartedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.StartedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void add_TransportMessageReceived(EventHandler<NServiceBus.Unicast.Transport.TransportMessageReceivedEventArgs>)` - No upgrade instructions provided.
- * `void ChangeMaximumConcurrencyLevel(int)` - No upgrade instructions provided.
- * `void ChangeMaximumMessageThroughputPerSecond(int)` - No upgrade instructions provided.
- * `int get_MaximumConcurrencyLevel()` - No upgrade instructions provided.
- * `int get_MaximumMessageThroughputPerSecond()` - No upgrade instructions provided.
- * `void remove_FailedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FailedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void remove_FinishedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FinishedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void remove_StartedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.StartedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void remove_TransportMessageReceived(EventHandler<NServiceBus.Unicast.Transport.TransportMessageReceivedEventArgs>)` - No upgrade instructions provided.
- * `void Start(NServiceBus.Address)` - No upgrade instructions provided.
- * `void Stop()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.StartedMessageProcessingEventArgs
- #### Removed methods
- * `void .ctor(NServiceBus.TransportMessage)` - No upgrade instructions provided.
- * `NServiceBus.TransportMessage get_Message()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.TransactionSettings
- #### Removed methods
- * `void .ctor(bool, TimeSpan, IsolationLevel, int, bool, bool)` - No upgrade instructions provided.
- * `int get_MaxRetries()` - No upgrade instructions provided.
- * `void set_MaxRetries(int)` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.TransportMessageAvailableEventArgs
- #### Removed methods
- * `void .ctor(NServiceBus.TransportMessage)` - No upgrade instructions provided.
- * `NServiceBus.TransportMessage get_Message()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.TransportMessageReceivedEventArgs
- #### Removed methods
- * `void .ctor(NServiceBus.TransportMessage)` - No upgrade instructions provided.
- * `NServiceBus.TransportMessage get_Message()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.Transport.TransportReceiver
- #### Removed methods
- * `void .ctor(NServiceBus.Unicast.Transport.TransactionSettings, int, int, NServiceBus.Transports.IDequeueMessages, NServiceBus.Faults.IManageMessageFailures, NServiceBus.Settings.ReadOnlySettings, NServiceBus.Configure)` - No upgrade instructions provided.
- * `void AbortHandlingCurrentMessage()` - No upgrade instructions provided.
- * `void add_FailedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FailedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void add_FinishedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FinishedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void add_StartedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.StartedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void add_TransportMessageReceived(EventHandler<NServiceBus.Unicast.Transport.TransportMessageReceivedEventArgs>)` - No upgrade instructions provided.
- * `void ChangeMaximumConcurrencyLevel(int)` - No upgrade instructions provided.
- * `void ChangeMaximumMessageThroughputPerSecond(int)` - No upgrade instructions provided.
- * `void Dispose()` - No upgrade instructions provided.
- * `NServiceBus.Faults.IManageMessageFailures get_FailureManager()` - No upgrade instructions provided.
- * `int get_MaximumConcurrencyLevel()` - No upgrade instructions provided.
- * `int get_MaximumMessageThroughputPerSecond()` - No upgrade instructions provided.
- * `NServiceBus.Transports.IDequeueMessages get_Receiver()` - No upgrade instructions provided.
- * `NServiceBus.Unicast.Transport.TransactionSettings get_TransactionSettings()` - No upgrade instructions provided.
- * `void remove_FailedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FailedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void remove_FinishedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.FinishedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void remove_StartedMessageProcessing(EventHandler<NServiceBus.Unicast.Transport.StartedMessageProcessingEventArgs>)` - No upgrade instructions provided.
- * `void remove_TransportMessageReceived(EventHandler<NServiceBus.Unicast.Transport.TransportMessageReceivedEventArgs>)` - No upgrade instructions provided.
- * `void set_FailureManager(NServiceBus.Faults.IManageMessageFailures)` - No upgrade instructions provided.
- * `void set_Receiver(NServiceBus.Transports.IDequeueMessages)` - No upgrade instructions provided.
- * `void Start(NServiceBus.Address)` - No upgrade instructions provided.
- * `void Stop()` - No upgrade instructions provided.
- ### NServiceBus.Unicast.UnicastBus
- #### Removed methods
- * `NServiceBus.ICallback Defer(TimeSpan, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Defer(DateTime, object)` - No upgrade instructions provided.
- * `void Dispose()` - No upgrade instructions provided.
- * `void DoNotContinueDispatchingCurrentMessageToHandlers()` - No upgrade instructions provided.
- * `void ForwardCurrentMessageTo(string)` - No upgrade instructions provided.
- * `NServiceBus.ObjectBuilder.IBuilder get_Builder()` - No upgrade instructions provided.
- * `NServiceBus.Configure get_Configure()` - No upgrade instructions provided.
- * `NServiceBus.CriticalError get_CriticalError()` - No upgrade instructions provided.
- * `NServiceBus.IMessageContext get_CurrentMessageContext()` - No upgrade instructions provided.
- * `bool get_DoNotStartTransport()` - No upgrade instructions provided.
- * `Func<object, string, string> get_GetHeaderAction()` - No upgrade instructions provided.
- * `NServiceBus.Hosting.HostInformation get_HostInformation()` - We have introduced a more explicit API to set the host identifier, see busConfiguration.UniquelyIdentifyRunningInstance().
- * `NServiceBus.Address get_InputAddress()` - No upgrade instructions provided.
- * `NServiceBus.MessageInterfaces.IMessageMapper get_MessageMapper()` - No upgrade instructions provided.
- * `NServiceBus.Unicast.Routing.StaticMessageRouter get_MessageRouter()` - No upgrade instructions provided.
- * `NServiceBus.Transports.ISendMessages get_MessageSender()` - No upgrade instructions provided.
- * `IDictionary<string, string> get_OutgoingHeaders()` - No upgrade instructions provided.
- * `bool get_PropagateReturnAddressOnSend()` - No upgrade instructions provided.
- * `Action<object, string, string> get_SetHeaderAction()` - No upgrade instructions provided.
- * `NServiceBus.Settings.ReadOnlySettings get_Settings()` - No upgrade instructions provided.
- * `NServiceBus.Transports.IManageSubscriptions get_SubscriptionManager()` - No upgrade instructions provided.
- * `NServiceBus.Unicast.Transport.ITransport get_Transport()` - No upgrade instructions provided.
- * `void HandleCurrentMessageLater()` - No upgrade instructions provided.
- * `void Publish<T>(Action<T>)` - No upgrade instructions provided.
- * `void Publish<T>()` - No upgrade instructions provided.
- * `void Publish<T>(T)` - No upgrade instructions provided.
- * `void Reply(object)` - No upgrade instructions provided.
- * `void Reply<T>(Action<T>)` - No upgrade instructions provided.
- * `void Return<T>(T)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(string, Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(NServiceBus.Address, Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(string, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(NServiceBus.Address, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(string, string, Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send<T>(NServiceBus.Address, string, Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(string, string, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback Send(NServiceBus.Address, string, object)` - No upgrade instructions provided.
- * `NServiceBus.ICallback SendLocal<T>(Action<T>)` - No upgrade instructions provided.
- * `NServiceBus.ICallback SendLocal(object)` - No upgrade instructions provided.
- * `void set_Builder(NServiceBus.ObjectBuilder.IBuilder)` - No upgrade instructions provided.
- * `void set_Configure(NServiceBus.Configure)` - No upgrade instructions provided.
- * `void set_CriticalError(NServiceBus.CriticalError)` - No upgrade instructions provided.
- * `void set_DoNotStartTransport(bool)` - No upgrade instructions provided.
- * `void set_HostInformation(NServiceBus.Hosting.HostInformation)` - We have introduced a more explicit API to set the host identifier, see busConfiguration.UniquelyIdentifyRunningInstance().
- * `void set_InputAddress(NServiceBus.Address)` - No upgrade instructions provided.
- * `void set_MessageMapper(NServiceBus.MessageInterfaces.IMessageMapper)` - No upgrade instructions provided.
- * `void set_MessageRouter(NServiceBus.Unicast.Routing.StaticMessageRouter)` - No upgrade instructions provided.
- * `void set_MessageSender(NServiceBus.Transports.ISendMessages)` - No upgrade instructions provided.
- * `void set_PropagateReturnAddressOnSend(bool)` - No upgrade instructions provided.
- * `void set_Settings(NServiceBus.Settings.ReadOnlySettings)` - No upgrade instructions provided.
- * `void set_SubscriptionManager(NServiceBus.Transports.IManageSubscriptions)` - No upgrade instructions provided.
- * `void set_Transport(NServiceBus.Unicast.Transport.ITransport)` - No upgrade instructions provided.
- * `NServiceBus.IBus Start()` - No upgrade instructions provided.
- * `void Subscribe<T>()` - No upgrade instructions provided.
- * `void Subscribe(Type)` - No upgrade instructions provided.
- * `void Unsubscribe<T>()` - No upgrade instructions provided.
- * `void Unsubscribe(Type)` - No upgrade instructions provided.
- ### NServiceBus.UnitOfWork.IManageUnitsOfWork
- #### Removed methods
- * `void Begin()` - No upgrade instructions provided.
- * `void End(Exception)` - No upgrade instructions provided.
- ### NServiceBus.UseDataBusExtensions
- #### Removed methods
- * `NServiceBus.DataBus.DataBusExtentions<T> UseDataBus<T>(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `NServiceBus.DataBus.DataBusExtentions UseDataBus(NServiceBus.BusConfiguration, Type)` - No upgrade instructions provided.
- ### NServiceBus.UseTransportExtensions
- #### Removed methods
- * `NServiceBus.TransportExtensions<T> UseTransport<T>(NServiceBus.BusConfiguration)` - No upgrade instructions provided.
- * `NServiceBus.TransportExtensions UseTransport(NServiceBus.BusConfiguration, Type)` - No upgrade instructions provided.
- ### NServiceBus.AutomaticSubscriptions.Config.AutoSubscribeSettings
- #### Removed methods
- * `void AutoSubscribePlainMessages()` - Encourages bad practices. IMessageSession.Subscribe should be explicitly used.
- * `void DoNotRequireExplicitRouting()` - Transports with support for centralized pubsub will default this to true. Can safely be removed.
- ### NServiceBus.Config.TransportConfig
- #### Removed methods
- * `int get_MaximumConcurrencyLevel()` - Please use `EndpointConfiguration.LimitMessageProcessingConcurrencyTo` instead.
- * `int get_MaximumMessageThroughputPerSecond()` - Message throughput throttling has been removed. Consult the documentation for further information.
- * `void set_MaximumConcurrencyLevel(int)` - Please use `EndpointConfiguration.LimitMessageProcessingConcurrencyTo` instead.
- * `void set_MaximumMessageThroughputPerSecond(int)` - Message throughput throttling has been removed. Consult the documentation for further information.
- ### NServiceBus.Config.UnicastBusConfig
- #### Removed methods
- * `string get_DistributorControlAddress()` - Switch to the code API by using 'EndpointConfiguration.EnlistWithLegacyMSMQDistributor' instead.
- * `string get_DistributorDataAddress()` - Switch to the code API by using 'EndpointConfiguration.EnlistWithLegacyMSMQDistributor' instead.
- * `string get_ForwardReceivedMessagesTo()` - Use 'EndpointConfiguration.ForwardReceivedMessagesTo' to configure the forwarding address.
- * `void set_DistributorControlAddress(string)` - Switch to the code API by using 'EndpointConfiguration.EnlistWithLegacyMSMQDistributor' instead.
- * `void set_DistributorDataAddress(string)` - Switch to the code API by using 'EndpointConfiguration.EnlistWithLegacyMSMQDistributor' instead.
- * `void set_ForwardReceivedMessagesTo(string)` - Use 'EndpointConfiguration.ForwardReceivedMessagesTo' to configure the forwarding address.
- ### NServiceBus.ConfigurePurging
- #### Removed methods
- * `bool PurgeOnStartup(NServiceBus.Configure)` - Will be removed in version 7.0.0.
- ### NServiceBus.ConfigureQueueCreation
- #### Removed methods
- * `bool CreateQueues(NServiceBus.Configure)` - Please use `CreateQueues` instead.
- ### NServiceBus.ConfigureTransportConnectionString
- #### Removed methods
- * `string TransportConnectionString(NServiceBus.Configure)` - Not available any more.
- ### NServiceBus.Conventions
- #### Removed methods
- * `TimeSpan GetTimeToBeReceived(Type)` - No longer an extension point.
- * `bool IsExpressMessageType(Type)` - No longer an extension point.
- ### NServiceBus.DurableMessagesConfig
- #### Removed methods
- * `bool DurableMessagesEnabled(NServiceBus.Configure)` - Please use `DurableMessagesEnabled` instead.
- ### NServiceBus.ExtensionMethods
- #### Removed methods
- * `object get_CurrentMessageBeingHandled()` - Use a incoming behavior to get access to the current message.
- * `string GetMessageHeader(NServiceBus.IBus, object, string)` - Headers are not 'set' only on the outgoing pipeline.
- * `void set_CurrentMessageBeingHandled(object)` - Use a incoming behavior to get access to the current message.
- ### NServiceBus.Hosting.Helpers.AssemblyScanner
- #### Removed methods
- * `List<Assembly> get_MustReferenceAtLeastOneAssembly()` - This method is no longer required since deep scanning of assemblies is done to detect an NServiceBus reference.
- ### NServiceBus.IStartableBus
- #### Removed methods
- * `NServiceBus.IBus Start()` - Please use `IStartableEndpoint` instead.
- ### NServiceBus.Outbox.OutboxSettings
- #### Removed methods
- * `void TimeToKeepDeduplicationData(TimeSpan)` - Please use `InMemoryOutboxSettingsExtensions.TimeToKeepDeduplicationData(TimeSpan time)` instead.
- ### NServiceBus.Sagas.ActiveSagaInstance
- #### Removed methods
- * `Type get_SagaType()` - Please use `.Metadata.SagaType` instead.
- ### NServiceBus.SecondLevelRetries.Config.SecondLevelRetriesSettings
- #### Removed methods
- * `void CustomRetryPolicy(Func<NServiceBus.TransportMessage, TimeSpan>)` - Please use `CustomRetryPolicy(Func<IncomingMessage, TimeSpan> customPolicy)` instead.
- ### NServiceBus.Settings.ScaleOutSettings
- #### Removed methods
- * `void UniqueQueuePerEndpointInstance()` - Not required any more as for MSMQ this is the default behavior and for other transports the unique instance ID has to be provided.
- * `void UniqueQueuePerEndpointInstance(string)` - Please use `EndpointConfiguration.ScaleOut().InstanceDiscriminator(string discriminator)` instead.
- * `void UseSingleBrokerQueue()` - This is the default starting with V6.
- * `void UseUniqueBrokerQueuePerMachine()` - Not required any more as for MSMQ this is the default behavior and for other transports the unique instance ID has to be provided.
- ### NServiceBus.Settings.SettingsHolder
- #### Removed methods
- * `void ApplyTo<T>(NServiceBus.ObjectBuilder.IComponentConfig)` - Setting property values explicitly is no longer supported via this API. Use `.ConfigureComponent(b=> new MyMessageHandler(){ MyProperty = X})` to get full control over handler creation.
- ### NServiceBus.Settings.TransactionSettings
- #### Removed methods
- * `NServiceBus.Settings.TransactionSettings DefaultTimeout(TimeSpan)` - Please use `config.UnitOfWork().WrapHandlersInATransactionScope(timeout: TimeSpan.FromSeconds(X));` instead.
- * `NServiceBus.Settings.TransactionSettings Disable()` - Please use `config.UseTransport<MyTransport>().Transactions(TransportTransactionMode.None);` instead.
- * `NServiceBus.Settings.TransactionSettings DisableDistributedTransactions()` - Please use `config.UseTransport<MyTransport>().Transactions(TransportTransactionMode.ReceiveOnly|TransportTransactionMode.SendsAtomicWithReceive);` instead.
- * `NServiceBus.Settings.TransactionSettings DoNotWrapHandlersExecutionInATransactionScope()` - DoNotWrapHandlersExecutionInATransactionScope() has been removed since transaction scopes are no longer used by non DTC transports delay the dispatch of all outgoing operations until handlers have been executed.
- In Version 6 handlers will only be wrapped in a transactionscope if running the MSMQ or SQLServer transports in default mode. This means that performing storage operations against data sources also supporting transaction scopes
- will escalate to a distributed transaction. Previous versions allowed opting out of this behavior using config.Transactions().DoNotWrapHandlersExecutionInATransactionScope(). In Version 6 it's recommended to use `EndpointConfiguration.UseTransport<MyTransport>().Transactions(TransportTransactionMode.ReceiveOnly)` to lean on native transport transaction and the new batched dispatch support to achieve the same level of consistency with better performance.
- Suppressing the ambient transaction created by the MSMQ and SQL Server transports can still be achieved by creating a custom pipeline behavior with a suppressed transaction scope.
- * `NServiceBus.Settings.TransactionSettings Enable()` - Please use `config.UseTransport<MyTransport>().Transactions(TransportTransactionMode.ReceiveOnly|TransportTransactionMode.SendsAtomicWithReceive);` instead.
- * `NServiceBus.Settings.TransactionSettings EnableDistributedTransactions()` - Please use `config.UseTransport<MyTransport>().Transactions(TransportTransactionMode.TransactionScope);` instead.
- * `NServiceBus.Settings.TransactionSettings IsolationLevel(IsolationLevel)` - Please use `config.UnitOfWork().WrapHandlersInATransactionScope(isolationLevel: IsolationLevel.X);` instead.
- * `NServiceBus.Settings.TransactionSettings WrapHandlersExecutionInATransactionScope()` - Please use `config.UnitOfWork().WrapHandlersInATransactionScope();` instead.
- ### NServiceBus.Timeout.Core.TimeoutData
- #### Removed fields
- * `string OriginalReplyToAddress` - Not used anymore.
- #### Removed methods
- * `NServiceBus.Unicast.SendOptions ToSendOptions(NServiceBus.Address)` - Use new SendOptions() instead.
- * `NServiceBus.TransportMessage ToTransportMessage()` - Use new OutgoingMessage(timeoutData.State) instead.
- ### NServiceBus.TransportMessage
- #### Removed methods
- * `Byte[] get_Body()` - Use the value of the 'IncomingMessage.Body' or 'OutgoingMessage.Body' instead.
- * `string get_CorrelationId()` - Use the value of the 'NServiceBus.CorrelationId' header instead.
- * `Dictionary<string, string> get_Headers()` - Use the value of the 'IncomingMessage.Headers' or 'OutgoingMesssage.Headers' instead.
- * `string get_Id()` - Use the value of the 'IncomingMessage.MessageId' or 'OutgoingMesssage.MessageId' instead.
- * `NServiceBus.MessageIntentEnum get_MessageIntent()` - Please use `GetMessageIntent(this IncomingMessage message)` instead.
- * `bool get_Recoverable()` - For sending purposes use `DeliveryConstraintContextExtensions.AddDeliveryConstraint(new NonDurableDelivery())` to set NonDurable delivery or `NonDurableDelivery constraint;DeliveryConstraintContextExtensions.TryGetDeliveryConstraint(out constraint)` to read wether NonDurable delivery is set. When receiving look at the new 'NServiceBus.NonDurableMessage' header.
- * `TimeSpan get_TimeToBeReceived()` - For sending purposes use `DeliveryConstraintContextExtensions.AddDeliveryConstraint(new DiscardIfNotReceivedBefore(timeToBeReceived))` to set the `TimeToBeReceived` or `DiscardIfNotReceivedBefore constraint;DeliveryConstraintContextExtensions.TryGetDeliveryConstraint(out constraint)` to read the `TimeToBeReceived`. When receiving look at the new 'NServiceBus.TimeToBeReceived' header.
- * `void set_Body(Byte[])` - Use the value of the 'IncomingMessage.Body' or 'OutgoingMessage.Body' instead.
- * `void set_CorrelationId(string)` - Use the value of the 'NServiceBus.CorrelationId' header instead.
- * `void set_Recoverable(bool)` - For sending purposes use `DeliveryConstraintContextExtensions.AddDeliveryConstraint(new NonDurableDelivery())` to set NonDurable delivery or `NonDurableDelivery constraint;DeliveryConstraintContextExtensions.TryGetDeliveryConstraint(out constraint)` to read wether NonDurable delivery is set. When receiving look at the new 'NServiceBus.NonDurableMessage' header.
- * `void set_TimeToBeReceived(TimeSpan)` - For sending purposes use `DeliveryConstraintContextExtensions.AddDeliveryConstraint(new DiscardIfNotReceivedBefore(timeToBeReceived))` to set the `TimeToBeReceived` or `DiscardIfNotReceivedBefore constraint;DeliveryConstraintContextExtensions.TryGetDeliveryConstraint(out constraint)` to read the `TimeToBeReceived`. When receiving look at the new 'NServiceBus.TimeToBeReceived' header.
- ### NServiceBus.Transports.IDeferMessages
- #### Removed methods
- * `void ClearDeferredMessages(string, string)` - Please use `ICancelDeferredMessages` instead.
- ### NServiceBus.Transports.TransportDefinition
- #### Removed methods
- * `bool get_HasNativePubSubSupport()` - Use TransportInfrastructure.OutboundRoutingPolicy.Publishes == OutboundRoutingType.Multicast instead.
- * `bool get_HasSupportForCentralizedPubSub()` - The concept of centralized publish and subscribe is no longer available.
- * `Nullable<bool> get_HasSupportForDistributedTransactions()` - Use TransportInfrastructure.TransactionMode == TransportTransactionMode.TransactionScope instead.
- ### NServiceBus.Unicast.Behaviors.MessageHandler
- #### Removed methods
- * `void .ctor()` - Please use `NServiceBus.Pipeline.MessageHandler(Action<object, object, object> invocation, Type handlerType)` instead.
- * `Action<object, object> get_Invocation()` - Please use `NServiceBus.Pipeline.MessageHandler.Invoke` instead.
- * `void set_Invocation(Action<object, object>)` - Please use `NServiceBus.Pipeline.MessageHandler.Invoke` instead.
- ### NServiceBus.Unicast.DeliveryOptions
- #### Removed methods
- * `bool get_EnforceMessagingBestPractices()` - Turn best practices check off using configuration.DisableFeature<BestPracticeEnforcement>().
- * `void set_EnforceMessagingBestPractices(bool)` - Turn best practices check off using configuration.DisableFeature<BestPracticeEnforcement>().
- ### NServiceBus.Unicast.MessageHandlerRegistry
- #### Removed methods
- * `void CacheMethodForHandler(Type, Type)` - Please use `MessageHandlerRegistry.RegisterHandler(Type handlerType)` instead.
- * `IEnumerable<Type> GetHandlerTypes(Type)` - Please use `MessageHandlerRegistry.GetHandlersFor(Type messageType)` instead.
- * `void InvokeHandle(object, object)` - Please use `MessageHandler.Invoke(object message, object context)` instead.
- * `void InvokeTimeout(object, object)` - Please use `MessageHandler.Invoke(object message, object context)` instead.
- ### NServiceBus.Unicast.Messages.MessageMetadata
- #### Removed methods
- * `bool get_Recoverable()` - You can access Recoverable via the DeliveryConstraints collection on the outgoing context, the new constraint is called NonDurableDelivery.
- * `TimeSpan get_TimeToBeReceived()` - You can access TTBR via the DeliveryConstraints collection on the outgoing context.
- ### NServiceBus.Unicast.Queuing.QueueNotFoundException
- #### Removed methods
- * `void .ctor(NServiceBus.Address, string, Exception)` - Please use `QueueNotFoundException(string queue, string message, Exception inner)` instead.
- ### NServiceBus.Unicast.Routing.StaticMessageRouter
- #### Removed methods
- * `bool get_SubscribeToPlainMessages()` - Please use `config.AutoSubscribe().AutoSubscribePlainMessages()` instead.
- * `void set_SubscribeToPlainMessages(bool)` - Please use `config.AutoSubscribe().AutoSubscribePlainMessages()` instead.
- ### NServiceBus.Unicast.SendOptions
- #### Removed methods
- * `void .ctor(NServiceBus.Address)` - Please use `SendMessageOptions(string)` instead.
- * `string get_CorrelationId()` - Reply to address can be get/set using the `NServiceBus.CorrelationId` header.
- * `Nullable<TimeSpan> get_DelayDeliveryWith()` - Please use `DelayDeliveryFor` instead.
- * `void set_CorrelationId(string)` - Reply to address can be get/set using the `NServiceBus.CorrelationId` header.
- * `void set_DelayDeliveryWith(Nullable<TimeSpan>)` - Please use `DelayDeliveryFor` instead.
- ### NServiceBus.Unicast.Transport.TransactionSettings
- #### Removed methods
- * `bool get_DoNotWrapHandlersExecutionInATransactionScope()` - DoNotWrapHandlersExecutionInATransactionScope is no longer used here. Use settings.GetOrDefault<bool>('Transactions.DoNotWrapHandlersExecutionInATransactionScope') instead.
- * `IsolationLevel get_IsolationLevel()` - Isolation level are now controlled explicitly for the transaction scope unit of work using config.UnitOfWork().WrapHandlersInATransactionScope(isolationlevel: X).
- * `bool get_IsTransactional()` - IsTransactional is no longer used here. Use `context.Settings.GetRequiredTransactionModeForReceives() != Transactions.None` instead.
- * `bool get_SuppressDistributedTransactions()` - SuppressDistributedTransactions is no longer used here. Uuse `context.Settings.GetRequiredTransactionModeForReceives() != Transactions.TransactionScope` instead.
- * `TimeSpan get_TransactionTimeout()` - Timeouts are now controlled explicitly for the transaction scope unit of work using config.UnitOfWork().WrapHandlersInATransactionScope(timeout: X).
- * `void set_DoNotWrapHandlersExecutionInATransactionScope(bool)` - DoNotWrapHandlersExecutionInATransactionScope is no longer used here. Use settings.GetOrDefault<bool>('Transactions.DoNotWrapHandlersExecutionInATransactionScope') instead.
- * `void set_IsolationLevel(IsolationLevel)` - Isolation level are now controlled explicitly for the transaction scope unit of work using config.UnitOfWork().WrapHandlersInATransactionScope(isolationlevel: X).
- * `void set_IsTransactional(bool)` - IsTransactional is no longer used here. Use `context.Settings.GetRequiredTransactionModeForReceives() != Transactions.None` instead.
- * `void set_SuppressDistributedTransactions(bool)` - SuppressDistributedTransactions is no longer used here. Uuse `context.Settings.GetRequiredTransactionModeForReceives() != Transactions.TransactionScope` instead.
- * `void set_TransactionTimeout(TimeSpan)` - Timeouts are now controlled explicitly for the transaction scope unit of work using config.UnitOfWork().WrapHandlersInATransactionScope(timeout: X).
- ### NServiceBus.Headers
- #### Removed fields
- * `string WindowsIdentityName` - The WinIdName header is no longer attached to outgoing message to avoid passing security related information on the wire. Should you rely on the header being present you can add a message mutator that sets it.
- ### NServiceBus.Pipeline.WellKnownStep
- #### Removed fields
- * `NServiceBus.Pipeline.WellKnownStep CreateChildContainer` - The child container creation is now an integral part of the pipeline invocation and no longer a separate behavior.
- * `NServiceBus.Pipeline.WellKnownStep DispatchMessageToTransport` - The dispatch step is the terminating step in v6 so any dependency on it can safely be removed.
Advertisement
Add Comment
Please, Sign In to add comment
Advertisement