No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
Removed to reduce complexity and API confusion.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
No upgrade instructions provided.
Use the string based overloads.
Please use EndpointConfiguration.ExcludeAssemblies
instead.
No longer used, use the new callbacks api described in the version 6 upgrade guide.
Please use EndpointConfiguration
instead.
Please use Notifications
instead.
Replaced by NServiceBus.Callbacks package.
Use the feature concept instead via A class which inherits from NServiceBus.Features.Feature
and use configuration.EnableFeature<YourClass>()
.
Please use EndpointConfiguration.EnlistWithLegacyMSMQDistributor
instead.
This is no longer a public API.
Will be removed in version 7.0.0.
Headers are not managed via the send, reply and publishoptions.
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.
Use the ConfigureSerialization Feature class instead. Please use ConfigureSerialization
instead.
No longer used, safe to remove.
No longer used, safe to remove.
Please use EndpointConfiguration.ExecuteTheseHandlersFirst
instead.
Please use config.UseTransport<MsmqTransport>().SubscriptionAuthorizer(Authorizer);
instead.
IHandleMessages 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.
Replaced by NServiceBus.Callbacks package.
Will be removed in version 7.0.0.
Will be removed in version 7.0.0.
No longer used, can safely be removed.
Use IMessageHandlerContext
provided to message handlers instead.
Use IEndpointInstance to create sending session.
Please use EndpointConfiguration.ExecuteTheseHandlersFirst
instead.
Please use IStartableEndpoint
instead.
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.
Have the mutator implement both IMutateOutgoingMessages and IMutateIncomingMessages.
Have the mutator implement both IMutateIncomingTransportMessages and IMutateOutgoingTransportMessages.
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.
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.
Please use EndpointConfiguration.ExecuteTheseHandlersFirst
instead.
Please use NServiceBus.Persistence.StorageType
instead.
Please use OutgoingLogicalMessage
instead.
Please use Behavior<T>
instead.
The pipeline context is no longer avaliable via dependency injection. Use a custom behavior as described in the version 6 upgrade guide.
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.
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.
Use extension methods provided on ISendOnlyBus.
Built-in serializers are internal. Switch to an alternative (e.g. Json.net) or copy the serializer code.
Built-in serializers are internal. Switch to an alternative (e.g. XmlSerializer) or copy the serializer code.
Not used anymore, use OutgoingMessage
or IncomingMessage
instead.
No longer used, safe to remove.
Please use IDispatchMessages
instead.
Please use NServiceBus.Transport.IPushMessages
instead.
Please use IDispatchMessages
instead.
Please use IDispatchMessages
instead.
No longer available, see the documentation for native sends for alternative solutions.
No longer available, resolve an instance of IPushMessages from the container instead.
No longer available, see the documentation for native sends for alternative solutions.
The msmq transaction is now available via the pipeline context.
No longer used, use the new callbacks api described in the version 6 upgrade guide.
Please use NServiceBus.UnicastBus.DeliveryMessageOptions
instead.
Not a public API. Please use MessageHandlerRegistry
instead.
Will be removed in version 7.0.0.
Use context.Intent to detect of the message is a event being published and use context.MessageType to get the actual event type.
Please use QueueBindings
instead.
Not used anymore, use the 'NServiceBus.MessageIntent' header to detect if the message is a reply.
No longer used, safe to remove.
Please use NServiceBus.UnicastBus.SendMessageOptions
instead.
No longer used, safe to remove.
No longer used, can safely be removed.
Use the pipeline to catch failures.
No longer used, can safely be removed.
Please use IPushMessages
instead.
No longer used, can safely be removed.
Transaction settings is no longer available via this class. See obsoletes on individual members for further details.
No longer used, can safely be removed.
No longer used, can safely be removed.
No longer used, can safely be removed.
UnicastBus has been made internal. Use IEndpointInstance instead.
NServiceBus.Address Self
- No upgrade instructions provided.NServiceBus.Address Undefined
- No upgrade instructions provided.
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.
string Binary
- No upgrade instructions provided.string Bson
- No upgrade instructions provided.
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 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.IExcludesBuilder Except(string)
- No upgrade instructions provided.IEnumerator<Assembly> GetEnumerator()
- No upgrade instructions provided.NServiceBus.IIncludesBuilder Matching(string)
- No upgrade instructions provided.
NServiceBus.AutomaticSubscriptions.Config.AutoSubscribeSettings AutoSubscribe(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
NServiceBus.IStartableBus Create(NServiceBus.BusConfiguration)
- No upgrade instructions provided.NServiceBus.ISendOnlyBus CreateSendOnly(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
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.
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.Faults.ErrorsNotifications get_Errors()
- No upgrade instructions provided.NServiceBus.Pipeline.PipelineNotifications get_Pipeline()
- No upgrade instructions provided.
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.
void Run(NServiceBus.Configure)
- No upgrade instructions provided.
string get_Node()
- No upgrade instructions provided.void set_Node(string)
- No upgrade instructions provided.
void Configure(Action<Type, NServiceBus.Address>)
- No upgrade instructions provided.
void TimeToWaitBeforeTriggeringCriticalErrorOnTimeoutOutages(NServiceBus.BusConfiguration, TimeSpan)
- No upgrade instructions provided.
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.
void DefineCriticalErrorAction(NServiceBus.BusConfiguration, Action<string, Exception>)
- No upgrade instructions provided.
void DiscardFailedMessagesInsteadOfSendingToErrorQueue(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
void License(NServiceBus.BusConfiguration, string)
- No upgrade instructions provided.void LicensePath(NServiceBus.BusConfiguration, string)
- No upgrade instructions provided.
void PurgeOnStartup(NServiceBus.BusConfiguration, bool)
- No upgrade instructions provided.
void DoNotCreateQueues(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
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 useRijndaelEncryptionService(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.
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.
void .ctor(Action<string, Exception>, NServiceBus.Configure)
- No upgrade instructions provided.
void EnableCriticalTimePerformanceCounter(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
Stream Get(string)
- No upgrade instructions provided.string Put(Stream, TimeSpan)
- No upgrade instructions provided.void Start()
- No upgrade instructions provided.
void DisableDurableMessages(NServiceBus.BusConfiguration)
- No upgrade instructions provided.void EnableDurableMessages(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
void SetMessageHeader(NServiceBus.ISendOnlyBus, object, string, string)
- No upgrade instructions provided.
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.
void .ctor(Dictionary<string, string>, Byte[], Exception)
- No upgrade instructions provided.
void .ctor(Dictionary<string, string>, Byte[], Exception, int)
- No upgrade instructions provided.
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.
bool ShouldSerializationFeatureBeEnabled(NServiceBus.Features.Feature, NServiceBus.Features.FeatureConfigurationContext)
- No upgrade instructions provided.
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.
bool DeduplicateMessage(string, DateTime)
- No upgrade instructions provided.
NServiceBus.HostInfoSettings UniquelyIdentifyRunningInstance(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
bool AuthorizeSubscribe(string, string, IDictionary<string, string>)
- No upgrade instructions provided.bool AuthorizeUnsubscribe(string, string, IDictionary<string, string>)
- No upgrade instructions provided.
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.
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 And(string)
- No upgrade instructions provided.
void Handle(T)
- No upgrade instructions provided.
NServiceBus.IIncludesBuilder And(string)
- No upgrade instructions provided.NServiceBus.IExcludesBuilder Except(string)
- No upgrade instructions provided.
Func<object, string, string> get_GetHeaderAction()
- No upgrade instructions provided.Action<object, string, string> get_SetHeaderAction()
- No upgrade instructions provided.
IDictionary<string, string> get_Headers()
- No upgrade instructions provided.string get_Id()
- No upgrade instructions provided.NServiceBus.Address get_ReplyToAddress()
- No upgrade instructions provided.
void Customize(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
void Install(string, NServiceBus.Configure)
- No upgrade instructions provided.
void EnableInstallers(NServiceBus.BusConfiguration, string)
- No upgrade instructions provided.
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.
void SpecifyOrder(NServiceBus.Order)
- No upgrade instructions provided.
void Run(NServiceBus.Configure)
- No upgrade instructions provided.
void Start()
- No upgrade instructions provided.void Stop()
- No upgrade instructions provided.
void LoadMessageHandlers<TFirst>(NServiceBus.BusConfiguration)
- No upgrade instructions provided.void LoadMessageHandlers<T>(NServiceBus.BusConfiguration, NServiceBus.First<T>)
- No upgrade instructions provided.
object MutateIncoming(object)
- No upgrade instructions provided.
void MutateIncoming(NServiceBus.TransportMessage)
- No upgrade instructions provided.
object MutateOutgoing(object)
- No upgrade instructions provided.
void MutateOutgoing(NServiceBus.Unicast.Messages.LogicalMessage, NServiceBus.TransportMessage)
- No upgrade instructions provided.
void ConfigureProperty(Type, string, object)
- No upgrade instructions provided.
NServiceBus.ObjectBuilder.IComponentConfig ConfigureProperty(string, object)
- No upgrade instructions provided.
NServiceBus.ObjectBuilder.IComponentConfig<T> ConfigureProperty(Expression<Func<T, object>>, object)
- No upgrade instructions provided.
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.
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.
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.
void .ctor(string)
- No upgrade instructions provided.List<NServiceBus.Outbox.TransportOperation> get_TransportOperations()
- No upgrade instructions provided.
NServiceBus.Outbox.OutboxSettings EnableOutbox(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
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.
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.
void Invoke(TContext, Action)
- No upgrade instructions provided.
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.
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.
void AttachNewEntity(NServiceBus.Saga.IContainSagaData)
- No upgrade instructions provided.NServiceBus.Saga.Saga get_Instance()
- Please usecontext.MessageHandler.Instance
instead.
Action<NServiceBus.Unicast.Transport.TransportReceiver> GetReceiverCustomization()
- No upgrade instructions provided.
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.Settings.ScaleOutSettings ScaleOut(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
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.SecondLevelRetries.Config.SecondLevelRetriesSettings SecondLevelRetries(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
NServiceBus.Serialization.SerializationExtentions<T> UseSerialization<T>(NServiceBus.BusConfiguration)
- No upgrade instructions provided.void UseSerialization(NServiceBus.BusConfiguration, Type)
- No upgrade instructions provided.
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.
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.
void ApplyTo<T>(NServiceBus.ObjectBuilder.IComponentConfig)
- No upgrade instructions provided.
string EndpointName(NServiceBus.Settings.ReadOnlySettings)
- No upgrade instructions provided.NServiceBus.Address LocalAddress(NServiceBus.Settings.ReadOnlySettings)
- No upgrade instructions provided.
void EnableSLAPerformanceCounter(NServiceBus.BusConfiguration, TimeSpan)
- No upgrade instructions provided.void EnableSLAPerformanceCounter(NServiceBus.BusConfiguration)
- No upgrade instructions provided.
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.Address get_Destination()
- No upgrade instructions provided.void set_Destination(NServiceBus.Address)
- No upgrade instructions provided.
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.
void .ctor(string, Dictionary<string, string>)
- No upgrade instructions provided.void .ctor(string, Dictionary<string, string>, NServiceBus.Address)
- Useheaders[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.
void Audit(NServiceBus.Unicast.SendOptions, NServiceBus.TransportMessage)
- No upgrade instructions provided.
void CreateQueueIfNecessary(NServiceBus.Address, string)
- No upgrade instructions provided.
void Defer(NServiceBus.TransportMessage, NServiceBus.Unicast.SendOptions)
- No upgrade instructions provided.
void Subscribe(Type, NServiceBus.Address)
- No upgrade instructions provided.void Unsubscribe(Type, NServiceBus.Address)
- No upgrade instructions provided.
void Publish(NServiceBus.TransportMessage, NServiceBus.Unicast.PublishOptions)
- No upgrade instructions provided.
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.
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.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.
void Dispose()
- No upgrade instructions provided.System.Messaging.MessageQueueTransaction get_Transaction()
- No upgrade instructions provided.bool HasActiveTransaction()
- No upgrade instructions provided.
bool get_RequireOutboxConsent()
- No upgrade instructions provided.void set_RequireOutboxConsent(bool)
- No upgrade instructions provided.
object get_Instance()
- No upgrade instructions provided.void set_Instance(object)
- No upgrade instructions provided.
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.
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.
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.
void .ctor(NServiceBus.TransportMessage)
- No upgrade instructions provided.DateTime get_TimeSent()
- No upgrade instructions provided.
string ToString()
- No upgrade instructions provided.
void .ctor(Type)
- No upgrade instructions provided.Type get_EventType()
- No upgrade instructions provided.
NServiceBus.Address get_Address()
- No upgrade instructions provided.bool ShouldCreateQueue()
- No upgrade instructions provided.
NServiceBus.Address get_Queue()
- No upgrade instructions provided.void set_Queue(NServiceBus.Address)
- No upgrade instructions provided.
void .ctor(NServiceBus.Address, string)
- No upgrade instructions provided.
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.
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.
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.
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.TransportMessage Create()
- No upgrade instructions provided.
void .ctor(NServiceBus.TransportMessage, Exception)
- No upgrade instructions provided.NServiceBus.TransportMessage get_Message()
- No upgrade instructions provided.Exception get_Reason()
- No upgrade instructions provided.
void .ctor(NServiceBus.TransportMessage)
- No upgrade instructions provided.NServiceBus.TransportMessage get_Message()
- 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.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.
void .ctor(NServiceBus.TransportMessage)
- No upgrade instructions provided.NServiceBus.TransportMessage get_Message()
- No upgrade instructions provided.
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.
void .ctor(NServiceBus.TransportMessage)
- No upgrade instructions provided.NServiceBus.TransportMessage get_Message()
- No upgrade instructions provided.
void .ctor(NServiceBus.TransportMessage)
- No upgrade instructions provided.NServiceBus.TransportMessage get_Message()
- No upgrade instructions provided.
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.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.
void Begin()
- No upgrade instructions provided.void End(Exception)
- No upgrade instructions provided.
NServiceBus.DataBus.DataBusExtentions<T> UseDataBus<T>(NServiceBus.BusConfiguration)
- No upgrade instructions provided.NServiceBus.DataBus.DataBusExtentions UseDataBus(NServiceBus.BusConfiguration, Type)
- No upgrade instructions provided.
NServiceBus.TransportExtensions<T> UseTransport<T>(NServiceBus.BusConfiguration)
- No upgrade instructions provided.NServiceBus.TransportExtensions UseTransport(NServiceBus.BusConfiguration, Type)
- No upgrade instructions provided.
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.
int get_MaximumConcurrencyLevel()
- Please useEndpointConfiguration.LimitMessageProcessingConcurrencyTo
instead.int get_MaximumMessageThroughputPerSecond()
- Message throughput throttling has been removed. Consult the documentation for further information.void set_MaximumConcurrencyLevel(int)
- Please useEndpointConfiguration.LimitMessageProcessingConcurrencyTo
instead.void set_MaximumMessageThroughputPerSecond(int)
- Message throughput throttling has been removed. Consult the documentation for further information.
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.
bool PurgeOnStartup(NServiceBus.Configure)
- Will be removed in version 7.0.0.
bool CreateQueues(NServiceBus.Configure)
- Please useCreateQueues
instead.
string TransportConnectionString(NServiceBus.Configure)
- Not available any more.
TimeSpan GetTimeToBeReceived(Type)
- No longer an extension point.bool IsExpressMessageType(Type)
- No longer an extension point.
bool DurableMessagesEnabled(NServiceBus.Configure)
- Please useDurableMessagesEnabled
instead.
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.
List<Assembly> get_MustReferenceAtLeastOneAssembly()
- This method is no longer required since deep scanning of assemblies is done to detect an NServiceBus reference.
NServiceBus.IBus Start()
- Please useIStartableEndpoint
instead.
void TimeToKeepDeduplicationData(TimeSpan)
- Please useInMemoryOutboxSettingsExtensions.TimeToKeepDeduplicationData(TimeSpan time)
instead.
Type get_SagaType()
- Please use.Metadata.SagaType
instead.
void CustomRetryPolicy(Func<NServiceBus.TransportMessage, TimeSpan>)
- Please useCustomRetryPolicy(Func<IncomingMessage, TimeSpan> customPolicy)
instead.
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 useEndpointConfiguration.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.
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 DefaultTimeout(TimeSpan)
- Please useconfig.UnitOfWork().WrapHandlersInATransactionScope(timeout: TimeSpan.FromSeconds(X));
instead.NServiceBus.Settings.TransactionSettings Disable()
- Please useconfig.UseTransport<MyTransport>().Transactions(TransportTransactionMode.None);
instead.NServiceBus.Settings.TransactionSettings DisableDistributedTransactions()
- Please useconfig.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 useEndpointConfiguration.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 useconfig.UseTransport<MyTransport>().Transactions(TransportTransactionMode.ReceiveOnly|TransportTransactionMode.SendsAtomicWithReceive);
instead.NServiceBus.Settings.TransactionSettings EnableDistributedTransactions()
- Please useconfig.UseTransport<MyTransport>().Transactions(TransportTransactionMode.TransactionScope);
instead.NServiceBus.Settings.TransactionSettings IsolationLevel(IsolationLevel)
- Please useconfig.UnitOfWork().WrapHandlersInATransactionScope(isolationLevel: IsolationLevel.X);
instead.NServiceBus.Settings.TransactionSettings WrapHandlersExecutionInATransactionScope()
- Please useconfig.UnitOfWork().WrapHandlersInATransactionScope();
instead.
string OriginalReplyToAddress
- Not used anymore.
NServiceBus.Unicast.SendOptions ToSendOptions(NServiceBus.Address)
- Use new SendOptions() instead.NServiceBus.TransportMessage ToTransportMessage()
- Use new OutgoingMessage(timeoutData.State) instead.
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 useGetMessageIntent(this IncomingMessage message)
instead.bool get_Recoverable()
- For sending purposes useDeliveryConstraintContextExtensions.AddDeliveryConstraint(new NonDurableDelivery())
to set NonDurable delivery orNonDurableDelivery 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 useDeliveryConstraintContextExtensions.AddDeliveryConstraint(new DiscardIfNotReceivedBefore(timeToBeReceived))
to set theTimeToBeReceived
orDiscardIfNotReceivedBefore constraint;DeliveryConstraintContextExtensions.TryGetDeliveryConstraint(out constraint)
to read theTimeToBeReceived
. 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 useDeliveryConstraintContextExtensions.AddDeliveryConstraint(new NonDurableDelivery())
to set NonDurable delivery orNonDurableDelivery 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 useDeliveryConstraintContextExtensions.AddDeliveryConstraint(new DiscardIfNotReceivedBefore(timeToBeReceived))
to set theTimeToBeReceived
orDiscardIfNotReceivedBefore constraint;DeliveryConstraintContextExtensions.TryGetDeliveryConstraint(out constraint)
to read theTimeToBeReceived
. When receiving look at the new 'NServiceBus.TimeToBeReceived' header.
void ClearDeferredMessages(string, string)
- Please useICancelDeferredMessages
instead.
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.
void .ctor()
- Please useNServiceBus.Pipeline.MessageHandler(Action<object, object, object> invocation, Type handlerType)
instead.Action<object, object> get_Invocation()
- Please useNServiceBus.Pipeline.MessageHandler.Invoke
instead.void set_Invocation(Action<object, object>)
- Please useNServiceBus.Pipeline.MessageHandler.Invoke
instead.
bool get_EnforceMessagingBestPractices()
- Turn best practices check off using configuration.DisableFeature().void set_EnforceMessagingBestPractices(bool)
- Turn best practices check off using configuration.DisableFeature().
void CacheMethodForHandler(Type, Type)
- Please useMessageHandlerRegistry.RegisterHandler(Type handlerType)
instead.IEnumerable<Type> GetHandlerTypes(Type)
- Please useMessageHandlerRegistry.GetHandlersFor(Type messageType)
instead.void InvokeHandle(object, object)
- Please useMessageHandler.Invoke(object message, object context)
instead.void InvokeTimeout(object, object)
- Please useMessageHandler.Invoke(object message, object context)
instead.
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.
void .ctor(NServiceBus.Address, string, Exception)
- Please useQueueNotFoundException(string queue, string message, Exception inner)
instead.
bool get_SubscribeToPlainMessages()
- Please useconfig.AutoSubscribe().AutoSubscribePlainMessages()
instead.void set_SubscribeToPlainMessages(bool)
- Please useconfig.AutoSubscribe().AutoSubscribePlainMessages()
instead.
void .ctor(NServiceBus.Address)
- Please useSendMessageOptions(string)
instead.string get_CorrelationId()
- Reply to address can be get/set using theNServiceBus.CorrelationId
header.Nullable<TimeSpan> get_DelayDeliveryWith()
- Please useDelayDeliveryFor
instead.void set_CorrelationId(string)
- Reply to address can be get/set using theNServiceBus.CorrelationId
header.void set_DelayDeliveryWith(Nullable<TimeSpan>)
- Please useDelayDeliveryFor
instead.
bool get_DoNotWrapHandlersExecutionInATransactionScope()
- DoNotWrapHandlersExecutionInATransactionScope is no longer used here. Use settings.GetOrDefault('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. Usecontext.Settings.GetRequiredTransactionModeForReceives() != Transactions.None
instead.bool get_SuppressDistributedTransactions()
- SuppressDistributedTransactions is no longer used here. Uusecontext.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('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. Usecontext.Settings.GetRequiredTransactionModeForReceives() != Transactions.None
instead.void set_SuppressDistributedTransactions(bool)
- SuppressDistributedTransactions is no longer used here. Uusecontext.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).
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 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.