diff --git a/concepts/broker/testing.html b/concepts/broker/testing.html
index 2417c156f..455f92eb0 100644
--- a/concepts/broker/testing.html
+++ b/concepts/broker/testing.html
@@ -285,7 +285,7 @@ Mocked Kafka
Many aspects of the Kafka broker have been mocked to replicated as much as possible the behavior you have when connected with the real broker. This new implementation supports commits, kafka events, offset reset, partitioning, rebalance, etc.
The mocked topics can be retrieved and inspected via the GetTopic
method of the IKafkaTestingHelper.
Partitioning
-By default 5 partitions will be created per each topic being mocked. This number can be configured as shown in the following snippet. The setting is per broker and there's currently no way to configure each topic independently.
+By default 5 partitions will be created per each topic being mocked. This number can be configured as shown in the following snippet. One can also specify the number of partitions per topic.
public class IntegrationTests : IClassFixture<WebApplicationFactory<Startup>>
{
private readonly WebApplicationFactory<Startup> _factory;
@@ -298,7 +298,9 @@ Partitioning
{
services
.UseMockedKafka(options => options
- .WithDefaultPartitionsCount(10));
+ .WithDefaultPartitionsCount(10)
+ .WithPartitionsCount("my-topic", 3)
+ .WithPartitionsCount("my-other-topic", 1);
});
});
}
diff --git a/index.json b/index.json
index 63bf12c20..28058e0ad 100644
--- a/index.json
+++ b/index.json
@@ -894,10 +894,15 @@
"title": "Namespace Silverback.Messaging.Broker.Kafka.Mocks | Silverback",
"keywords": "Namespace Silverback.Messaging.Broker.Kafka.Mocks Interfaces IInMemoryPartition A mocked topic partition where the messages are just stored in memory. IInMemoryTopic A mocked topic where the messages are just stored in memory. Note that it isn't obviously possible to accurately replicate the message broker behavior and this implementation is just intended for testing purposes. IMockedConfluentConsumer A mocked implementation of Confluent.Kafka.IConsumer from Confluent.Kafka that consumes from an IInMemoryTopic."
},
+ "api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html": {
+ "href": "api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html",
+ "title": "Class OffsetsTracker | Silverback",
+ "keywords": "Class OffsetsTracker Keeps track of the offsets of the messages being produced or consumed. Inheritance object OffsetsTracker Inherited Members object.Equals(object) object.Equals(object, object) object.GetHashCode() object.GetType() object.ReferenceEquals(object, object) object.ToString() Namespace: Silverback.Messaging.Broker.Kafka Assembly: Silverback.Integration.Kafka.dll Syntax public sealed class OffsetsTracker Methods | Improve this doc View source Commit(TopicPartitionOffset) Marks the specified offset as committed. Declaration public void Commit(TopicPartitionOffset offset) Parameters Type Name Description TopicPartitionOffset offset The offset to be marked as committed. | Improve this doc View source GetCommitOffsets() Gets the offsets to be used to commit after successful processing. Declaration public IReadOnlyCollection GetCommitOffsets() Returns Type Description IReadOnlyCollection The offsets to be used to commit. | Improve this doc View source GetRollbackOffSets() Gets the offsets to be used to rollback in case of error. Declaration public IReadOnlyCollection GetRollbackOffSets() Returns Type Description IReadOnlyCollection The offsets to be used to rollback. | Improve this doc View source TrackOffset(TopicPartitionOffset) Tracks the specified offset. Declaration public void TrackOffset(TopicPartitionOffset offset) Parameters Type Name Description TopicPartitionOffset offset The offset to be tracked. | Improve this doc View source TrackOffset(KafkaOffset) Tracks the specified offset. Declaration public void TrackOffset(KafkaOffset offset) Parameters Type Name Description KafkaOffset offset The offset to be tracked. | Improve this doc View source UntrackAllPartitions() Removes the tracked offset for all partitions. Declaration public void UntrackAllPartitions() | Improve this doc View source UntrackPartition(TopicPartition) Removes the tracked offset for the specified partition. Declaration public void UntrackPartition(TopicPartition topicPartition) Parameters Type Name Description TopicPartition topicPartition The partition to be untracked."
+ },
"api/Silverback.Messaging.Broker.Kafka.html": {
"href": "api/Silverback.Messaging.Broker.Kafka.html",
"title": "Namespace Silverback.Messaging.Broker.Kafka | Silverback",
- "keywords": "Namespace Silverback.Messaging.Broker.Kafka Classes ConfluentAdminClientBuilder Wraps the Confluent.Kafka.AdminClientBuilder. ConfluentConsumerBuilder Wraps the Confluent.Kafka.ConsumerBuilder. ConfluentProducerBuilder Wraps the Confluent.Kafka.ProducerBuilder. MockedConfluentAdminClientBuilder The builder for the MockedConfluentAdminClient. MockedConfluentConsumerBuilder The builder for the MockedConfluentConsumer. MockedConfluentProducerBuilder The builder for the MockedConfluentProducer. Interfaces IConfluentAdminClientBuilder Used to build the Confluent.Kafka.IAdminClient. IConfluentConsumerBuilder The Confluent.Kafka.IConsumer builder used by the KafkaConsumer. IConfluentProducerBuilder The Confluent.Kafka.IProducer builder used by the KafkaProducer. IConfluentProducersCache Creates and stores the Confluent.Kafka.IProducer instances in order to reuse them for the same KafkaProducerConfig configuration."
+ "keywords": "Namespace Silverback.Messaging.Broker.Kafka Classes ConfluentAdminClientBuilder Wraps the Confluent.Kafka.AdminClientBuilder. ConfluentConsumerBuilder Wraps the Confluent.Kafka.ConsumerBuilder. ConfluentProducerBuilder Wraps the Confluent.Kafka.ProducerBuilder. MockedConfluentAdminClientBuilder The builder for the MockedConfluentAdminClient. MockedConfluentConsumerBuilder The builder for the MockedConfluentConsumer. MockedConfluentProducerBuilder The builder for the MockedConfluentProducer. OffsetsTracker Keeps track of the offsets of the messages being produced or consumed. Interfaces IConfluentAdminClientBuilder Used to build the Confluent.Kafka.IAdminClient. IConfluentConsumerBuilder The Confluent.Kafka.IConsumer builder used by the KafkaConsumer. IConfluentProducerBuilder The Confluent.Kafka.IProducer builder used by the KafkaProducer. IConfluentProducersCache Creates and stores the Confluent.Kafka.IProducer instances in order to reuse them for the same KafkaProducerConfig configuration."
},
"api/Silverback.Messaging.Broker.KafkaBroker.html": {
"href": "api/Silverback.Messaging.Broker.KafkaBroker.html",
@@ -907,7 +912,7 @@
"api/Silverback.Messaging.Broker.KafkaConsumer.html": {
"href": "api/Silverback.Messaging.Broker.KafkaConsumer.html",
"title": "Class KafkaConsumer | Silverback",
- "keywords": "Class KafkaConsumer Consumes an endpoint and invokes a callback delegate when a message is received. Inheritance object Consumer Consumer KafkaConsumer Implements IConsumer IDisposable Inherited Members Consumer.Broker Consumer.Endpoint Consumer.CommitCoreAsync(IReadOnlyCollection) Consumer.RollbackCoreAsync(IReadOnlyCollection) Consumer.CommitCoreAsync(IReadOnlyCollection) Consumer.RollbackCoreAsync(IReadOnlyCollection) Consumer.Id Consumer.Broker Consumer.Endpoint Consumer.StatusInfo Consumer.IsConnecting Consumer.IsConnected Consumer.IsConsuming Consumer.IsDisconnecting Consumer.ServiceProvider Consumer.IsStopping Consumer.ConnectAsync() Consumer.DisconnectAsync() Consumer.TriggerReconnectAsync() Consumer.StartAsync() Consumer.StopAsync() Consumer.CommitAsync(IBrokerMessageIdentifier) Consumer.CommitAsync(IReadOnlyCollection) Consumer.RollbackAsync(IBrokerMessageIdentifier) Consumer.RollbackAsync(IReadOnlyCollection) Consumer.IncrementFailedAttempts(IRawInboundEnvelope) Consumer.Dispose() Consumer.CommitCoreAsync(IReadOnlyCollection) Consumer.RollbackCoreAsync(IReadOnlyCollection) Consumer.HandleMessageAsync(byte[], IReadOnlyCollection, string, IBrokerMessageIdentifier, ISequenceStore) Consumer.SetReadyStatus() Consumer.RevertReadyStatus() Consumer.Dispose(bool) object.Equals(object) object.Equals(object, object) object.GetHashCode() object.GetType() object.MemberwiseClone() object.ReferenceEquals(object, object) object.ToString() Namespace: Silverback.Messaging.Broker Assembly: Silverback.Integration.Kafka.dll Syntax public class KafkaConsumer : Consumer, IConsumer, IDisposable Constructors | Improve this doc View source KafkaConsumer(KafkaBroker, KafkaConsumerEndpoint, IBrokerBehaviorsProvider, IConfluentConsumerBuilder, IBrokerCallbacksInvoker, IServiceProvider, IInboundLogger) Initializes a new instance of the KafkaConsumer class. Declaration public KafkaConsumer(KafkaBroker broker, KafkaConsumerEndpoint endpoint, IBrokerBehaviorsProvider behaviorsProvider, IConfluentConsumerBuilder confluentConsumerBuilder, IBrokerCallbacksInvoker callbacksInvoker, IServiceProvider serviceProvider, IInboundLogger logger) Parameters Type Name Description KafkaBroker broker The IBroker that is instantiating the consumer. KafkaConsumerEndpoint endpoint The endpoint to be consumed. IBrokerBehaviorsProvider behaviorsProvider The IBrokerBehaviorsProvider. IConfluentConsumerBuilder confluentConsumerBuilder The IConfluentConsumerBuilder. IBrokerCallbacksInvoker callbacksInvoker The IBrokerCallbacksInvoker. IServiceProvider serviceProvider The IServiceProvider to be used to resolve the needed services. IInboundLogger logger The IInboundLogger. Properties | Improve this doc View source MemberId Gets the (dynamic) group member id of this consumer (as set by the broker). Declaration public string MemberId { get; } Property Value Type Description string Methods | Improve this doc View source CommitCoreAsync(IReadOnlyCollection) Commits the specified messages sending the acknowledgement to the message broker. Declaration protected override Task CommitCoreAsync(IReadOnlyCollection brokerMessageIdentifiers) Parameters Type Name Description IReadOnlyCollection brokerMessageIdentifiers The identifiers of to message be committed. Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.CommitCoreAsync(IReadOnlyCollection) | Improve this doc View source ConnectCoreAsync() Connects to the message broker. Declaration protected override Task ConnectCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.ConnectCoreAsync() | Improve this doc View source DisconnectCoreAsync() Disconnects from the message broker. Declaration protected override Task DisconnectCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.DisconnectCoreAsync() | Improve this doc View source GetCurrentSequenceStores() Gets the ISequenceStore instances used by this consumer. Some brokers will require multiple stores (e.g. the KafkaConsumer will create a store per each assigned partition). Declaration public override IReadOnlyList GetCurrentSequenceStores() Returns Type Description IReadOnlyList The list of ISequenceStore. Overrides Consumer.GetCurrentSequenceStores() Remarks Used only for testing and maintained to preserve backward compatibility. | Improve this doc View source RollbackCoreAsync(IReadOnlyCollection) If necessary notifies the message broker that the specified messages couldn't be processed successfully, to ensure that they will be consumed again. Declaration protected override Task RollbackCoreAsync(IReadOnlyCollection brokerMessageIdentifiers) Parameters Type Name Description IReadOnlyCollection brokerMessageIdentifiers The identifiers of to message be rolled back. Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.RollbackCoreAsync(IReadOnlyCollection) | Improve this doc View source StartCoreAsync() Starts consuming. Called to resume consuming after StopAsync() has been called. Declaration protected override Task StartCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.StartCoreAsync() | Improve this doc View source StopCoreAsync() Stops consuming while staying connected to the message broker. Declaration protected override Task StopCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.StopCoreAsync() | Improve this doc View source WaitUntilConsumingStoppedCoreAsync() Waits until the consuming is stopped. Declaration protected override Task WaitUntilConsumingStoppedCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.WaitUntilConsumingStoppedCoreAsync() Implements IConsumer IDisposable"
+ "keywords": "Class KafkaConsumer Consumes an endpoint and invokes a callback delegate when a message is received. Inheritance object Consumer Consumer KafkaConsumer Implements IConsumer IDisposable Inherited Members Consumer.Broker Consumer.Endpoint Consumer.CommitCoreAsync(IReadOnlyCollection) Consumer.RollbackCoreAsync(IReadOnlyCollection) Consumer.CommitCoreAsync(IReadOnlyCollection) Consumer.RollbackCoreAsync(IReadOnlyCollection) Consumer.Id Consumer.Broker Consumer.Endpoint Consumer.StatusInfo Consumer.IsConnecting Consumer.IsConnected Consumer.IsConsuming Consumer.IsDisconnecting Consumer.ServiceProvider Consumer.IsStopping Consumer.ConnectAsync() Consumer.DisconnectAsync() Consumer.TriggerReconnectAsync() Consumer.StartAsync() Consumer.StopAsync() Consumer.CommitAsync(IBrokerMessageIdentifier) Consumer.CommitAsync(IReadOnlyCollection) Consumer.RollbackAsync(IBrokerMessageIdentifier) Consumer.RollbackAsync(IReadOnlyCollection) Consumer.IncrementFailedAttempts(IRawInboundEnvelope) Consumer.Dispose() Consumer.CommitCoreAsync(IReadOnlyCollection) Consumer.RollbackCoreAsync(IReadOnlyCollection) Consumer.HandleMessageAsync(byte[], IReadOnlyCollection, string, IBrokerMessageIdentifier, ISequenceStore) Consumer.SetReadyStatus() Consumer.RevertReadyStatus() Consumer.Dispose(bool) object.Equals(object) object.Equals(object, object) object.GetHashCode() object.GetType() object.MemberwiseClone() object.ReferenceEquals(object, object) object.ToString() Namespace: Silverback.Messaging.Broker Assembly: Silverback.Integration.Kafka.dll Syntax public class KafkaConsumer : Consumer, IConsumer, IDisposable Constructors | Improve this doc View source KafkaConsumer(KafkaBroker, KafkaConsumerEndpoint, IBrokerBehaviorsProvider, IConfluentConsumerBuilder, IBrokerCallbacksInvoker, IServiceProvider, IInboundLogger) Initializes a new instance of the KafkaConsumer class. Declaration public KafkaConsumer(KafkaBroker broker, KafkaConsumerEndpoint endpoint, IBrokerBehaviorsProvider behaviorsProvider, IConfluentConsumerBuilder confluentConsumerBuilder, IBrokerCallbacksInvoker callbacksInvoker, IServiceProvider serviceProvider, IInboundLogger logger) Parameters Type Name Description KafkaBroker broker The IBroker that is instantiating the consumer. KafkaConsumerEndpoint endpoint The endpoint to be consumed. IBrokerBehaviorsProvider behaviorsProvider The IBrokerBehaviorsProvider. IConfluentConsumerBuilder confluentConsumerBuilder The IConfluentConsumerBuilder. IBrokerCallbacksInvoker callbacksInvoker The IBrokerCallbacksInvoker. IServiceProvider serviceProvider The IServiceProvider to be used to resolve the needed services. IInboundLogger logger The IInboundLogger. Properties | Improve this doc View source MemberId Gets the (dynamic) group member id of this consumer (as set by the broker). Declaration public string MemberId { get; } Property Value Type Description string Methods | Improve this doc View source CommitCoreAsync(IReadOnlyCollection) Commits the specified messages sending the acknowledgement to the message broker. Declaration protected override Task CommitCoreAsync(IReadOnlyCollection brokerMessageIdentifiers) Parameters Type Name Description IReadOnlyCollection brokerMessageIdentifiers The identifiers of to message be committed. Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.CommitCoreAsync(IReadOnlyCollection) | Improve this doc View source ConnectCoreAsync() Connects to the message broker. Declaration protected override Task ConnectCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.ConnectCoreAsync() | Improve this doc View source DisconnectCoreAsync() Disconnects from the message broker. Declaration protected override Task DisconnectCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.DisconnectCoreAsync() | Improve this doc View source GetCurrentSequenceStores() Gets the ISequenceStore instances used by this consumer. Some brokers will require multiple stores (e.g. the KafkaConsumer will create a store per each assigned partition). Declaration public override IReadOnlyList GetCurrentSequenceStores() Returns Type Description IReadOnlyList The list of ISequenceStore. Overrides Consumer.GetCurrentSequenceStores() Remarks Used only for testing and maintained to preserve backward compatibility. | Improve this doc View source GetOffsetsForTimestamp(IEnumerable, TimeSpan) Look up the offsets for the given partitions by timestamp. The returned offset for each partition is the earliest offset for which the timestamp is greater than or equal to the given timestamp. If the provided timestamp exceeds that of the last message in the partition, a value of Offset.End (-1) will be returned. Declaration public IReadOnlyList GetOffsetsForTimestamp(IEnumerable topicPartitionTimestamps, TimeSpan timeout) Parameters Type Name Description IEnumerable topicPartitionTimestamps The list of partitions with the target timestamps. TimeSpan timeout The maximum amount of time to block waiting for the requested offsets. Returns Type Description IReadOnlyList The list of offsets for each partition. | Improve this doc View source RollbackCoreAsync(IReadOnlyCollection) If necessary notifies the message broker that the specified messages couldn't be processed successfully, to ensure that they will be consumed again. Declaration protected override Task RollbackCoreAsync(IReadOnlyCollection brokerMessageIdentifiers) Parameters Type Name Description IReadOnlyCollection brokerMessageIdentifiers The identifiers of to message be rolled back. Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.RollbackCoreAsync(IReadOnlyCollection) | Improve this doc View source StartCoreAsync() Starts consuming. Called to resume consuming after StopAsync() has been called. Declaration protected override Task StartCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.StartCoreAsync() | Improve this doc View source StopCoreAsync() Stops consuming while staying connected to the message broker. Declaration protected override Task StopCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.StopCoreAsync() | Improve this doc View source WaitUntilConsumingStoppedCoreAsync() Waits until the consuming is stopped. Declaration protected override Task WaitUntilConsumingStoppedCoreAsync() Returns Type Description Task A Task representing the asynchronous operation. Overrides Consumer.WaitUntilConsumingStoppedCoreAsync() Implements IConsumer IDisposable"
},
"api/Silverback.Messaging.Broker.KafkaConsumerLocalTimeoutMonitor.html": {
"href": "api/Silverback.Messaging.Broker.KafkaConsumerLocalTimeoutMonitor.html",
@@ -1292,12 +1297,12 @@
"api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.html": {
"href": "api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.html",
"title": "Interface IMockedKafkaOptions | Silverback",
- "keywords": "Interface IMockedKafkaOptions Stores the mocked Kafka configuration. Namespace: Silverback.Messaging.Configuration.Kafka Assembly: Silverback.Integration.Kafka.Testing.dll Syntax public interface IMockedKafkaOptions Properties | Improve this doc View source DefaultPartitionsCount Gets or sets the default number of partitions to be created per each topic. The default is 5. Declaration int DefaultPartitionsCount { get; set; } Property Value Type Description int | Improve this doc View source OverriddenAutoCommitIntervalMs Gets or sets the value to be used instead of the default 5 seconds or the configured\"ConfluentConsumerConfigProxy.AutoCommitIntervalMs\" /> for the inbound topics. Set it to null to disable the feature. The default is 50 milliseconds. Declaration int? OverriddenAutoCommitIntervalMs { get; set; } Property Value Type Description int? | Improve this doc View source PartitionsAssignmentDelay Gets or sets the delay to be applied before and assigning the partitions. Declaration TimeSpan PartitionsAssignmentDelay { get; set; } Property Value Type Description TimeSpan"
+ "keywords": "Interface IMockedKafkaOptions Stores the mocked Kafka configuration. Namespace: Silverback.Messaging.Configuration.Kafka Assembly: Silverback.Integration.Kafka.Testing.dll Syntax public interface IMockedKafkaOptions Properties | Improve this doc View source DefaultPartitionsCount Gets or sets the default number of partitions to be created per each topic. The default is 5. Declaration int DefaultPartitionsCount { get; set; } Property Value Type Description int | Improve this doc View source OverriddenAutoCommitIntervalMs Gets or sets the value to be used instead of the default 5 seconds or the configured\"ConfluentConsumerConfigProxy.AutoCommitIntervalMs\" /> for the inbound topics. Set it to null to disable the feature. The default is 50 milliseconds. Declaration int? OverriddenAutoCommitIntervalMs { get; set; } Property Value Type Description int? | Improve this doc View source PartitionsAssignmentDelay Gets or sets the delay to be applied before and assigning the partitions. Declaration TimeSpan PartitionsAssignmentDelay { get; set; } Property Value Type Description TimeSpan | Improve this doc View source TopicPartitionsCount Gets the number of partitions created for the given topic. If not specified for a topic the DefaultPartitionsCount will be used. Declaration IDictionary TopicPartitionsCount { get; } Property Value Type Description IDictionary"
},
"api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.html": {
"href": "api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.html",
"title": "Interface IMockedKafkaOptionsBuilder | Silverback",
- "keywords": "Interface IMockedKafkaOptionsBuilder Exposes the methods to configure the mocked Kafka. Namespace: Silverback.Messaging.Configuration.Kafka Assembly: Silverback.Integration.Kafka.Testing.dll Syntax public interface IMockedKafkaOptionsBuilder Methods | Improve this doc View source DelayPartitionsAssignment(TimeSpan) Specifies the delay to be applied before assigning the partitions. Declaration IMockedKafkaOptionsBuilder DelayPartitionsAssignment(TimeSpan delay) Parameters Type Name Description TimeSpan delay The delay to be applied before assigning the partitions. Returns Type Description IMockedKafkaOptionsBuilder The IMockedKafkaOptionsBuilder so that additional calls can be chained. | Improve this doc View source OverrideAutoCommitIntervalMs(int?) Specifies the value to be used instead of the default 5 seconds or the configured AutoCommitIntervalMs for the inbound topics. Set it to null to disable the feature. The default is 10 milliseconds. Declaration IMockedKafkaOptionsBuilder OverrideAutoCommitIntervalMs(int? intervalMs) Parameters Type Name Description int? intervalMs The desired auto commit interval in milliseconds. Returns Type Description IMockedKafkaOptionsBuilder The IMockedKafkaOptionsBuilder so that additional calls can be chained. Remarks This is necessary to speed up the tests, since the WaitUntilAllMessagesAreConsumedAsync(TimeSpan?) method waits until the offsets are committed. | Improve this doc View source WithDefaultPartitionsCount(int) Specifies the default number of partitions to be created per each topic. The default is 5. Declaration IMockedKafkaOptionsBuilder WithDefaultPartitionsCount(int partitionsCount) Parameters Type Name Description int partitionsCount The number of partitions. Returns Type Description IMockedKafkaOptionsBuilder The IMockedKafkaOptionsBuilder so that additional calls can be chained."
+ "keywords": "Interface IMockedKafkaOptionsBuilder Exposes the methods to configure the mocked Kafka. Namespace: Silverback.Messaging.Configuration.Kafka Assembly: Silverback.Integration.Kafka.Testing.dll Syntax public interface IMockedKafkaOptionsBuilder Methods | Improve this doc View source DelayPartitionsAssignment(TimeSpan) Specifies the delay to be applied before assigning the partitions. Declaration IMockedKafkaOptionsBuilder DelayPartitionsAssignment(TimeSpan delay) Parameters Type Name Description TimeSpan delay The delay to be applied before assigning the partitions. Returns Type Description IMockedKafkaOptionsBuilder The IMockedKafkaOptionsBuilder so that additional calls can be chained. | Improve this doc View source OverrideAutoCommitIntervalMs(int?) Specifies the value to be used instead of the default 5 seconds or the configured AutoCommitIntervalMs for the inbound topics. Set it to null to disable the feature. The default is 10 milliseconds. Declaration IMockedKafkaOptionsBuilder OverrideAutoCommitIntervalMs(int? intervalMs) Parameters Type Name Description int? intervalMs The desired auto commit interval in milliseconds. Returns Type Description IMockedKafkaOptionsBuilder The IMockedKafkaOptionsBuilder so that additional calls can be chained. Remarks This is necessary to speed up the tests, since the WaitUntilAllMessagesAreConsumedAsync(TimeSpan?) method waits until the offsets are committed. | Improve this doc View source WithDefaultPartitionsCount(int) Specifies the default number of partitions to be created per each topic. The default is 5. Declaration IMockedKafkaOptionsBuilder WithDefaultPartitionsCount(int partitionsCount) Parameters Type Name Description int partitionsCount The number of partitions. Returns Type Description IMockedKafkaOptionsBuilder The IMockedKafkaOptionsBuilder so that additional calls can be chained. | Improve this doc View source WithPartitionsCount(string, int) Specify the default number of partitions to be created for the topic. Declaration IMockedKafkaOptionsBuilder WithPartitionsCount(string topicName, int partitionsCount) Parameters Type Name Description string topicName The name of the topic. int partitionsCount The number of partitions. Returns Type Description IMockedKafkaOptionsBuilder The IMockedKafkaOptionsBuilder so that additional calls can be chained."
},
"api/Silverback.Messaging.Configuration.Kafka.KafkaClientConfig.html": {
"href": "api/Silverback.Messaging.Configuration.Kafka.KafkaClientConfig.html",
@@ -3152,7 +3157,7 @@
"concepts/broker/testing.html": {
"href": "concepts/broker/testing.html",
"title": "Testing | Silverback",
- "keywords": "Testing Silverback ships a mocked version of the message broker implementations on a different nuget package: Silverback.Integration.Kafka.Testing (coming soon) Silverback.Integration.RabbitMQ.Testing These packages allow to perform end-to-end tests without having to integrate with a real message broker. Unit Tests Here an example of an xUnit test built using Silverback.Integration.Kafka.Testing. public class KafkaTests { private readonly IServiceProvider _serviceProvider; // Configure DI during setup public InMemoryBrokerTests() { var services = new ServiceCollection(); // Loggers are a prerequisite services.AddSingleton(); services.AddSingleton(typeof(ILogger<>), typeof(NullLogger<>)); services // Register Silverback as usual .AddSilverback() // Register the mocked KafkaBroker .WithConnectionToMessageBroker(config => config.AddMockedKafka()) // Configure inbound and outbound endpoints .AddKafkaEndpoints(endpoints => endpoints .Configure(config => { config.BootstrapServers = \"PLAINTEXT://tests\"; }) .AddOutbound(endpoint => endpoint .ProduceTo(\"test-topic\")) .AddInbound(endpoint => endpoint .ConsumeFrom(\"test-topic\") .Configure(config => { config.GroupId = \"my-test-consumer\"; }))) // Register the subscriber under test .AddScopedSubscriber(); // ...register all other types you need... _serviceProvider = services.BuildServiceProvider(); } [Fact] public async Task SampleTest() { // Arrange // Connect the broker await _serviceProvider.GetRequiredService().ConnectAsync(); // Create a producer to push to test-topic var producer = _serviceProvider .GetRequiredService() .GetProducer(new KafkaProducerEndpoint(\"test-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"hello!\" }); await producer.ProduceAsync(new TestMessage { Content = \"hello 2!\" }); // Assert // ...your assertions... } } Integration Tests Mocking the message broker is especially interesting for the integration tests, where you probably leverage the ASP.NET Core integration tests to perform a full test based on the real configuration applied in the application's startup class. The following code shows the simplest integration test possible, in which an object is published to the broker and e.g. a subscriber is called. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { // Replace the usual broker (KafkaBroker) // with the mocked version services.UseMockedKafka(); }); }); } [Fact] public async Task SampleTest() { // Arrange // Resolve a producer to push to test-topic var producer = _factory.Server.Host.Services .GetRequiredService() .GetProducer(new KafkaProducerEndpoint(\"tst-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"abc\" }); // Assert // ...your assertions... } } Testing helper The testing helpers (such has IKafkaTestingHelper) contain some methods that simplify testing with the message broker, given it's asynchronous nature. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { services.UseMockedKafka(); }); }); } [Fact] public async Task SampleTest() { // Arrange // Resolve the IKafkaTestingHelper (used below) var testingHelper = _factory.Server.Host.Services .GetRequiredService(); // Resolve a producer to push to test-topic var producer = testingHelper.Broker .GetProducer(new KafkaProducerEndpoint(\"tst-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"abc\" }); // Wait until all messages have been consumed and // committed before asserting await testingHelper.WaitUntilAllMessagesAreConsumedAsync(); // Assert // ...your assertions... } } IntegrationSpy The IIntegrationSpy ships with the Silverback.Integration.Testing package (referenced by the other Integration.Testing.* packages) and can be used to inspect all outbound and inbound messages. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { services .ConfigureSilverback() .UseMockedKafka() .AddIntegrationSpy(); }); }); } [Fact] public async Task SampleTest() { // Arrange var testingHelper = _factory.Server.Host.Services .GetRequiredService(); var producer = testingHelper.Broker .GetProducer(new KafkaProducerEndpoint(\"tst-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"abc\" }); // Wait until all messages have been consumed and // committed before asserting await testingHelper.WaitUntilAllMessagesAreConsumedAsync(); // Assert testingHelper.Spy.OutboundEnvelopes.Should().HaveCount(1); testingHelper.Spy.InboundEnvelopes.Should().HaveCount(1); testingHelper.Spy.InboundEnvelopes[0].Message.As .Content.Should().Be(\"abc\"); } } Mocked Kafka Many aspects of the Kafka broker have been mocked to replicated as much as possible the behavior you have when connected with the real broker. This new implementation supports commits, kafka events, offset reset, partitioning, rebalance, etc. The mocked topics can be retrieved and inspected via the GetTopic method of the IKafkaTestingHelper. Partitioning By default 5 partitions will be created per each topic being mocked. This number can be configured as shown in the following snippet. The setting is per broker and there's currently no way to configure each topic independently. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { services .UseMockedKafka(options => options .WithDefaultPartitionsCount(10)); }); }); } }"
+ "keywords": "Testing Silverback ships a mocked version of the message broker implementations on a different nuget package: Silverback.Integration.Kafka.Testing (coming soon) Silverback.Integration.RabbitMQ.Testing These packages allow to perform end-to-end tests without having to integrate with a real message broker. Unit Tests Here an example of an xUnit test built using Silverback.Integration.Kafka.Testing. public class KafkaTests { private readonly IServiceProvider _serviceProvider; // Configure DI during setup public InMemoryBrokerTests() { var services = new ServiceCollection(); // Loggers are a prerequisite services.AddSingleton(); services.AddSingleton(typeof(ILogger<>), typeof(NullLogger<>)); services // Register Silverback as usual .AddSilverback() // Register the mocked KafkaBroker .WithConnectionToMessageBroker(config => config.AddMockedKafka()) // Configure inbound and outbound endpoints .AddKafkaEndpoints(endpoints => endpoints .Configure(config => { config.BootstrapServers = \"PLAINTEXT://tests\"; }) .AddOutbound(endpoint => endpoint .ProduceTo(\"test-topic\")) .AddInbound(endpoint => endpoint .ConsumeFrom(\"test-topic\") .Configure(config => { config.GroupId = \"my-test-consumer\"; }))) // Register the subscriber under test .AddScopedSubscriber(); // ...register all other types you need... _serviceProvider = services.BuildServiceProvider(); } [Fact] public async Task SampleTest() { // Arrange // Connect the broker await _serviceProvider.GetRequiredService().ConnectAsync(); // Create a producer to push to test-topic var producer = _serviceProvider .GetRequiredService() .GetProducer(new KafkaProducerEndpoint(\"test-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"hello!\" }); await producer.ProduceAsync(new TestMessage { Content = \"hello 2!\" }); // Assert // ...your assertions... } } Integration Tests Mocking the message broker is especially interesting for the integration tests, where you probably leverage the ASP.NET Core integration tests to perform a full test based on the real configuration applied in the application's startup class. The following code shows the simplest integration test possible, in which an object is published to the broker and e.g. a subscriber is called. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { // Replace the usual broker (KafkaBroker) // with the mocked version services.UseMockedKafka(); }); }); } [Fact] public async Task SampleTest() { // Arrange // Resolve a producer to push to test-topic var producer = _factory.Server.Host.Services .GetRequiredService() .GetProducer(new KafkaProducerEndpoint(\"tst-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"abc\" }); // Assert // ...your assertions... } } Testing helper The testing helpers (such has IKafkaTestingHelper) contain some methods that simplify testing with the message broker, given it's asynchronous nature. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { services.UseMockedKafka(); }); }); } [Fact] public async Task SampleTest() { // Arrange // Resolve the IKafkaTestingHelper (used below) var testingHelper = _factory.Server.Host.Services .GetRequiredService(); // Resolve a producer to push to test-topic var producer = testingHelper.Broker .GetProducer(new KafkaProducerEndpoint(\"tst-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"abc\" }); // Wait until all messages have been consumed and // committed before asserting await testingHelper.WaitUntilAllMessagesAreConsumedAsync(); // Assert // ...your assertions... } } IntegrationSpy The IIntegrationSpy ships with the Silverback.Integration.Testing package (referenced by the other Integration.Testing.* packages) and can be used to inspect all outbound and inbound messages. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { services .ConfigureSilverback() .UseMockedKafka() .AddIntegrationSpy(); }); }); } [Fact] public async Task SampleTest() { // Arrange var testingHelper = _factory.Server.Host.Services .GetRequiredService(); var producer = testingHelper.Broker .GetProducer(new KafkaProducerEndpoint(\"tst-topic\")); // Act await producer.ProduceAsync(new TestMessage { Content = \"abc\" }); // Wait until all messages have been consumed and // committed before asserting await testingHelper.WaitUntilAllMessagesAreConsumedAsync(); // Assert testingHelper.Spy.OutboundEnvelopes.Should().HaveCount(1); testingHelper.Spy.InboundEnvelopes.Should().HaveCount(1); testingHelper.Spy.InboundEnvelopes[0].Message.As .Content.Should().Be(\"abc\"); } } Mocked Kafka Many aspects of the Kafka broker have been mocked to replicated as much as possible the behavior you have when connected with the real broker. This new implementation supports commits, kafka events, offset reset, partitioning, rebalance, etc. The mocked topics can be retrieved and inspected via the GetTopic method of the IKafkaTestingHelper. Partitioning By default 5 partitions will be created per each topic being mocked. This number can be configured as shown in the following snippet. One can also specify the number of partitions per topic. public class IntegrationTests : IClassFixture> { private readonly WebApplicationFactory _factory; public IntegrationTests(WebApplicationFactory factory) { _factory = factory.WithWebHostBuilder(builder => { builder.ConfigureTestServices(services => { services .UseMockedKafka(options => options .WithDefaultPartitionsCount(10) .WithPartitionsCount(\"my-topic\", 3) .WithPartitionsCount(\"my-other-topic\", 1); }); }); } }"
},
"concepts/broker/tombstone.html": {
"href": "concepts/broker/tombstone.html",
@@ -3232,7 +3237,7 @@
"releases.html": {
"href": "releases.html",
"title": "Releases | Silverback",
- "keywords": "Releases 4.5.1 Fixes Fix assembly qualified name parsing for generic types 4.5.0 What's new Upgrade to MQTTnet 4.3.6.1152 Upgrade to Confluent.Kafka 2.4.0 Minor changes to reduce the likelihood of a deadlock 4.4.1 What's new Upgrade to Confluent.Kafka 2.3.0 Upgrade to MQTTnet 4.3.2.930 4.4.0 What's new Allow parallel processing of MQTT messages Upgrade to MQTTnet 4.3.1.873 Upgrade to Confluent.Kafka 2.2.0 Fixes Correctly set message timestamp in mocked Kafka Properly handle Kafka partitions revoked event when no partitions were assigned [#214] Respect IgnoreUnhandledException when batch processing [#216] 4.3.2 Fixes Fix potential message loss in OutboxWorker 4.3.1 Fixes Fix deadlock in OutboxWorker when enforceMessageOrder=true (default) 4.3.0 What's new Upgrade to MQTTnet 4.2.0.706 Upgrade to Confluent.Kafka 2.1.1 Upgrade to Newtonsoft.Json 13.0.3 Add ReasonCode and ReasonString to MqttProduceException message 4.2.1 Fixes Prevent an ObjectDisposedException to be thrown by the BrokerCallbackInvoker during application shutdown Fix possible deadlock in BatchSequence with timeout 4.2.0 What's new Upgrade to Confluent.Kafka 2.1.0 4.1.2 Fixes Fix chained error policies attempts counter 4.1.1 Fixes Fix bug in outbox producer writing to the wrong endpoint [#165] 4.1.0 What's new Upgrade to Confluent.Kafka 2.0.2 Replace the deprecated package Confluent.Kafka.SchemaRegistry.Serdes with Confluent.Kafka.SchemaRegistry.Serdes.Avro Simplify the Avro serializer configuration and add samples (see Kafka - Avro) 4.0.1 What's new Upgrade to MQTTnet 4.1.4.563 4.0.0 What's new Upgrade to MQTTnet 4.1.3.436 Upgrade to Confluent.Kafka 1.9.3 Upgrade to Newtonsoft.Json 13.0.2 Disable server-side offset commit in KafkaConsumer when GroupId is not set Breaking changes Some breaking changes in MQTTnet 4 are reflected into Silverback 3.8.0 What's new Topic name resolvers can be used to filter the messages to be produce: returning null will discard the message Fixes Fix error policies not being triggered consistently when batch consuming Make IntegrationSpy fully thread-safe Prevent errors when the IKafkaPartitionsRevokedCallback is invoked during application shutdown Improve error handling during connection to MQTT 3.7.3 Fixes Support topic names with symbols (e.g. hyphens) in mocked MQTT broker 3.7.2 Fixes Correctly invoke the IKafkaOffsetCommittedCallback when auto commit is disabled [#167] 3.7.1 Fixes Improve message streams abort process to avoid first chance exceptions (e.g. during dispose) 3.7.0 What's new Implement basic support for Kafka transactions via KafkaTransactionalProducer (Note: this is just a first step and a more comprehensive implementation is planned for the upcoming release 4.0.0) Skip chunking when processing single chunk messages Fixes Fix possible race condition in consumer pipeline 3.6.1 Fixes Handle race condition in BatchSequence with timeout Limit consumer status history 3.6.0 What's new Handle IAsyncEnumerable returned by the subscriber and republished the contained messages Enrich Kafka messages moved by the MoveMessageErrorPolicy adding some extra headers containing some information about the source topic, partition, offset, etc. (see Message Headers) Allow filters such as the KafkaGroupIdFilterAttribute or MqttClientIdFilterAttribute to be added to the subscribers at runtime via the configuration API (see Multiple Consumer Groups (in same process) and Multiple Clients (in same process)) Add overload for Publish method in the error policies that forwards the exception as well as the envelope Throw TimeoutException from KafkaTestingHelper and MqttTestingHelper Improve MQTT connection related logs (info for successful reconnect and add broker name to log messages) Support shared sessions in mocked MQTT broker Fixes Ensure each consumed message gets a unique traceId (when the traceparent header is not present) Fix memory leak in consumer Fully validate messages, including nested objects 3.5.0 What's new Log MqttClient internal events (see Logging) Upgrade to Confluent.Kafka 1.8.2 Upgrade to MQTTnet 3.0.16 Upgrade to RabbitMQ.Client 6.2.2 Update several dependencies Fixes Fix MqttConsumer reconnection issues Handle edge cases related to MQTT acknowledgment timeout in MqttConsumer Allow max retries specification and error policies chains with MQTT V3 3.4.0 What's new Support encryption key rotation (see Encryption) 3.3.1 Fixes Fix AddHeaders and WithKafkaKey not being correctly invoked by all IProducer.Produce and IProducer.ProducerAsync overloads Add endpoint friendly name to all logs 3.3.0 What's new Optimize in-memory mocked Kafka (avoid spawning too many threads) Support multiple brokers (with overlapping topic names) in mocked Kafka and MQTT Add message validation for both producer and consumer (see Message Validation) Add new AddInbound overloads specifying message type for a more compact configuration when using the typed deserializer (see Serialization) Fixes Invoke the Kafka partition EOF callback for all connected consumers Ignore null or empty Kafka key in producer 3.2.0 What's new Add new Kafka partition EOF callback to be notified when the end of a partition is reached by the consumer (see Kafka Events and IKafkaPartitionEofCallback) Allow multiple calls to IKafkaConsumerEndpointBuilder.Configure or IKafkaProducerEndpointBuilder.Configure for the same endpoint Observe a grace period in the ConsumersHealthCheck to prevent false positives during a normal Kafka rebalance Add optional friendly name to the endpoints (see IEndpointBuilder .WithName and Endpoint.FriendlyName) Allow filtering the endpoints targeted by the ConsumersHealthCheck (see AddConsumersCheck) 3.1.1 Fixes Invoke broker callbacks during the application shutdown to allow custom code to be run when disconnecting 3.1.0 What's new Add new ways to configure headers and kafka key (see Message Headers and Kafka Partitioning and Message Key) New callbacks for Kafka log events (see Kafka Events) Improve consumer status tracking introducing ConsumerStatus.Ready Revert the Kafka consumer status from Ready to Connected whenever partitions are revoked or a poll timeout occurs Adapt consumer health check to monitor the new status and report unhealthy if not Ready (see Health Monitoring) Try to automatically recover from Kafka maximum poll interval exceed errors Improve Kafka static partition assignment with resolver function and fetching the available partitions (see Kafka Partitioning and Message Key) Upgrade to Confluent.Kafka 1.7.0 Upgrade to MQTTnet 3.0.15 Fixes Prevent possible race condition causing messages to be skipped when a RetryPolicy kicks in for messages from multiple Kafka partitions simultaneously Prevent ObjectDisposedException to be thrown when Kafka events (e.g. statistics) are fired during the application shutdown Prevent ObjectDisposedException to be thrown when Consumer.Dispose is called multiple times Properly clear the trace context (Activity) when reconnecting the consumer to prevent the newly started consume loop to be tracked under the current message traceId Fix wrong prefix in MQTT log event names 3.0.1 Fixes Fix IOutboxWriter lifecycle [#128] 3.0.0 What's new Add support for MQTT (see Connecting to a Message Broker, Inbound Endpoint, Outbound Endpoint, ...) Simplify configuration and reduce boilerplate (see Subscribing and Connecting to a Message Broker) Simplify subscribers registration and get rid of the ISubscriber interface (see Subscribing) Scan subscribers automatically at startup to reduce cost of first message Connect brokers and handle graceful shutdown automatically (see Connecting to a Message Broker) Improve endpoints configuration API (see Connecting to a Message Broker) Add IServiceCollection.ConfigureSilverback extension method to conveniently split the configuration code (see Enabling Silverback) Refactor Silverback.Integration to support streaming Create IMessageStreamEnumerable (see Streaming) Improve chunking support in conjunction with streaming, requiring only one chunk at a time to be loaded into memory Redesign sequences handling to support chunking, batch consuming and future sequences as well Improve Kafka partitions handling (see Kafka Partitioning and Message Key) Process partitions independently and concurrently Add setting to produce to a specific partition Add setting to manually assign the consumer partitions Add option to throw an exception if no subscriber is handling a message that was published to the internal bus or was consumed from a message broker (see throwIfUnhandled argument in the IPublisher methods and ThrowIfUnhandled property in the IConsumerEndpoint) Handle null messages as Tombstone/Tombstone (see Tombstone Message) Replace Newtonsoft.Json with System.Text.Json to improve serialization and deserialization performance (the old serializers have been moved into the Silverback.Integration.Newtonsoft package, see Serialization) Improve outbound routing customization options with endpoint name resolvers (see Outbound Messages Routing) Add non-blocking Produce/ProduceAsync/RawProduce/RawProduceAsync overloads to IProducer, better suitable for higher throughput scenarios (see Producer) Refactor broker event handlers (see Broker Callbacks) Expose IConsumer.StopAsync and IConsumer.StartAsync methods to pause and resume consumers Add log levels configuration (see Logging) Improve (distributed) tracing (see Logging) Allow header names customization (see Message Headers) Add consumer status information and statistics (see Connecting to a Message Broker) Add basic consumer health check (see Health Monitoring) Allow broker behaviors to be registered as transient, meaning that an instance will be created per each producer or consumer (see Broker behaviors pipeline) Improve code quality Enhance CI pipeline to use Roslyn analyzers Integrate SonarCloud) Improve integration tests Increase automated tests coverage Enable nullable reference types and adjust all API Document the entire public API (see API Documentation) Released some utilities to help writing automated tests involving Silverback.Integration (see Testing) Upgrade to Confluent.Kafka 1.6.2 Upgrade to RabbitMQ.Client 6.2.1 Fixes Fix OutboxWorker not publishing custom headers [#102] Breaking Changes Refactored IPublisher Removed the overloads to publish a batch of messages (see Publishing) Cannot subscribe to collection of messages anymore (see Subscribing), unless they are consumed from a message broker (see Streaming) The chunks belonging to the same message must be contiguous (interleaved messages are at the moment not supported anymore) and in the same partition in case of Kafka Removed ISubscriber interface Removed BusConfigurator (moved all the configuration into the ISilverbackBuilder extension methods) Replaced BusConfigurator.Connect with ISilverbackBuilder.AddEndpointsConfigurator and ISilverbackBuilder.AddEndpoints (or ISilverbackBuilder.AddKafkaEndpoints etc.) to configure the endpoints, while the broker is connected automatically at startup (see Connecting to a Message Broker) Replaced BusConfigurator.Subscribe methods with ISilverbackBuilder.AddDelegateSubscriber (see Subscribing) Replaced BusConfigurator.HandleMessagesOfType methods with ISilverbackBuilder.HandleMessageOfType (see Subscribing) BusConfigurator.ScanSubscribers is not needed anymore since it gets called automatically at startup (from an IHostedService) Removed IServiceCollection.Add*Subscriber, IServiceCollection.Add*Behavior, IServiceCollection.Add*BrokerBehavior, IServiceCollection.AddEndpointsConfigurator, IServiceCollection.Add*OutboundRouter extension methods, use the same methods on the ISilverbackBuilder (using IServiceCollection.ConfigureSilverback to get an instance if the ISilverbackBuilder if necessary, as shown in Enabling Silverback) Removed IBrokerOptionsBuilder.Add*BrokerBehavior, IBrokerOptionsBuilder.RegisterConfigurator, IBrokerOptionsBuilder.Add*OutboundRouter extension methods, use the same methods on the ISilverbackBuilder (using IServiceCollection.ConfigureSilverback to get an instance if the ISilverbackBuilder if necessary, as shown in Enabling Silverback) Reorganized the Silverback.Messaging.Configuration namespace moving some broker specific types under Silverback.Messaging.Configuration.Kafka, Silverback.Messaging.Configuration.Rabbit or Silverback.Messaging.Configuration.Mqtt The visibility of some types has been changed to internal to favor a cleaner and clearer API where the public types are well documented and their backward compatibility is valued Removed Silverback prefix from exceptions name Removed the IRequest interface (it was implemented by both IQuery and ICommand) Changed Impl methods suffix with Core, this affects some virtual members in the Broker and other base classes IConsumer.Received event replaced by a callback delegate IBroker.GetConsumer and IBrokerCollection.GetConsumer methods renamed to IBroker.AddConsumer and IBrokerCollection.AddConsumer IQueueProducer and IQueueConsumer renamed to IOutboxWriter and IOutboxReader The messages with a null body are by default mapped to a Tombstone/Tombstone (see Tombstone Message) Database: Moved all entities (used with Entity Framework Core) to the Silverback.Database.Model namespace Replaced InboundMessage entity with InboundLogEntry Replaced OutboundMessage entity with OutboxMessage Removed TemporaryMessageChunk Modified schema of StoredOffset entity Moved and renamed some internally used types (e.g. QueuedMessage, DbQueuedMessage, ...) Complete redesign of the error policies Removed IMessageIdProvider and all related logic: the Id or MessageId property will not be automatically initialized anymore and its value will not be used as identifier for the outbound message anymore (refer to the Message Identifier page for further details on how to set a custom message id, if needed) WithConnectionTo<>, WithConnectionToKafka, WithConnectionToRabbitMQ and WithInMemoryBroker have been removed, please use the new WithConnectionToMessageBroker and AddKafka/AddRabbit methods (see Connecting to a Message Broker) Replaced the internal messages for the Kafka events such as partitions revoked/assigned, offset commit, error, log and statistics with event handler interfaces (see Kafka Events) Deprecated Silverback.Integration.InMemory, use Silverback.Integration.Kafka.Testing, Silverback.Integration.RabbitMQ.Testing, etc. instead Renamed PartitioningKeyMemberAttribute to KafkaKeyMemberAttribute Silverback.Integration.Configuration has been discontinued Renamed Settings property to Options in the default JsonMessageSerializer (since the switch to System.Text.Json) Removed LogWithLevel method from SkipMessageErrorPolicy, use the new WithLogLevels configuration instead Removed Parallel option from SubscribeAttribute Renamed Offset to a more generic BrokerMessageIdentifier in the Silverback.Integration abstractions (including the envelopes) Some changes to the behaviors: Renamed Handle to HandleAsync in the IBehavior, IProducerBehavior and IConsumerBehavior Changed signature of the HandleAsync method (see Behaviors and Broker behaviors pipeline) Changed some sort indexes and introduced some new broker behaviors, you may need to adjust the sort index of your custom behaviors (see Broker behaviors pipeline for the updated list of built-in behaviors) Replaced IBroker.Connect and IBroker.Disconnect with IBroker.ConnectAsync and IBroker.DisconnectAsync Some major changes to batch consuming: Removed all batch events (BatchStartedEvent, BatchCompleteEvent, BatchProcessedEvent, BatchAbortedEvent), refer to Streaming to learn how to leverage the new IMessageStreamEnumerable Setting the batch size to 1 doesn't disable batching anymore, set the Batch to null in the ConsumerEndpoint to disable it When batching is enabled the messages can be subscribed only via the IMessageStreamEnumerable (see Streaming), the subscribers to the single messages will not be invoked ChunkSettings moved from Silverback.Messaging.LargeMessages namespace to Silverback.Messaging.Sequences.Chunking Replaced CoreEventIds, IntegrationEventIds, KafkaEventIds and RabbitEventIds with CoreLogEvents, IntegrationLogEvents, KafkaLogEvents and RabbitLogEvents (see also Logging) Deprecated support for Entity Framework 2, only the version 3.0.1 of Silverback.Core.EntityFrameworkCore will work with Silverback 3.0.0 Modified message encryption for chunked messages and it will not be compatible with previous versions of Silverback (affects chunking+encryption only) 2.2.0 What's new Allow custom outbound routers to be registered as scoped or transient (instead of singleton only) 2.1.2 Fixes Fix delay in Retry policy [#97] 2.1.1 What's new Add support for multiple message brokers (Kafka and RabbitMQ) in the same application (see Connecting to a Message Broker) Add end-to-end message encryption (see Encryption) Add dynamic custom routing of outbound messages (see Outbound Messages Routing) Improve support for message headers (see Message Headers) Add support for binary files (see Binary Files) Improve message identifier handling: the IIntegrationMessage is not required to have an Id property anymore (the x-message-id header will still be generated and if the property exists will continue to be automatically initialized) x-first-chunk-offset header added by default (see Message Headers) Deserialize KafkaStasticsEvent JSON and provided its content as an object (in addition to the raw JSON) Add support for Apache Avro and schema registry (see Serialization) Upgrade to Confluent.Kafka 1.4.2 Add consumer PrefetchSize and PrefetchCount settings to RabbitConsumerEndpoint Add AcknowledgeEach to the RabbitConsumerEndpoint to define the number of message processed before sending the acknowledgment to the server Upgrade to RabbitMQ.Client 6.0.0 Improve message type resolution performance and reliability in JsonMessageSerializer Add LogWithLevel method to SkipMessageErrorPolicy to specify the desired level for the \"Message skipped\" log entry (the default is now increased to Error) Breaking Changes These changes shouldn't affect you unless you built your own IBroker implementation or are interacting at low-level with the IBroker (this is why has been decided to still mark this as a minor release): The IBroker interface and Broker abstract base class have been modified to explicitly declare which endpoint type is being handled by the broker implementation The IMessageSerializer interfaces has been changed The IConsumerBehavior and IProducerBehavior interfaces have been changed Changed the parameters order in some less used overloads in the IBrokerOptionBuilder Announced Breaking Changes These aren't real breaking changes but some methods have been marked as deprecated and will be removed in one of the next major releases: WithConnectionTo<>, WithConnectionToKafka and WithConnectionToRabbitMQ are deprecated (they will still be supported in this version), please use the new WithConnectionToMessageBroker and AddKafka/AddRabbit methods (see Connecting to a Message Broker) 2.0.0 What's new Create Silverback.Integration.RabbitMQ package to connect Silverback with RabbitMQ (see Connecting to a Message Broker) Enable subscription of messages with an empty body (you must subscribe to the IInboundEnvelope) [#61] Add hook to manually set the Kafka partition start offset when a partition is assigned to the consumer (see Kafka Events) [#57] Support for multiple consumer groups running in the same process (see Multiple Consumer Groups (in same process)) [#59] Publish KafkaStatisticsEvent also from the KafkaProducer (previously done in KafkaConsumer only) Several reliability and performance related improvements Breaking Changes The IBroker, IProducer and IConsumer interfaces have been slightly modified (it shouldn't affect you unless you built your own IBroker implementation) Many interfaces (such as IBehavior) and delegates have been slightly modified to pass around an IReadOnlyCollection instead of an IEnumerable , to avoid the possible issues related to multiple enumeration of an IEnumerable The IMessageKeyProvider interface has been renamed to IMessageIdProvider to prevent to be mistaken with the Kafka Key or Rabbit's Routing Key IInboundMessage/IOutboundMessage (plus all the related types) have been renamed to IInboundEnvelope/IOutboundEnvelope and the property containing the actual message has been renamed from Content to Message The MustUnwrap option has been removed from the inbound connector configuration (messages are unwrapped by default) 1.2.0 What's new Publish events to the internal bus as a consequence to the Kafka events such as partitions assigned or revoked (see Kafka Events) [#34] 1.1.0 What's new Add IEndpointsConfigurator interface to allow splitting the endpoints configuration across multiple types (see Connecting to a Message Broker) Add support for distributed tracing (based on System.Diagnostics) Add IProducerBehavior and IConsumerBehavior to create an extension point closer to the actual message broker logic (see Broker behaviors pipeline) Breaking Changes Replaced ISortedBehavior with a generic ISorted interface 1.0.5 What's new Upgrade to Confluent.Kafka 1.3.0 Fixes Fix OutboundQueueHealthCheck [#43] Remove automatic disposal of the KafkaProducer when a KafkaException is thrown (creating too many instances of the producer over a short time span could lead to too many active TCP connections) Fix the bug preventing a KafkaConsumerEndpoint pointing to multiple topics to be successfully subscribed 1.0.4 Fixes Fix mortal loop issue: it is finally safe to consume and produce the same type of messages from within the same process (in a natural way, without any extra configuration) Since version 1.0.0 the messages routed to an endpoint aren't forwarded to any subscriber directly Now the inbound connector has been fixed as well, preventing the inbound messages to be immediately routed once again to the outbound endpoint and eliminating all possible causes of mortal loops 1.0.3 What's new Deprecate PartitioningKeyMemberAttribute in favor of KafkaKeyMemberAttribute, since the message key isn't used just for partitioning (see Kafka Partitioning and Message Key) Fixes Forward Kafka message key as-is (not hashed anymore) to avoid possible collisions and simplify debugging 1.0.2 Fixes Reintroduce Add*Subscriber and Add*Behavior as IServiceCollection extension methods (for backward compatibility and greater flexibility) [#41] Add WithInMemoryBroker and OverrideWithInMemoryBroker extension methods (see Testing) 1.0.0 What's new Optimize message size (no wrappers anymore) Improve headers usage: identifiers, types, chunks information, etc. are now all sent in the headers Review severity of some log entries Improve and clean up internal implementation Improve exception handling (flattening of AggregateException) Upgrade to Confluent.Kafka 1.2.2 Add automatic recovers from fatal errors in KafkaConsumer (can be disabled via Endpoint configuration) Support .Net Core 3.0 and Entity Framework Core 3.0 Refactor packages (EF binding logic is now in a single package, versioned after the related EF version) Improve configuration API Improve and optimize performance (including #37) Improve database locks mechanism (used also to run the OutboundQueueWorker) Fixes Fix issue requiring types not implementing IMessage to be registered with HandleMessagesOfType to consume them [#33] Mitigate issue causing the DistributedBackgroundService to sometime fail to acquire the database lock [#39] Fix partition key value being lost when using the DeferredOutboundConnector Other small fixes to improve stability and reliability Breaking Changes By default the messages published via IPublisher that are routed to an outbound endpoint are not sent through to the internal bus and cannot therefore be subscribed locally, within the same process (see Outbound Endpoint) Some changes in IInboundMessage and IOutboundMessage interfaces Changes to the schema of the outbox table (Silverback.Messaging.Connectors.Model.OutboundMessage) The configuration fluent API changed quite a bit, refer to the current documentation Important WithConnectionTo has to be replaced with WithConnectionToKafka in order for all features to work properly. When failing to do so no message key will be generated, causing the messages to land in a random partition and/or preventing to publish to a compacted topic. (see Kafka Partitioning and Message Key) Silverback.Integration.EntityFrameworkCore and Silverback.EventSourcing.EntityFrameworkCore have been deprecated (Silverback.Core.EntityFrameworkCore contains all the necessary logic to use EF as store) KeyMemberAttribute has been renamed to PartitioningKeyMemberAttribute (see Connecting to a Message Broker) 0.10.0 What's new Improve error handling: now all exceptions, including the ones thrown by the message serialzer can be handled through the error policies Improve logs: promoted some important logs to Information level, writing all processing errors as (at least) Warning and improved logged information quality (logged attributes) Add ability to modify messages and headers when moving them via MoveMessageErrorPolicy Refactor message processing to a cleaner, more extensible and predictable API and behavior Fixes Fixed several small (and not so small) issues and bugs 0.8.0 - 0.9.0 Released two versions mostly to fix bugs, do some small adjustments according to some user feedbacks and update the external dependencies (e.g. Confluent.Kafka 1.0.1). Fixes Fix exception loading error policies from JSON in Silverback.Integration.Configuration [#24] 0.7.0 What's new Upgrade to Confluent.Kafka 1.0.0 Create a simple event store that perfectly integrates with the rest of the Silverback framework (see Event Sourcing) Add Silverback.Integration.InMemory package to mock the message broker behavior in your unit tests Several small optimizations and improvements 0.6.0 What's new Add support for message headers Simplify message subscription even further: now all public methods of the types implementing the marker interface ISubscriber are automatically subscribed by default without having to annotate them with the SubscribeAttribute (this behavior is customizable) Upgrade to Confluent.Kafka 1.0.0-RC1 0.3.x - 0.5.x Some releases where done adding quite a few features. What's new Add Silverback.Integration.Configuration package to load the inbound/outbound configuration from the app.settings json Add batch processing Add parallel subscribers Add delegate subscription as an alternative to SubscribeAttribute based subscription Improve support for Rx.net Add support for legacy messages and POCO classes Add offset storage as an alternative and more optimized way to guarantee exactly once processing, storing just the offset of the last message instead of logging every message (see Inbound Endpoint) Add behaviors as a convenient way to implement your cross-cutting concerns (like logging, validation, etc.) to be plugged into the internal bus publishing pipeline (see Behaviors) Add message chunking to automatically split the larger messages and rebuild them on the other end (see Chunking) ...much more...and a huge amount of refactorings Fixes Several fixes and optimizations 0.3.2 The very first public release of Silverback! It included: In-process message bus Inbound/outbound connector for message broker abstraction Kafka broker implementation Outbox table pattern implementation Exactly once processing ..."
+ "keywords": "Releases 4.6.0 What's new Add GetOffsetsForTimestamp to KafkaConsumer Allow specifying the number of partitions per topic in the mocked Kafka Fixes Further improve assembly qualified name parsing for generic types 4.5.1 Fixes Fix assembly qualified name parsing for generic types 4.5.0 What's new Upgrade to MQTTnet 4.3.6.1152 Upgrade to Confluent.Kafka 2.4.0 Minor changes to reduce the likelihood of a deadlock 4.4.1 What's new Upgrade to Confluent.Kafka 2.3.0 Upgrade to MQTTnet 4.3.2.930 4.4.0 What's new Allow parallel processing of MQTT messages Upgrade to MQTTnet 4.3.1.873 Upgrade to Confluent.Kafka 2.2.0 Fixes Correctly set message timestamp in mocked Kafka Properly handle Kafka partitions revoked event when no partitions were assigned [#214] Respect IgnoreUnhandledException when batch processing [#216] 4.3.2 Fixes Fix potential message loss in OutboxWorker 4.3.1 Fixes Fix deadlock in OutboxWorker when enforceMessageOrder=true (default) 4.3.0 What's new Upgrade to MQTTnet 4.2.0.706 Upgrade to Confluent.Kafka 2.1.1 Upgrade to Newtonsoft.Json 13.0.3 Add ReasonCode and ReasonString to MqttProduceException message 4.2.1 Fixes Prevent an ObjectDisposedException to be thrown by the BrokerCallbackInvoker during application shutdown Fix possible deadlock in BatchSequence with timeout 4.2.0 What's new Upgrade to Confluent.Kafka 2.1.0 4.1.2 Fixes Fix chained error policies attempts counter 4.1.1 Fixes Fix bug in outbox producer writing to the wrong endpoint [#165] 4.1.0 What's new Upgrade to Confluent.Kafka 2.0.2 Replace the deprecated package Confluent.Kafka.SchemaRegistry.Serdes with Confluent.Kafka.SchemaRegistry.Serdes.Avro Simplify the Avro serializer configuration and add samples (see Kafka - Avro) 4.0.1 What's new Upgrade to MQTTnet 4.1.4.563 4.0.0 What's new Upgrade to MQTTnet 4.1.3.436 Upgrade to Confluent.Kafka 1.9.3 Upgrade to Newtonsoft.Json 13.0.2 Disable server-side offset commit in KafkaConsumer when GroupId is not set Breaking changes Some breaking changes in MQTTnet 4 are reflected into Silverback 3.8.0 What's new Topic name resolvers can be used to filter the messages to be produce: returning null will discard the message Fixes Fix error policies not being triggered consistently when batch consuming Make IntegrationSpy fully thread-safe Prevent errors when the IKafkaPartitionsRevokedCallback is invoked during application shutdown Improve error handling during connection to MQTT 3.7.3 Fixes Support topic names with symbols (e.g. hyphens) in mocked MQTT broker 3.7.2 Fixes Correctly invoke the IKafkaOffsetCommittedCallback when auto commit is disabled [#167] 3.7.1 Fixes Improve message streams abort process to avoid first chance exceptions (e.g. during dispose) 3.7.0 What's new Implement basic support for Kafka transactions via KafkaTransactionalProducer (Note: this is just a first step and a more comprehensive implementation is planned for the upcoming release 4.0.0) Skip chunking when processing single chunk messages Fixes Fix possible race condition in consumer pipeline 3.6.1 Fixes Handle race condition in BatchSequence with timeout Limit consumer status history 3.6.0 What's new Handle IAsyncEnumerable returned by the subscriber and republished the contained messages Enrich Kafka messages moved by the MoveMessageErrorPolicy adding some extra headers containing some information about the source topic, partition, offset, etc. (see Message Headers) Allow filters such as the KafkaGroupIdFilterAttribute or MqttClientIdFilterAttribute to be added to the subscribers at runtime via the configuration API (see Multiple Consumer Groups (in same process) and Multiple Clients (in same process)) Add overload for Publish method in the error policies that forwards the exception as well as the envelope Throw TimeoutException from KafkaTestingHelper and MqttTestingHelper Improve MQTT connection related logs (info for successful reconnect and add broker name to log messages) Support shared sessions in mocked MQTT broker Fixes Ensure each consumed message gets a unique traceId (when the traceparent header is not present) Fix memory leak in consumer Fully validate messages, including nested objects 3.5.0 What's new Log MqttClient internal events (see Logging) Upgrade to Confluent.Kafka 1.8.2 Upgrade to MQTTnet 3.0.16 Upgrade to RabbitMQ.Client 6.2.2 Update several dependencies Fixes Fix MqttConsumer reconnection issues Handle edge cases related to MQTT acknowledgment timeout in MqttConsumer Allow max retries specification and error policies chains with MQTT V3 3.4.0 What's new Support encryption key rotation (see Encryption) 3.3.1 Fixes Fix AddHeaders and WithKafkaKey not being correctly invoked by all IProducer.Produce and IProducer.ProducerAsync overloads Add endpoint friendly name to all logs 3.3.0 What's new Optimize in-memory mocked Kafka (avoid spawning too many threads) Support multiple brokers (with overlapping topic names) in mocked Kafka and MQTT Add message validation for both producer and consumer (see Message Validation) Add new AddInbound overloads specifying message type for a more compact configuration when using the typed deserializer (see Serialization) Fixes Invoke the Kafka partition EOF callback for all connected consumers Ignore null or empty Kafka key in producer 3.2.0 What's new Add new Kafka partition EOF callback to be notified when the end of a partition is reached by the consumer (see Kafka Events and IKafkaPartitionEofCallback) Allow multiple calls to IKafkaConsumerEndpointBuilder.Configure or IKafkaProducerEndpointBuilder.Configure for the same endpoint Observe a grace period in the ConsumersHealthCheck to prevent false positives during a normal Kafka rebalance Add optional friendly name to the endpoints (see IEndpointBuilder .WithName and Endpoint.FriendlyName) Allow filtering the endpoints targeted by the ConsumersHealthCheck (see AddConsumersCheck) 3.1.1 Fixes Invoke broker callbacks during the application shutdown to allow custom code to be run when disconnecting 3.1.0 What's new Add new ways to configure headers and kafka key (see Message Headers and Kafka Partitioning and Message Key) New callbacks for Kafka log events (see Kafka Events) Improve consumer status tracking introducing ConsumerStatus.Ready Revert the Kafka consumer status from Ready to Connected whenever partitions are revoked or a poll timeout occurs Adapt consumer health check to monitor the new status and report unhealthy if not Ready (see Health Monitoring) Try to automatically recover from Kafka maximum poll interval exceed errors Improve Kafka static partition assignment with resolver function and fetching the available partitions (see Kafka Partitioning and Message Key) Upgrade to Confluent.Kafka 1.7.0 Upgrade to MQTTnet 3.0.15 Fixes Prevent possible race condition causing messages to be skipped when a RetryPolicy kicks in for messages from multiple Kafka partitions simultaneously Prevent ObjectDisposedException to be thrown when Kafka events (e.g. statistics) are fired during the application shutdown Prevent ObjectDisposedException to be thrown when Consumer.Dispose is called multiple times Properly clear the trace context (Activity) when reconnecting the consumer to prevent the newly started consume loop to be tracked under the current message traceId Fix wrong prefix in MQTT log event names 3.0.1 Fixes Fix IOutboxWriter lifecycle [#128] 3.0.0 What's new Add support for MQTT (see Connecting to a Message Broker, Inbound Endpoint, Outbound Endpoint, ...) Simplify configuration and reduce boilerplate (see Subscribing and Connecting to a Message Broker) Simplify subscribers registration and get rid of the ISubscriber interface (see Subscribing) Scan subscribers automatically at startup to reduce cost of first message Connect brokers and handle graceful shutdown automatically (see Connecting to a Message Broker) Improve endpoints configuration API (see Connecting to a Message Broker) Add IServiceCollection.ConfigureSilverback extension method to conveniently split the configuration code (see Enabling Silverback) Refactor Silverback.Integration to support streaming Create IMessageStreamEnumerable (see Streaming) Improve chunking support in conjunction with streaming, requiring only one chunk at a time to be loaded into memory Redesign sequences handling to support chunking, batch consuming and future sequences as well Improve Kafka partitions handling (see Kafka Partitioning and Message Key) Process partitions independently and concurrently Add setting to produce to a specific partition Add setting to manually assign the consumer partitions Add option to throw an exception if no subscriber is handling a message that was published to the internal bus or was consumed from a message broker (see throwIfUnhandled argument in the IPublisher methods and ThrowIfUnhandled property in the IConsumerEndpoint) Handle null messages as Tombstone/Tombstone (see Tombstone Message) Replace Newtonsoft.Json with System.Text.Json to improve serialization and deserialization performance (the old serializers have been moved into the Silverback.Integration.Newtonsoft package, see Serialization) Improve outbound routing customization options with endpoint name resolvers (see Outbound Messages Routing) Add non-blocking Produce/ProduceAsync/RawProduce/RawProduceAsync overloads to IProducer, better suitable for higher throughput scenarios (see Producer) Refactor broker event handlers (see Broker Callbacks) Expose IConsumer.StopAsync and IConsumer.StartAsync methods to pause and resume consumers Add log levels configuration (see Logging) Improve (distributed) tracing (see Logging) Allow header names customization (see Message Headers) Add consumer status information and statistics (see Connecting to a Message Broker) Add basic consumer health check (see Health Monitoring) Allow broker behaviors to be registered as transient, meaning that an instance will be created per each producer or consumer (see Broker behaviors pipeline) Improve code quality Enhance CI pipeline to use Roslyn analyzers Integrate SonarCloud) Improve integration tests Increase automated tests coverage Enable nullable reference types and adjust all API Document the entire public API (see API Documentation) Released some utilities to help writing automated tests involving Silverback.Integration (see Testing) Upgrade to Confluent.Kafka 1.6.2 Upgrade to RabbitMQ.Client 6.2.1 Fixes Fix OutboxWorker not publishing custom headers [#102] Breaking Changes Refactored IPublisher Removed the overloads to publish a batch of messages (see Publishing) Cannot subscribe to collection of messages anymore (see Subscribing), unless they are consumed from a message broker (see Streaming) The chunks belonging to the same message must be contiguous (interleaved messages are at the moment not supported anymore) and in the same partition in case of Kafka Removed ISubscriber interface Removed BusConfigurator (moved all the configuration into the ISilverbackBuilder extension methods) Replaced BusConfigurator.Connect with ISilverbackBuilder.AddEndpointsConfigurator and ISilverbackBuilder.AddEndpoints (or ISilverbackBuilder.AddKafkaEndpoints etc.) to configure the endpoints, while the broker is connected automatically at startup (see Connecting to a Message Broker) Replaced BusConfigurator.Subscribe methods with ISilverbackBuilder.AddDelegateSubscriber (see Subscribing) Replaced BusConfigurator.HandleMessagesOfType methods with ISilverbackBuilder.HandleMessageOfType (see Subscribing) BusConfigurator.ScanSubscribers is not needed anymore since it gets called automatically at startup (from an IHostedService) Removed IServiceCollection.Add*Subscriber, IServiceCollection.Add*Behavior, IServiceCollection.Add*BrokerBehavior, IServiceCollection.AddEndpointsConfigurator, IServiceCollection.Add*OutboundRouter extension methods, use the same methods on the ISilverbackBuilder (using IServiceCollection.ConfigureSilverback to get an instance if the ISilverbackBuilder if necessary, as shown in Enabling Silverback) Removed IBrokerOptionsBuilder.Add*BrokerBehavior, IBrokerOptionsBuilder.RegisterConfigurator, IBrokerOptionsBuilder.Add*OutboundRouter extension methods, use the same methods on the ISilverbackBuilder (using IServiceCollection.ConfigureSilverback to get an instance if the ISilverbackBuilder if necessary, as shown in Enabling Silverback) Reorganized the Silverback.Messaging.Configuration namespace moving some broker specific types under Silverback.Messaging.Configuration.Kafka, Silverback.Messaging.Configuration.Rabbit or Silverback.Messaging.Configuration.Mqtt The visibility of some types has been changed to internal to favor a cleaner and clearer API where the public types are well documented and their backward compatibility is valued Removed Silverback prefix from exceptions name Removed the IRequest interface (it was implemented by both IQuery and ICommand) Changed Impl methods suffix with Core, this affects some virtual members in the Broker and other base classes IConsumer.Received event replaced by a callback delegate IBroker.GetConsumer and IBrokerCollection.GetConsumer methods renamed to IBroker.AddConsumer and IBrokerCollection.AddConsumer IQueueProducer and IQueueConsumer renamed to IOutboxWriter and IOutboxReader The messages with a null body are by default mapped to a Tombstone/Tombstone (see Tombstone Message) Database: Moved all entities (used with Entity Framework Core) to the Silverback.Database.Model namespace Replaced InboundMessage entity with InboundLogEntry Replaced OutboundMessage entity with OutboxMessage Removed TemporaryMessageChunk Modified schema of StoredOffset entity Moved and renamed some internally used types (e.g. QueuedMessage, DbQueuedMessage, ...) Complete redesign of the error policies Removed IMessageIdProvider and all related logic: the Id or MessageId property will not be automatically initialized anymore and its value will not be used as identifier for the outbound message anymore (refer to the Message Identifier page for further details on how to set a custom message id, if needed) WithConnectionTo<>, WithConnectionToKafka, WithConnectionToRabbitMQ and WithInMemoryBroker have been removed, please use the new WithConnectionToMessageBroker and AddKafka/AddRabbit methods (see Connecting to a Message Broker) Replaced the internal messages for the Kafka events such as partitions revoked/assigned, offset commit, error, log and statistics with event handler interfaces (see Kafka Events) Deprecated Silverback.Integration.InMemory, use Silverback.Integration.Kafka.Testing, Silverback.Integration.RabbitMQ.Testing, etc. instead Renamed PartitioningKeyMemberAttribute to KafkaKeyMemberAttribute Silverback.Integration.Configuration has been discontinued Renamed Settings property to Options in the default JsonMessageSerializer (since the switch to System.Text.Json) Removed LogWithLevel method from SkipMessageErrorPolicy, use the new WithLogLevels configuration instead Removed Parallel option from SubscribeAttribute Renamed Offset to a more generic BrokerMessageIdentifier in the Silverback.Integration abstractions (including the envelopes) Some changes to the behaviors: Renamed Handle to HandleAsync in the IBehavior, IProducerBehavior and IConsumerBehavior Changed signature of the HandleAsync method (see Behaviors and Broker behaviors pipeline) Changed some sort indexes and introduced some new broker behaviors, you may need to adjust the sort index of your custom behaviors (see Broker behaviors pipeline for the updated list of built-in behaviors) Replaced IBroker.Connect and IBroker.Disconnect with IBroker.ConnectAsync and IBroker.DisconnectAsync Some major changes to batch consuming: Removed all batch events (BatchStartedEvent, BatchCompleteEvent, BatchProcessedEvent, BatchAbortedEvent), refer to Streaming to learn how to leverage the new IMessageStreamEnumerable Setting the batch size to 1 doesn't disable batching anymore, set the Batch to null in the ConsumerEndpoint to disable it When batching is enabled the messages can be subscribed only via the IMessageStreamEnumerable (see Streaming), the subscribers to the single messages will not be invoked ChunkSettings moved from Silverback.Messaging.LargeMessages namespace to Silverback.Messaging.Sequences.Chunking Replaced CoreEventIds, IntegrationEventIds, KafkaEventIds and RabbitEventIds with CoreLogEvents, IntegrationLogEvents, KafkaLogEvents and RabbitLogEvents (see also Logging) Deprecated support for Entity Framework 2, only the version 3.0.1 of Silverback.Core.EntityFrameworkCore will work with Silverback 3.0.0 Modified message encryption for chunked messages and it will not be compatible with previous versions of Silverback (affects chunking+encryption only) 2.2.0 What's new Allow custom outbound routers to be registered as scoped or transient (instead of singleton only) 2.1.2 Fixes Fix delay in Retry policy [#97] 2.1.1 What's new Add support for multiple message brokers (Kafka and RabbitMQ) in the same application (see Connecting to a Message Broker) Add end-to-end message encryption (see Encryption) Add dynamic custom routing of outbound messages (see Outbound Messages Routing) Improve support for message headers (see Message Headers) Add support for binary files (see Binary Files) Improve message identifier handling: the IIntegrationMessage is not required to have an Id property anymore (the x-message-id header will still be generated and if the property exists will continue to be automatically initialized) x-first-chunk-offset header added by default (see Message Headers) Deserialize KafkaStasticsEvent JSON and provided its content as an object (in addition to the raw JSON) Add support for Apache Avro and schema registry (see Serialization) Upgrade to Confluent.Kafka 1.4.2 Add consumer PrefetchSize and PrefetchCount settings to RabbitConsumerEndpoint Add AcknowledgeEach to the RabbitConsumerEndpoint to define the number of message processed before sending the acknowledgment to the server Upgrade to RabbitMQ.Client 6.0.0 Improve message type resolution performance and reliability in JsonMessageSerializer Add LogWithLevel method to SkipMessageErrorPolicy to specify the desired level for the \"Message skipped\" log entry (the default is now increased to Error) Breaking Changes These changes shouldn't affect you unless you built your own IBroker implementation or are interacting at low-level with the IBroker (this is why has been decided to still mark this as a minor release): The IBroker interface and Broker abstract base class have been modified to explicitly declare which endpoint type is being handled by the broker implementation The IMessageSerializer interfaces has been changed The IConsumerBehavior and IProducerBehavior interfaces have been changed Changed the parameters order in some less used overloads in the IBrokerOptionBuilder Announced Breaking Changes These aren't real breaking changes but some methods have been marked as deprecated and will be removed in one of the next major releases: WithConnectionTo<>, WithConnectionToKafka and WithConnectionToRabbitMQ are deprecated (they will still be supported in this version), please use the new WithConnectionToMessageBroker and AddKafka/AddRabbit methods (see Connecting to a Message Broker) 2.0.0 What's new Create Silverback.Integration.RabbitMQ package to connect Silverback with RabbitMQ (see Connecting to a Message Broker) Enable subscription of messages with an empty body (you must subscribe to the IInboundEnvelope) [#61] Add hook to manually set the Kafka partition start offset when a partition is assigned to the consumer (see Kafka Events) [#57] Support for multiple consumer groups running in the same process (see Multiple Consumer Groups (in same process)) [#59] Publish KafkaStatisticsEvent also from the KafkaProducer (previously done in KafkaConsumer only) Several reliability and performance related improvements Breaking Changes The IBroker, IProducer and IConsumer interfaces have been slightly modified (it shouldn't affect you unless you built your own IBroker implementation) Many interfaces (such as IBehavior) and delegates have been slightly modified to pass around an IReadOnlyCollection instead of an IEnumerable , to avoid the possible issues related to multiple enumeration of an IEnumerable The IMessageKeyProvider interface has been renamed to IMessageIdProvider to prevent to be mistaken with the Kafka Key or Rabbit's Routing Key IInboundMessage/IOutboundMessage (plus all the related types) have been renamed to IInboundEnvelope/IOutboundEnvelope and the property containing the actual message has been renamed from Content to Message The MustUnwrap option has been removed from the inbound connector configuration (messages are unwrapped by default) 1.2.0 What's new Publish events to the internal bus as a consequence to the Kafka events such as partitions assigned or revoked (see Kafka Events) [#34] 1.1.0 What's new Add IEndpointsConfigurator interface to allow splitting the endpoints configuration across multiple types (see Connecting to a Message Broker) Add support for distributed tracing (based on System.Diagnostics) Add IProducerBehavior and IConsumerBehavior to create an extension point closer to the actual message broker logic (see Broker behaviors pipeline) Breaking Changes Replaced ISortedBehavior with a generic ISorted interface 1.0.5 What's new Upgrade to Confluent.Kafka 1.3.0 Fixes Fix OutboundQueueHealthCheck [#43] Remove automatic disposal of the KafkaProducer when a KafkaException is thrown (creating too many instances of the producer over a short time span could lead to too many active TCP connections) Fix the bug preventing a KafkaConsumerEndpoint pointing to multiple topics to be successfully subscribed 1.0.4 Fixes Fix mortal loop issue: it is finally safe to consume and produce the same type of messages from within the same process (in a natural way, without any extra configuration) Since version 1.0.0 the messages routed to an endpoint aren't forwarded to any subscriber directly Now the inbound connector has been fixed as well, preventing the inbound messages to be immediately routed once again to the outbound endpoint and eliminating all possible causes of mortal loops 1.0.3 What's new Deprecate PartitioningKeyMemberAttribute in favor of KafkaKeyMemberAttribute, since the message key isn't used just for partitioning (see Kafka Partitioning and Message Key) Fixes Forward Kafka message key as-is (not hashed anymore) to avoid possible collisions and simplify debugging 1.0.2 Fixes Reintroduce Add*Subscriber and Add*Behavior as IServiceCollection extension methods (for backward compatibility and greater flexibility) [#41] Add WithInMemoryBroker and OverrideWithInMemoryBroker extension methods (see Testing) 1.0.0 What's new Optimize message size (no wrappers anymore) Improve headers usage: identifiers, types, chunks information, etc. are now all sent in the headers Review severity of some log entries Improve and clean up internal implementation Improve exception handling (flattening of AggregateException) Upgrade to Confluent.Kafka 1.2.2 Add automatic recovers from fatal errors in KafkaConsumer (can be disabled via Endpoint configuration) Support .Net Core 3.0 and Entity Framework Core 3.0 Refactor packages (EF binding logic is now in a single package, versioned after the related EF version) Improve configuration API Improve and optimize performance (including #37) Improve database locks mechanism (used also to run the OutboundQueueWorker) Fixes Fix issue requiring types not implementing IMessage to be registered with HandleMessagesOfType to consume them [#33] Mitigate issue causing the DistributedBackgroundService to sometime fail to acquire the database lock [#39] Fix partition key value being lost when using the DeferredOutboundConnector Other small fixes to improve stability and reliability Breaking Changes By default the messages published via IPublisher that are routed to an outbound endpoint are not sent through to the internal bus and cannot therefore be subscribed locally, within the same process (see Outbound Endpoint) Some changes in IInboundMessage and IOutboundMessage interfaces Changes to the schema of the outbox table (Silverback.Messaging.Connectors.Model.OutboundMessage) The configuration fluent API changed quite a bit, refer to the current documentation Important WithConnectionTo has to be replaced with WithConnectionToKafka in order for all features to work properly. When failing to do so no message key will be generated, causing the messages to land in a random partition and/or preventing to publish to a compacted topic. (see Kafka Partitioning and Message Key) Silverback.Integration.EntityFrameworkCore and Silverback.EventSourcing.EntityFrameworkCore have been deprecated (Silverback.Core.EntityFrameworkCore contains all the necessary logic to use EF as store) KeyMemberAttribute has been renamed to PartitioningKeyMemberAttribute (see Connecting to a Message Broker) 0.10.0 What's new Improve error handling: now all exceptions, including the ones thrown by the message serialzer can be handled through the error policies Improve logs: promoted some important logs to Information level, writing all processing errors as (at least) Warning and improved logged information quality (logged attributes) Add ability to modify messages and headers when moving them via MoveMessageErrorPolicy Refactor message processing to a cleaner, more extensible and predictable API and behavior Fixes Fixed several small (and not so small) issues and bugs 0.8.0 - 0.9.0 Released two versions mostly to fix bugs, do some small adjustments according to some user feedbacks and update the external dependencies (e.g. Confluent.Kafka 1.0.1). Fixes Fix exception loading error policies from JSON in Silverback.Integration.Configuration [#24] 0.7.0 What's new Upgrade to Confluent.Kafka 1.0.0 Create a simple event store that perfectly integrates with the rest of the Silverback framework (see Event Sourcing) Add Silverback.Integration.InMemory package to mock the message broker behavior in your unit tests Several small optimizations and improvements 0.6.0 What's new Add support for message headers Simplify message subscription even further: now all public methods of the types implementing the marker interface ISubscriber are automatically subscribed by default without having to annotate them with the SubscribeAttribute (this behavior is customizable) Upgrade to Confluent.Kafka 1.0.0-RC1 0.3.x - 0.5.x Some releases where done adding quite a few features. What's new Add Silverback.Integration.Configuration package to load the inbound/outbound configuration from the app.settings json Add batch processing Add parallel subscribers Add delegate subscription as an alternative to SubscribeAttribute based subscription Improve support for Rx.net Add support for legacy messages and POCO classes Add offset storage as an alternative and more optimized way to guarantee exactly once processing, storing just the offset of the last message instead of logging every message (see Inbound Endpoint) Add behaviors as a convenient way to implement your cross-cutting concerns (like logging, validation, etc.) to be plugged into the internal bus publishing pipeline (see Behaviors) Add message chunking to automatically split the larger messages and rebuild them on the other end (see Chunking) ...much more...and a huge amount of refactorings Fixes Several fixes and optimizations 0.3.2 The very first public release of Silverback! It included: In-process message bus Inbound/outbound connector for message broker abstraction Kafka broker implementation Outbox table pattern implementation Exactly once processing ..."
},
"samples/kafka/avro.html": {
"href": "samples/kafka/avro.html",
diff --git a/manifest.json b/manifest.json
index 588050d24..b3a45b2d9 100644
--- a/manifest.json
+++ b/manifest.json
@@ -1805,6 +1805,16 @@
},
"version": ""
},
+ {
+ "type": "ManagedReference",
+ "source_relative_path": "api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.yml",
+ "output": {
+ ".html": {
+ "relative_path": "api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html"
+ }
+ },
+ "version": ""
+ },
{
"type": "ManagedReference",
"source_relative_path": "api/Silverback.Messaging.Broker.Kafka.yml",
diff --git a/releases.html b/releases.html
index 1990d70c3..25159a4b5 100644
--- a/releases.html
+++ b/releases.html
@@ -79,49 +79,59 @@
Releases
-
+
+What's new
+
+- Add
GetOffsetsForTimestamp
to KafkaConsumer
+- Allow specifying the number of partitions per topic in the mocked Kafka
+
Fixes
+- Further improve assembly qualified name parsing for generic types
+
+
+Fixes
+
- Fix assembly qualified name parsing for generic types
-What's new
+What's new
-What's new
+What's new
-What's new
+What's new
-Fixes
+Fixes
- Correctly set message timestamp in mocked Kafka
- Properly handle Kafka partitions revoked event when no partitions were assigned [#214]
- Respect
IgnoreUnhandledException
when batch processing [#216]
-Fixes
+Fixes
- Fix potential message loss in
OutboxWorker
-Fixes
+Fixes
- Fix deadlock in
OutboxWorker
when enforceMessageOrder=true
(default)
-What's new
+What's new
-Fixes
+Fixes
- Prevent an
ObjectDisposedException
to be thrown by the BrokerCallbackInvoker
during application shutdown
- Fix possible deadlock in BatchSequence with timeout
-What's new
+What's new
-Fixes
+Fixes
- Fix chained error policies attempts counter
-Fixes
+Fixes
- Fix bug in outbox producer writing to the wrong endpoint [#165]
-What's new
+What's new
- Upgrade to Confluent.Kafka 2.0.2
- Replace the deprecated package
Confluent.Kafka.SchemaRegistry.Serdes
with Confluent.Kafka.SchemaRegistry.Serdes.Avro
- Simplify the Avro serializer configuration and add samples (see Kafka - Avro)
-What's new
+What's new
-What's new
+What's new
-What's new
+What's new
- Topic name resolvers can be used to filter the messages to be produce: returning
null
will discard the message
-Fixes
+Fixes
- Fix error policies not being triggered consistently when batch consuming
- Make
IntegrationSpy
fully thread-safe
@@ -186,38 +196,38 @@ Fixes
- Improve error handling during connection to MQTT
-Fixes
+Fixes
- Support topic names with symbols (e.g. hyphens) in mocked MQTT broker
-Fixes
+Fixes
-Fixes
+Fixes
- Improve message streams abort process to avoid first chance exceptions (e.g. during dispose)
-What's new
+What's new
- Implement basic support for Kafka transactions via KafkaTransactionalProducer (Note: this is just a first step and a more comprehensive implementation is planned for the upcoming release 4.0.0)
- Skip chunking when processing single chunk messages
-Fixes
+Fixes
- Fix possible race condition in consumer pipeline
-Fixes
+Fixes
- Handle race condition in BatchSequence with timeout
- Limit consumer status history
-What's new
+What's new
- Handle
IAsyncEnumerable<T>
returned by the subscriber and republished the contained messages
- Enrich Kafka messages moved by the MoveMessageErrorPolicy adding some extra headers containing some information about the source topic, partition, offset, etc. (see Message Headers)
@@ -227,14 +237,14 @@ What's new
- Improve MQTT connection related logs (info for successful reconnect and add broker name to log messages)
- Support shared sessions in mocked MQTT broker
-Fixes
+Fixes
- Ensure each consumed message gets a unique traceId (when the traceparent header is not present)
- Fix memory leak in consumer
- Fully validate messages, including nested objects
-What's new
+What's new
-Fixes
+Fixes
- Fix MqttConsumer reconnection issues
- Handle edge cases related to MQTT acknowledgment timeout in MqttConsumer
- Allow max retries specification and error policies chains with MQTT V3
-What's new
+What's new
-Fixes
+Fixes
- Fix
AddHeaders<TMessage>
and WithKafkaKey<TMessage>
not being correctly invoked by all IProducer.Produce
and IProducer.ProducerAsync
overloads
- Add endpoint friendly name to all logs
-What's new
+What's new
- Optimize in-memory mocked Kafka (avoid spawning too many threads)
- Support multiple brokers (with overlapping topic names) in mocked Kafka and MQTT
- Add message validation for both producer and consumer (see Message Validation)
- Add new
AddInbound
overloads specifying message type for a more compact configuration when using the typed deserializer (see Serialization)
-Fixes
+Fixes
- Invoke the Kafka partition EOF callback for all connected consumers
- Ignore null or empty Kafka key in producer
-What's new
+What's new
-Fixes
+Fixes
- Invoke broker callbacks during the application shutdown to allow custom code to be run when disconnecting
-What's new
+What's new
-Fixes
+Fixes
- Prevent possible race condition causing messages to be skipped when a
RetryPolicy
kicks in for messages from multiple Kafka partitions simultaneously
- Prevent
ObjectDisposedException
to be thrown when Kafka events (e.g. statistics) are fired during the application shutdown
@@ -311,12 +321,12 @@ Fixes
- Fix wrong prefix in MQTT log event names
-Fixes
+Fixes
-What's new
+What's new
-Fixes
+Fixes
@@ -444,17 +454,17 @@ Breaking Changes
Modified message encryption for chunked messages and it will not be compatible with previous versions of Silverback (affects chunking+encryption only)
-What's new
+What's new
- Allow custom outbound routers to be registered as scoped or transient (instead of singleton only)
-Fixes
+Fixes
- Fix delay in Retry policy [#97]
-What's new
+What's new
- Add support for multiple message brokers (Kafka and RabbitMQ) in the same application (see Connecting to a Message Broker)
- Add end-to-end message encryption (see Encryption)
@@ -486,7 +496,7 @@ Announced Breaking Changes
WithConnectionTo<>
, WithConnectionToKafka
and WithConnectionToRabbitMQ
are deprecated (they will still be supported in this version), please use the new WithConnectionToMessageBroker
and AddKafka
/AddRabbit
methods (see Connecting to a Message Broker)
-What's new
+What's new
-What's new
+What's new
- Publish events to the internal bus as a consequence to the Kafka events such as partitions assigned or revoked (see Kafka Events) [#34]
-What's new
+What's new
-What's new
+What's new
-Fixes
+Fixes
- Fix
OutboundQueueHealthCheck
[#43]
- Remove automatic disposal of the KafkaProducer when a KafkaException is thrown (creating too many instances of the producer over a short time span could lead to too many active TCP connections)
- Fix the bug preventing a KafkaConsumerEndpoint pointing to multiple topics to be successfully subscribed
-Fixes
+Fixes
- Fix mortal loop issue: it is finally safe to consume and produce the same type of messages from within the same process (in a natural way, without any extra configuration)
@@ -541,22 +551,22 @@ Fixes
-What's new
+What's new
-Fixes
+Fixes
- Forward Kafka message key as-is (not hashed anymore) to avoid possible collisions and simplify debugging
-Fixes
+Fixes
- Reintroduce
Add*Subscriber
and Add*Behavior
as IServiceCollection extension methods (for backward compatibility and greater flexibility) [#41]
- Add
WithInMemoryBroker
and OverrideWithInMemoryBroker
extension methods (see Testing)
-What's new
+What's new
- Optimize message size (no wrappers anymore)
- Improve headers usage: identifiers, types, chunks information, etc. are now all sent in the headers
@@ -571,7 +581,7 @@ What's new
- Improve and optimize performance (including #37)
- Improve database locks mechanism (used also to run the OutboundQueueWorker)
-Fixes
+Fixes
- Fix issue requiring types not implementing IMessage to be registered with
HandleMessagesOfType<T>
to consume them [#33]
- Mitigate issue causing the DistributedBackgroundService to sometime fail to acquire the database lock [#39]
@@ -594,25 +604,25 @@ Important
- KeyMemberAttribute has been renamed to PartitioningKeyMemberAttribute (see Connecting to a Message Broker)
-What's new
+What's new
- Improve error handling: now all exceptions, including the ones thrown by the message serialzer can be handled through the error policies
- Improve logs: promoted some important logs to Information level, writing all processing errors as (at least) Warning and improved logged information quality (logged attributes)
- Add ability to modify messages and headers when moving them via MoveMessageErrorPolicy
- Refactor message processing to a cleaner, more extensible and predictable API and behavior
-Fixes
+Fixes
- Fixed several small (and not so small) issues and bugs
0.8.0 - 0.9.0
Released two versions mostly to fix bugs, do some small adjustments according to some user feedbacks and update the external dependencies (e.g. Confluent.Kafka 1.0.1).
-Fixes
+Fixes
- Fix exception loading error policies from JSON in Silverback.Integration.Configuration [#24]
0.7.0
-What's new
+What's new
- Upgrade to Confluent.Kafka 1.0.0
- Create a simple event store that perfectly integrates with the rest of the Silverback framework (see Event Sourcing)
@@ -620,7 +630,7 @@ What's new
- Several small optimizations and improvements
0.6.0
-What's new
+What's new
- Add support for message headers
- Simplify message subscription even further: now all public methods of the types implementing the marker interface ISubscriber are automatically subscribed by default without having to annotate them with the SubscribeAttribute (this behavior is customizable)
@@ -628,7 +638,7 @@ What's new
0.3.x - 0.5.x
Some releases where done adding quite a few features.
-What's new
+What's new
- Add Silverback.Integration.Configuration package to load the inbound/outbound configuration from the app.settings json
- Add batch processing
@@ -641,7 +651,7 @@ What's new
- Add message chunking to automatically split the larger messages and rebuild them on the other end (see Chunking)
- ...much more...and a huge amount of refactorings
-Fixes
+Fixes
- Several fixes and optimizations
diff --git a/sitemap.xml b/sitemap.xml
index 8b0829949..fbdeba6d0 100644
--- a/sitemap.xml
+++ b/sitemap.xml
@@ -2,3931 +2,3937 @@
https://silverback-messaging.net/about.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddBrokerExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddInboundLogExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddKafkaExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddMockedKafkaExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddMockedMqttExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddMqttExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddOffsetStoreExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddOutboxExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddOutboxWorkerExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAddRabbitExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderAllowDuplicateEndpointsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.BrokerOptionsBuilderWithConnectionOptionsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.HealthCheckBuilderExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.IBrokerOptionsBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.IBrokerOptionsConfigurator-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.ServiceCollectionAddSilverbackExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.ServiceCollectionConfigureSilverbackExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.ServiceCollectionUseMockedKafkaExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.ServiceCollectionUseMockedMqttExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddBehaviorExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddBrokerBehaviorExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddBrokerCallbackHandlerExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddDbDistributedLockManagerExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddDelegateSubscriberExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddEndpointsConfiguratorExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddEndpointsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddIntegrationSpyExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddKafkaEndpointsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddMqttEndpointsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddOutboundRouterExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddSequenceReaderExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddSequenceWriterExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAddSubscriberExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderAsObservableExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderUseDbContextExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderUseMockedKafkaExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderUseMockedMqttExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderUseModelExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderWithConnectionToExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.SilverbackBuilderWithLogLevelsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Microsoft.Extensions.DependencyInjection.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.DbDistributedLockManager.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.DistributedBackgroundService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.DistributedLock.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.DistributedLockSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.DistributedLockStatus.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.IDistributedLockManager.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.NullLockManager.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.NullLockSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.RecurringDistributedBackgroundService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Background.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.DatabaseTableNotFoundException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.EfCoreDbContext-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.EfCoreDbSet-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.IDbContext.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.IDbSet-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.Model.InboundLogEntry.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.Model.Lock.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.Model.OutboxMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.Model.StoredOffset.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.Model.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Database.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.CoreLogEvents.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.IBrokerLogEnricher-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.IBrokerLogEnricher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.IInboundLogger-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.ILogLevelDictionary.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.IOutboundLogger-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.ISilverbackLogger-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.ISilverbackLogger.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.IntegrationLogEvents.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.KafkaActivityEnricher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.KafkaLogEvents.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.LogEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.MqttLogEvents.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.RabbitLogEvents.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Diagnostics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.DomainEntity.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.DomainEvent-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.EntityEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.EventSourcingDomainEntity-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.EventSourcingDomainEntity-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.EventSourcingException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.IAggregateRoot.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.IDomainEvent-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.IDomainEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.IEntityEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Domain.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EntityFrameworkCore.DbContextEventsPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EntityFrameworkCore.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.DbEventStoreRepository-4.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.EventEntity.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.EventStoreConcurrencyException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.EventStoreEntity-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.EventStoreException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.EventStoreNotFoundException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.EventStoreRepository-3.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.IEventEntity.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.IEventSourcingDomainEntity-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.IEventSourcingDomainEntity.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.IEventStoreEntity-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.EventStore.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.ISorted.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Infrastructure.RepositoryBase-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Infrastructure.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.InstanceIdentifier.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.BinaryFiles.BinaryFileHandlerConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.BinaryFiles.BinaryFileHandlerProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.BinaryFiles.BinaryFileMessageSerializer-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.BinaryFiles.BinaryFileMessageSerializer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.BinaryFiles.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.BrokerBehaviorsProvider-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.BrokerBehaviorsSortIndexes.Consumer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.BrokerBehaviorsSortIndexes.Producer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.BrokerBehaviorsSortIndexes.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.ConsumerBehaviorHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.ConsumerPipelineContext.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.IBrokerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.IBrokerBehaviorsProvider-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.IConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.IProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.MessageIdInitializerProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.ProducerBehaviorHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.ProducerPipelineContext.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Behaviors.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Broker-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.BrokerCollection.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.BrokerConnectorService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.BrokerCallbackInvocationException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IBrokerCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IBrokerCallbacksInvoker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IEndpointsConfiguredCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaConsumerErrorCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaConsumerLogCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaConsumerStatisticsCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaOffsetCommittedCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaPartitionEofCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaPartitionsAssignedCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaPartitionsRevokedCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaProducerLogCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IKafkaProducerStatisticsCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IMqttClientConnectedCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.IMqttClientDisconnectingCallback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.BrokerStatistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.ConsumerGroupStatistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.ExactlyOnceSemanticsStatistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.KafkaStatistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.PartitionStatistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.TopicPartitions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.TopicStatistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.WindowStatistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.Statistics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Callbacks.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Consumer-3.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Consumer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.ConsumerStatus.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IBroker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IBrokerCollection.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IBrokerMessageIdentifier.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IBrokerMessageOffset.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IConsumer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IConsumerStatusChange.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IConsumerStatusInfo.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.IProducer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.ConfluentAdminClientBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.ConfluentConsumerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.ConfluentProducerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.IConfluentAdminClientBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.IConfluentConsumerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.IConfluentProducerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.IConfluentProducersCache.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.MockedConfluentAdminClientBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.MockedConfluentConsumerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.MockedConfluentProducerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.Mocks.IInMemoryPartition.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.Mocks.IInMemoryTopic.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.Mocks.IMockedConfluentConsumer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.Mocks.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
+ weekly
+ 0.5
+
+
+ https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Kafka.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.KafkaBroker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.KafkaConsumer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.KafkaConsumerLocalTimeoutMonitor.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.KafkaOffset.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.KafkaProducer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.KafkaTransactionalProducer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.IMqttNetClientFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.MockedMqttNetClientFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.Mocks.IClientSession.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.Mocks.IInMemoryMqttBroker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.Mocks.MockedMqttClient.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.Mocks.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.MqttConnectException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.MqttNetClientFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.MqttProduceException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Mqtt.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.MqttBroker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.MqttConsumer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.MqttMessageIdentifier.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.MqttProducer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.ProduceException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Producer-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Producer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Rabbit.RabbitConnectionFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.Rabbit.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.RabbitBroker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.RabbitConsumer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.RabbitDeliveryTag.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.RabbitProducer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Broker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.AvroMessageDeserializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.AvroMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.BinaryFileMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.BrokerConnectionMode.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.BrokerConnectionOptions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ConsumerEndpointBuilder-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ConsumerEndpointBuilderConsumeBinaryFilesExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ConsumerEndpointBuilderDecryptUsingExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ConsumerEndpointBuilderDeserializeAvroExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ConsumerEndpointBuilderDeserializeJsonExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ConsumerEndpointBuilderDeserializeJsonUsingNewtonsoftExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.EndpointBuilder-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.EndpointsConfigurationBuilderAddInboundExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.EndpointsConfigurationBuilderAddKafkaEndpointsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.EndpointsConfigurationBuilderAddMqttEndpointsExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.EndpointsConfigurationBuilderAddOutboundExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ErrorPolicyBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ErrorPolicyBuilderMoveToKafkaTopicExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ErrorPolicyBuilderMoveToMqttTopicExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ErrorPolicyChainBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ErrorPolicyChainBuilderMoveToKafkaTopicExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ErrorPolicyChainBuilderMoveToMqttTopicExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ExactlyOnceStrategy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ExactlyOnceStrategyBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IAvroMessageDeserializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IAvroMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IBinaryFileMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IBusOptions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IConsumerEndpointBuilder-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IEndpointBuilder-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IEndpointsConfigurationBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IEndpointsConfigurator.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IErrorPolicyBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IErrorPolicyChainBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IExactlyOnceStrategyBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IJsonMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ILogLevelConfigurator.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.INewtonsoftJsonMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IProducerEndpointBuilder-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ISilverbackBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.IValidatableEndpointSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.JsonMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.ConfluentClientConfigProxy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.ConfluentConsumerConfigProxy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.ConfluentProducerConfigProxy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.IKafkaConsumerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.IKafkaEndpointsConfigurationBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.IKafkaProducerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.KafkaClientConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.KafkaConsumerConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.KafkaConsumerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.KafkaProducerConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.KafkaProducerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Kafka.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.KafkaBrokerOptionsConfigurator.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.IMockedMqttOptions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.IMockedMqttOptionsBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.IMqttClientConfigBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.IMqttConsumerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.IMqttEndpointsConfigurationBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.IMqttLastWillMessageBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.IMqttProducerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.MqttBrokerOptionsConfigurator.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.MqttClientConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.MqttClientConfigBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.MqttConsumerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.MqttLastWillMessageBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.MqttProducerEndpointBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Mqtt.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.NewtonsoftJsonMessageSerializerBuilder.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ProducerEndpointBuilder-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ProducerEndpointBuilderEncryptUsingExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ProducerEndpointBuilderProduceBinaryFilesExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ProducerEndpointBuilderSerializeAsAvroExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ProducerEndpointBuilderSerializeAsJsonExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.ProducerEndpointBuilderSerializeAsJsonUsingNewtonsoftExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Rabbit.RabbitConnectionConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Rabbit.RabbitEndpointConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Rabbit.RabbitExchangeConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Rabbit.RabbitQueueConfig.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Rabbit.RabbitSslOption.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.Rabbit.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.RabbitBrokerOptionsConfigurator.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.SilverbackBuilderHandleMessageOfTypeExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.SilverbackBuilderPublishOutboundMessagesToInternalBusExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.SilverbackBuilderWithCustomHeaderNameExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Configuration.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.ConsumerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.ActivityConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.ActivityProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.ActivityTagNames.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.ConsumerPipelineFatalException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.FatalExceptionLoggerConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.IActivityEnricherFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.IBrokerActivityEnricher-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.IBrokerActivityEnricher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Diagnostics.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.DecryptorConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.EncryptionSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.EncryptorProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.ISilverbackCryptoStreamFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.SilverbackCryptoStream.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.SilverbackCryptoStreamFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.SymmetricDecryptStream.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.SymmetricDecryptionSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.SymmetricEncryptStream.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.SymmetricEncryptionSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.SymmetricEncryptionSettingsBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Encryption.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Endpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.EndpointConfigurationException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Headers.CustomHeadersMapperConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Headers.CustomHeadersMapperProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Headers.HeadersReaderConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Headers.HeadersWriterProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Headers.ICustomHeadersMappings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Headers.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.ConsumersHealthCheck.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.ConsumersHealthCheckService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.EndpointCheckResult.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.IConsumersHealthCheckService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.IOutboundEndpointsHealthCheckService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.IOutboundQueueHealthCheckService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.OutboundEndpointsHealthCheck.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.OutboundEndpointsHealthCheckService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.OutboundQueueHealthCheckService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.OutboxQueueHealthCheck.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.PingMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.HealthChecks.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.IConsumerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.IEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.IProducerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.IRawMessageTransformer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.ErrorPolicyBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.ErrorPolicyChain.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.ErrorPolicyImplementation.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.IErrorPolicy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.IErrorPolicyImplementation.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.MoveMessageErrorPolicy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.RetryErrorPolicy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.RetryableErrorPolicyBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.SkipMessageErrorPolicy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.StopConsumerErrorPolicy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ErrorHandling.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.ExactlyOnceGuardConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.IExactlyOnceStrategy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.IExactlyOnceStrategyImplementation.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.LogExactlyOnceStrategy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.OffsetStoreExactlyOnceStrategy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.Repositories.DbInboundLog.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.Repositories.DbOffsetStore.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.Repositories.IInboundLog.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.Repositories.IOffsetStore.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.Repositories.InMemoryInboundLog.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.Repositories.InMemoryOffsetStore.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.Repositories.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.ExactlyOnce.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.PublisherConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.Transaction.ConsumerTransactionManager.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.Transaction.IConsumerTransactionManager.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.Transaction.ITransactional.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.Transaction.TransactionHandlerConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.Transaction.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Inbound.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.KafkaConsumerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.KafkaProducerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.BinaryFileMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.DefaultMessageHeaders.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.EnvelopeFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.HeaderAttribute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IBinaryFileMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IBrokerEnvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.ICommand-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.ICommand.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IEnvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IInboundEnvelope-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IInboundEnvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IIntegrationCommand.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IIntegrationEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IIntegrationMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.ILazyMessageStreamEnumerable-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IMessageStreamEnumerable-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IMessageStreamObservable-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IMessageStreamProvider.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IMessageWithSource.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IMessagesSource.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IOutboundEnvelope-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IOutboundEnvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IQuery-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IRawBrokerEnvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IRawInboundEnvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.IRawOutboundEnvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.ISilverbackEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.KafkaKeyMemberAttribute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.KafkaMessageHeaders.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.MessageHeader.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.MessageHeaderCollection.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.MessageHeaderEnumerableExtensions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.MessagesSource-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.RabbitMessageHeaders.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.RabbitRoutingKeyAttribute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.Tombstone-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.Tombstone.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.TransactionAbortedEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.TransactionCompletedEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.TransactionStartedEvent.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Messages.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.MqttConsumerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.MqttProducerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.GenericOutboundHeadersEnricher-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.GenericOutboundHeadersEnricher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.IBrokerOutboundMessageEnrichersFactory.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.IMovePolicyMessageEnricher-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.IMovePolicyMessageEnricher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.IOutboundMessageEnricher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.MessageEnricherProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.OutboundMessageIdHeadersEnricher-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.OutboundMessageKafkaKeyEnricher-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.OutboundMessageRabbitRoutingKeyEnricher-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Enrichers.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.IProduceStrategy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.IProduceStrategyImplementation.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.IntegrationBehaviorsSortIndexes.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.KafkaMessageKeyInitializerProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.RabbitRoutingKeyInitializerProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.DictionaryOutboundRouter-2.RouterFunction.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.DictionaryOutboundRouter-2.SingleEndpointRouterFunction.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.DictionaryOutboundRouter-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.EndpointNameResolverProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.IKafkaProducerEndpointNameResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.IOutboundRoute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.IOutboundRouter-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.IOutboundRouter.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.IOutboundRoutingConfiguration.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.IProducerEndpointNameResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.KafkaOutboundEndpointRouter-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.KafkaPartitionResolverProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.KafkaProducerEndpointNameResolver-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.MqttOutboundEndpointRouter-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.OutboundQueueProducer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.OutboundRoute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.OutboundRouter-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.OutboundRouterBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.ProduceBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.ProducerEndpointNameResolver-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.SimpleOutboundRouter-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.StaticOutboundRouter.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.Routing.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.IOutboxWorker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.OutboxProduceStrategy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.OutboxTransactionManager.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.OutboxWorker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.OutboxWorkerService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.DbOutboxReader.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.DbOutboxWriter.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.IOutboxReader.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.IOutboxWriter.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.InMemoryOutbox.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.Model.DbOutboxStoredMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.Model.OutboxStoredMessage.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.Model.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.TransactionalOutboxBroker.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.TransactionalOutbox.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Outbound.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.ProducerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.BehaviorsProvider.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.CommandPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.EventPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.IBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.IBehaviorsProvider.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.ICommandPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.IEventPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.IPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.IQueryPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.MessageHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.Publisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.QueryPublisher.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.UnhandledMessageException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Publishing.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.RabbitConsumerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.RabbitExchangeConsumerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.RabbitExchangeProducerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.RabbitProducerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.RabbitQueueConsumerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.RabbitQueueProducerEndpoint.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.AddToSequenceResult.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Batch.BatchSequence.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Batch.BatchSequenceReader.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Batch.BatchSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Batch.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Chunking.ChunkSequence.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Chunking.ChunkSequenceReader.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Chunking.ChunkSequenceWriter.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Chunking.ChunkSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Chunking.ChunkStream.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Chunking.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.ISequence.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.ISequenceReader.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.ISequenceStore.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.ISequenceWriter.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.IncompleteSequence.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.RawSequence.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.RawSequencerConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.Sequence.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequenceAbortReason.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequenceBase-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequenceException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequenceReaderBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequenceSettings.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequencerConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequencerConsumerBehaviorBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.SequencerProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Sequences.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.AvroMessageDeserializer-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.AvroMessageDeserializerBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.AvroMessageSerializer-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.AvroMessageSerializerBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.DefaultKafkaMessageSerializer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.DeserializerConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.IKafkaMessageSerializer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.IMessageSerializer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.JsonMessageSerializer-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.JsonMessageSerializer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.JsonMessageSerializerBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.MessageEncoding.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.MessageSerializationContext.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.MessageSerializerException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.NewtonsoftJsonMessageSerializer-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.NewtonsoftJsonMessageSerializer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.NewtonsoftJsonMessageSerializerBase.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.NullMessageHandlingStrategy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.SerializerProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Serialization.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.DefaultAdditionalArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.IAdditionalArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.IArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.ILazyArgumentValue.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.IMessageArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.ISingleMessageArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.IStreamEnumerableMessageArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.ObservableStreamMessageArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.SingleMessageArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.StreamEnumerableMessageArgumentResolver.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ArgumentResolvers.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.IMessageFilter.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ISubscribedMethodsCache.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.KafkaGroupIdFilterAttribute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.MessageFilterAttribute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.MqttClientIdFilterAttribute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ReturnValueHandlers.AsyncEnumerableMessagesReturnValueHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ReturnValueHandlers.EnumerableMessagesReturnValueHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ReturnValueHandlers.IReturnValueHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ReturnValueHandlers.ObservableMessagesReturnValueHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ReturnValueHandlers.ReadOnlyCollectionMessagesReturnValueHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ReturnValueHandlers.SingleMessageReturnValueHandler.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.ReturnValueHandlers.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.SubscribeAttribute.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.SubscribedMethod.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.SubscribedMethodInvocationException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.SubscribedMethodsLoaderService.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.Subscriptions.ISubscription.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.Subscriptions.SubscriptionOptions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.Subscriptions.TypeSubscriptionOptions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.Subscriptions.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Subscribers.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Validation.MessageValidationException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Validation.MessageValidationMode.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Validation.ValidatorConsumerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Validation.ValidatorProducerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.Validation.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Messaging.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.SilverbackException.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.IIntegrationSpy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.IKafkaTestingHelper.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.IMqttTestingHelper.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.ITestingHelper-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.InboundSpyBrokerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.InboundSpySubscriber.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.IntegrationSpy.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.KafkaTestingHelper.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.MqttTestingHelper.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.OutboundSpyBrokerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.RawInboundSpyBrokerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.RawOutboundSpyBrokerBehavior.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.TestingHelper-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Testing.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Util.TransactionalDictionary-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Util.TransactionalDictionarySharedItems-2.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Util.TransactionalList-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Util.TransactionalListItem-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Util.TransactionalListSharedItems-1.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.Util.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/api/Silverback.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/background-services.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/behaviors.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/binary-files.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/callbacks.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/chunking.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/connecting.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/encryption.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/headers.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/inbound.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/inboundenvelope.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/kafka/kafka-events.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/kafka/kafka-partitioning.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/kafka/multiple-consumer-groups.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/message-id.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/mqtt/mqtt-events.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/mqtt/multiple-clients.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/outbound-routing.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/outbound.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/producer.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/rabbit/routing-key.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/serialization.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/streaming.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/testing.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/tombstone.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/translating-messages.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/broker/validation.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/bus/behaviors.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/bus/enabling.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/bus/model.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/bus/publish.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/bus/subscribe.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/dbcontext.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/domain-events.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/event-sourcing.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/introduction.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/concepts/logging.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/contributing.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/index.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/releases.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/kafka/avro.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/kafka/basic.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/kafka/batch.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/kafka/binaryfile-streaming.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/mqtt/basic-v3.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/mqtt/basic.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/mqtt/binaryfile-streaming.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
https://silverback-messaging.net/samples/samples.html
- 2024-09-25T11:22:27+02:00
+ 2025-01-09T04:51:04+01:00
weekly
0.5
diff --git a/xrefmap.yml b/xrefmap.yml
index 5bbc3b1af..cea5ef1a6 100644
--- a/xrefmap.yml
+++ b/xrefmap.yml
@@ -12905,6 +12905,96 @@ references:
isSpec: "True"
fullName: Silverback.Messaging.Broker.Kafka.Mocks.IMockedConfluentConsumer.PartitionsAssigned
nameWithType: IMockedConfluentConsumer.PartitionsAssigned
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker
+ name: OffsetsTracker
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html
+ commentId: T:Silverback.Messaging.Broker.Kafka.OffsetsTracker
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker
+ nameWithType: OffsetsTracker
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.Commit(Confluent.Kafka.TopicPartitionOffset)
+ name: Commit(TopicPartitionOffset)
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_Commit_Confluent_Kafka_TopicPartitionOffset_
+ commentId: M:Silverback.Messaging.Broker.Kafka.OffsetsTracker.Commit(Confluent.Kafka.TopicPartitionOffset)
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.Commit(Confluent.Kafka.TopicPartitionOffset)
+ nameWithType: OffsetsTracker.Commit(TopicPartitionOffset)
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.Commit*
+ name: Commit
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_Commit_
+ commentId: Overload:Silverback.Messaging.Broker.Kafka.OffsetsTracker.Commit
+ isSpec: "True"
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.Commit
+ nameWithType: OffsetsTracker.Commit
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetCommitOffsets
+ name: GetCommitOffsets()
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_GetCommitOffsets
+ commentId: M:Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetCommitOffsets
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetCommitOffsets()
+ nameWithType: OffsetsTracker.GetCommitOffsets()
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetCommitOffsets*
+ name: GetCommitOffsets
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_GetCommitOffsets_
+ commentId: Overload:Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetCommitOffsets
+ isSpec: "True"
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetCommitOffsets
+ nameWithType: OffsetsTracker.GetCommitOffsets
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetRollbackOffSets
+ name: GetRollbackOffSets()
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_GetRollbackOffSets
+ commentId: M:Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetRollbackOffSets
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetRollbackOffSets()
+ nameWithType: OffsetsTracker.GetRollbackOffSets()
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetRollbackOffSets*
+ name: GetRollbackOffSets
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_GetRollbackOffSets_
+ commentId: Overload:Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetRollbackOffSets
+ isSpec: "True"
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.GetRollbackOffSets
+ nameWithType: OffsetsTracker.GetRollbackOffSets
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset(Confluent.Kafka.TopicPartitionOffset)
+ name: TrackOffset(TopicPartitionOffset)
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_TrackOffset_Confluent_Kafka_TopicPartitionOffset_
+ commentId: M:Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset(Confluent.Kafka.TopicPartitionOffset)
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset(Confluent.Kafka.TopicPartitionOffset)
+ nameWithType: OffsetsTracker.TrackOffset(TopicPartitionOffset)
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset(Silverback.Messaging.Broker.KafkaOffset)
+ name: TrackOffset(KafkaOffset)
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_TrackOffset_Silverback_Messaging_Broker_KafkaOffset_
+ commentId: M:Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset(Silverback.Messaging.Broker.KafkaOffset)
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset(Silverback.Messaging.Broker.KafkaOffset)
+ nameWithType: OffsetsTracker.TrackOffset(KafkaOffset)
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset*
+ name: TrackOffset
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_TrackOffset_
+ commentId: Overload:Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset
+ isSpec: "True"
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.TrackOffset
+ nameWithType: OffsetsTracker.TrackOffset
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackAllPartitions
+ name: UntrackAllPartitions()
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_UntrackAllPartitions
+ commentId: M:Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackAllPartitions
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackAllPartitions()
+ nameWithType: OffsetsTracker.UntrackAllPartitions()
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackAllPartitions*
+ name: UntrackAllPartitions
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_UntrackAllPartitions_
+ commentId: Overload:Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackAllPartitions
+ isSpec: "True"
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackAllPartitions
+ nameWithType: OffsetsTracker.UntrackAllPartitions
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackPartition(Confluent.Kafka.TopicPartition)
+ name: UntrackPartition(TopicPartition)
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_UntrackPartition_Confluent_Kafka_TopicPartition_
+ commentId: M:Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackPartition(Confluent.Kafka.TopicPartition)
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackPartition(Confluent.Kafka.TopicPartition)
+ nameWithType: OffsetsTracker.UntrackPartition(TopicPartition)
+- uid: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackPartition*
+ name: UntrackPartition
+ href: api/Silverback.Messaging.Broker.Kafka.OffsetsTracker.html#Silverback_Messaging_Broker_Kafka_OffsetsTracker_UntrackPartition_
+ commentId: Overload:Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackPartition
+ isSpec: "True"
+ fullName: Silverback.Messaging.Broker.Kafka.OffsetsTracker.UntrackPartition
+ nameWithType: OffsetsTracker.UntrackPartition
- uid: Silverback.Messaging.Broker.KafkaBroker
name: KafkaBroker
href: api/Silverback.Messaging.Broker.KafkaBroker.html
@@ -13102,6 +13192,22 @@ references:
isSpec: "True"
fullName: Silverback.Messaging.Broker.KafkaConsumer.GetCurrentSequenceStores
nameWithType: KafkaConsumer.GetCurrentSequenceStores
+- uid: Silverback.Messaging.Broker.KafkaConsumer.GetOffsetsForTimestamp(System.Collections.Generic.IEnumerable{Confluent.Kafka.TopicPartitionTimestamp},System.TimeSpan)
+ name: GetOffsetsForTimestamp(IEnumerable, TimeSpan)
+ href: api/Silverback.Messaging.Broker.KafkaConsumer.html#Silverback_Messaging_Broker_KafkaConsumer_GetOffsetsForTimestamp_System_Collections_Generic_IEnumerable_Confluent_Kafka_TopicPartitionTimestamp__System_TimeSpan_
+ commentId: M:Silverback.Messaging.Broker.KafkaConsumer.GetOffsetsForTimestamp(System.Collections.Generic.IEnumerable{Confluent.Kafka.TopicPartitionTimestamp},System.TimeSpan)
+ name.vb: GetOffsetsForTimestamp(IEnumerable(Of TopicPartitionTimestamp), TimeSpan)
+ fullName: Silverback.Messaging.Broker.KafkaConsumer.GetOffsetsForTimestamp(System.Collections.Generic.IEnumerable, System.TimeSpan)
+ fullName.vb: Silverback.Messaging.Broker.KafkaConsumer.GetOffsetsForTimestamp(System.Collections.Generic.IEnumerable(Of Confluent.Kafka.TopicPartitionTimestamp), System.TimeSpan)
+ nameWithType: KafkaConsumer.GetOffsetsForTimestamp(IEnumerable, TimeSpan)
+ nameWithType.vb: KafkaConsumer.GetOffsetsForTimestamp(IEnumerable(Of TopicPartitionTimestamp), TimeSpan)
+- uid: Silverback.Messaging.Broker.KafkaConsumer.GetOffsetsForTimestamp*
+ name: GetOffsetsForTimestamp
+ href: api/Silverback.Messaging.Broker.KafkaConsumer.html#Silverback_Messaging_Broker_KafkaConsumer_GetOffsetsForTimestamp_
+ commentId: Overload:Silverback.Messaging.Broker.KafkaConsumer.GetOffsetsForTimestamp
+ isSpec: "True"
+ fullName: Silverback.Messaging.Broker.KafkaConsumer.GetOffsetsForTimestamp
+ nameWithType: KafkaConsumer.GetOffsetsForTimestamp
- uid: Silverback.Messaging.Broker.KafkaConsumer.MemberId
name: MemberId
href: api/Silverback.Messaging.Broker.KafkaConsumer.html#Silverback_Messaging_Broker_KafkaConsumer_MemberId
@@ -20689,6 +20795,19 @@ references:
isSpec: "True"
fullName: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.PartitionsAssignmentDelay
nameWithType: IMockedKafkaOptions.PartitionsAssignmentDelay
+- uid: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.TopicPartitionsCount
+ name: TopicPartitionsCount
+ href: api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.html#Silverback_Messaging_Configuration_Kafka_IMockedKafkaOptions_TopicPartitionsCount
+ commentId: P:Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.TopicPartitionsCount
+ fullName: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.TopicPartitionsCount
+ nameWithType: IMockedKafkaOptions.TopicPartitionsCount
+- uid: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.TopicPartitionsCount*
+ name: TopicPartitionsCount
+ href: api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.html#Silverback_Messaging_Configuration_Kafka_IMockedKafkaOptions_TopicPartitionsCount_
+ commentId: Overload:Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.TopicPartitionsCount
+ isSpec: "True"
+ fullName: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptions.TopicPartitionsCount
+ nameWithType: IMockedKafkaOptions.TopicPartitionsCount
- uid: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder
name: IMockedKafkaOptionsBuilder
href: api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.html
@@ -20740,6 +20859,22 @@ references:
isSpec: "True"
fullName: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithDefaultPartitionsCount
nameWithType: IMockedKafkaOptionsBuilder.WithDefaultPartitionsCount
+- uid: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithPartitionsCount(System.String,System.Int32)
+ name: WithPartitionsCount(string, int)
+ href: api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.html#Silverback_Messaging_Configuration_Kafka_IMockedKafkaOptionsBuilder_WithPartitionsCount_System_String_System_Int32_
+ commentId: M:Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithPartitionsCount(System.String,System.Int32)
+ name.vb: WithPartitionsCount(String, Integer)
+ fullName: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithPartitionsCount(string, int)
+ fullName.vb: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithPartitionsCount(String, Integer)
+ nameWithType: IMockedKafkaOptionsBuilder.WithPartitionsCount(string, int)
+ nameWithType.vb: IMockedKafkaOptionsBuilder.WithPartitionsCount(String, Integer)
+- uid: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithPartitionsCount*
+ name: WithPartitionsCount
+ href: api/Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.html#Silverback_Messaging_Configuration_Kafka_IMockedKafkaOptionsBuilder_WithPartitionsCount_
+ commentId: Overload:Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithPartitionsCount
+ isSpec: "True"
+ fullName: Silverback.Messaging.Configuration.Kafka.IMockedKafkaOptionsBuilder.WithPartitionsCount
+ nameWithType: IMockedKafkaOptionsBuilder.WithPartitionsCount
- uid: Silverback.Messaging.Configuration.Kafka.KafkaClientConfig
name: KafkaClientConfig
href: api/Silverback.Messaging.Configuration.Kafka.KafkaClientConfig.html