• Concepts
  • Samples
  • API Documentation
  • Releases
  • About
  • Contributing
  • API Documentation
  • Silverback.Diagnostics
  • IntegrationLogEvents

    Show / Hide Table of Contents
    • Microsoft.Extensions.DependencyInjection
      • BrokerOptionsBuilderAddBrokerExtensions
      • BrokerOptionsBuilderAddInboundLogExtensions
      • BrokerOptionsBuilderAddKafkaExtensions
      • BrokerOptionsBuilderAddMockedKafkaExtensions
      • BrokerOptionsBuilderAddMockedMqttExtensions
      • BrokerOptionsBuilderAddMqttExtensions
      • BrokerOptionsBuilderAddOffsetStoreExtensions
      • BrokerOptionsBuilderAddOutboxExtensions
      • BrokerOptionsBuilderAddOutboxWorkerExtensions
      • BrokerOptionsBuilderAddRabbitExtensions
      • BrokerOptionsBuilderAllowDuplicateEndpointsExtensions
      • BrokerOptionsBuilderWithConnectionOptionsExtensions
      • HealthCheckBuilderExtensions
      • IBrokerOptionsBuilder
      • IBrokerOptionsConfigurator<TBroker>
      • ServiceCollectionAddSilverbackExtensions
      • ServiceCollectionConfigureSilverbackExtensions
      • ServiceCollectionUseMockedKafkaExtensions
      • ServiceCollectionUseMockedMqttExtensions
      • SilverbackBuilderAddBehaviorExtensions
      • SilverbackBuilderAddBrokerBehaviorExtensions
      • SilverbackBuilderAddBrokerCallbackHandlerExtensions
      • SilverbackBuilderAddDbDistributedLockManagerExtensions
      • SilverbackBuilderAddDelegateSubscriberExtensions
      • SilverbackBuilderAddEndpointsConfiguratorExtensions
      • SilverbackBuilderAddEndpointsExtensions
      • SilverbackBuilderAddIntegrationSpyExtensions
      • SilverbackBuilderAddKafkaEndpointsExtensions
      • SilverbackBuilderAddMqttEndpointsExtensions
      • SilverbackBuilderAddOutboundRouterExtensions
      • SilverbackBuilderAddSequenceReaderExtensions
      • SilverbackBuilderAddSequenceWriterExtensions
      • SilverbackBuilderAddSubscriberExtensions
      • SilverbackBuilderAsObservableExtensions
      • SilverbackBuilderUseDbContextExtensions
      • SilverbackBuilderUseMockedKafkaExtensions
      • SilverbackBuilderUseMockedMqttExtensions
      • SilverbackBuilderUseModelExtensions
      • SilverbackBuilderWithConnectionToExtensions
      • SilverbackBuilderWithLogLevelsExtensions
    • Silverback
      • ISorted
      • InstanceIdentifier
      • SilverbackException
    • Silverback.Background
      • DbDistributedLockManager
      • DistributedBackgroundService
      • DistributedLock
      • DistributedLockSettings
      • DistributedLockStatus
      • IDistributedLockManager
      • NullLockManager
      • NullLockSettings
      • RecurringDistributedBackgroundService
    • Silverback.Database
      • DatabaseTableNotFoundException
      • EfCoreDbContext<TDbContext>
      • EfCoreDbSet<TEntity>
      • IDbContext
      • IDbSet<TEntity>
    • Silverback.Database.Model
      • InboundLogEntry
      • Lock
      • OutboxMessage
      • StoredOffset
    • Silverback.Diagnostics
      • CoreLogEvents
      • IBrokerLogEnricher
      • IBrokerLogEnricher<TEndpoint>
      • IInboundLogger<TCategoryName>
      • ILogLevelDictionary
      • IOutboundLogger<TCategoryName>
      • ISilverbackLogger
      • ISilverbackLogger<TCategoryName>
      • IntegrationLogEvents
      • KafkaActivityEnricher
      • KafkaLogEvents
      • LogEvent
      • MqttLogEvents
      • RabbitLogEvents
    • Silverback.Domain
      • DomainEntity
      • DomainEvent<TEntity>
      • EntityEvent
      • EventSourcingDomainEntity<TKey>
      • EventSourcingDomainEntity<TKey, TDomainEvent>
      • EventSourcingException
      • IAggregateRoot
      • IDomainEvent
      • IDomainEvent<TEntity>
      • IEntityEvent
    • Silverback.EntityFrameworkCore
      • DbContextEventsPublisher
    • Silverback.EventStore
      • DbEventStoreRepository<TDomainEntity, TKey, TEventStoreEntity, TEventEntity>
      • EventEntity
      • EventStoreConcurrencyException
      • EventStoreEntity<TEventEntity>
      • EventStoreException
      • EventStoreNotFoundException
      • EventStoreRepository<TDomainEntity, TEventStoreEntity, TEventEntity>
      • IEventEntity
      • IEventSourcingDomainEntity
      • IEventSourcingDomainEntity<TKey>
      • IEventStoreEntity<TEventEntity>
    • Silverback.Infrastructure
      • RepositoryBase<TEntity>
    • Silverback.Messaging
      • ConsumerEndpoint
      • Endpoint
      • EndpointConfigurationException
      • IConsumerEndpoint
      • IEndpoint
      • IProducerEndpoint
      • IRawMessageTransformer
      • KafkaConsumerEndpoint
      • KafkaProducerEndpoint
      • MqttConsumerEndpoint
      • MqttProducerEndpoint
      • ProducerEndpoint
      • RabbitConsumerEndpoint
      • RabbitExchangeConsumerEndpoint
      • RabbitExchangeProducerEndpoint
      • RabbitProducerEndpoint
      • RabbitQueueConsumerEndpoint
      • RabbitQueueProducerEndpoint
    • Silverback.Messaging.BinaryFiles
      • BinaryFileHandlerConsumerBehavior
      • BinaryFileHandlerProducerBehavior
      • BinaryFileMessageSerializer
      • BinaryFileMessageSerializer<TModel>
    • Silverback.Messaging.Broker
      • BrokerCollection
      • BrokerConnectorService
      • Broker<TProducerEndpoint, TConsumerEndpoint>
      • Consumer
      • ConsumerStatus
      • Consumer<TBroker, TEndpoint, TIdentifier>
      • IBroker
      • IBrokerCollection
      • IBrokerMessageIdentifier
      • IBrokerMessageOffset
      • IConsumer
      • IConsumerStatusChange
      • IConsumerStatusInfo
      • IProducer
      • KafkaBroker
      • KafkaConsumer
      • KafkaConsumerLocalTimeoutMonitor
      • KafkaOffset
      • KafkaProducer
      • KafkaTransactionalProducer
      • MqttBroker
      • MqttConsumer
      • MqttMessageIdentifier
      • MqttProducer
      • ProduceException
      • Producer
      • Producer<TBroker, TEndpoint>
      • RabbitBroker
      • RabbitConsumer
      • RabbitDeliveryTag
      • RabbitProducer
    • Silverback.Messaging.Broker.Behaviors
      • BrokerBehaviorsProvider<TBehavior>
      • BrokerBehaviorsSortIndexes
      • BrokerBehaviorsSortIndexes.Consumer
      • BrokerBehaviorsSortIndexes.Producer
      • ConsumerBehaviorHandler
      • ConsumerPipelineContext
      • IBrokerBehavior
      • IBrokerBehaviorsProvider<TBehavior>
      • IConsumerBehavior
      • IProducerBehavior
      • MessageIdInitializerProducerBehavior
      • ProducerBehaviorHandler
      • ProducerPipelineContext
    • Silverback.Messaging.Broker.Callbacks
      • BrokerCallbackInvocationException
      • IBrokerCallback
      • IBrokerCallbacksInvoker
      • IEndpointsConfiguredCallback
      • IKafkaConsumerErrorCallback
      • IKafkaConsumerLogCallback
      • IKafkaConsumerStatisticsCallback
      • IKafkaOffsetCommittedCallback
      • IKafkaPartitionEofCallback
      • IKafkaPartitionsAssignedCallback
      • IKafkaPartitionsRevokedCallback
      • IKafkaProducerLogCallback
      • IKafkaProducerStatisticsCallback
      • IMqttClientConnectedCallback
      • IMqttClientDisconnectingCallback
    • Silverback.Messaging.Broker.Callbacks.Statistics
      • BrokerStatistics
      • ConsumerGroupStatistics
      • ExactlyOnceSemanticsStatistics
      • KafkaStatistics
      • PartitionStatistics
      • TopicPartitions
      • TopicStatistics
      • WindowStatistics
    • Silverback.Messaging.Broker.Kafka
      • ConfluentAdminClientBuilder
      • ConfluentConsumerBuilder
      • ConfluentProducerBuilder
      • IConfluentAdminClientBuilder
      • IConfluentConsumerBuilder
      • IConfluentProducerBuilder
      • IConfluentProducersCache
      • MockedConfluentAdminClientBuilder
      • MockedConfluentConsumerBuilder
      • MockedConfluentProducerBuilder
      • OffsetsTracker
    • Silverback.Messaging.Broker.Kafka.Mocks
      • IInMemoryPartition
      • IInMemoryTopic
      • IMockedConfluentConsumer
    • Silverback.Messaging.Broker.Mqtt
      • IMqttNetClientFactory
      • MockedMqttNetClientFactory
      • MqttConnectException
      • MqttNetClientFactory
      • MqttProduceException
    • Silverback.Messaging.Broker.Mqtt.Mocks
      • IClientSession
      • IInMemoryMqttBroker
      • MockedMqttClient
    • Silverback.Messaging.Broker.Rabbit
      • RabbitConnectionFactory
    • Silverback.Messaging.Configuration
      • AvroMessageDeserializerBuilder
      • AvroMessageSerializerBuilder
      • BinaryFileMessageSerializerBuilder
      • BrokerConnectionMode
      • BrokerConnectionOptions
      • ConsumerEndpointBuilderConsumeBinaryFilesExtensions
      • ConsumerEndpointBuilderDecryptUsingExtensions
      • ConsumerEndpointBuilderDeserializeAvroExtensions
      • ConsumerEndpointBuilderDeserializeJsonExtensions
      • ConsumerEndpointBuilderDeserializeJsonUsingNewtonsoftExtensions
      • ConsumerEndpointBuilder<TEndpoint, TBuilder>
      • EndpointBuilder<TEndpoint, TBuilder>
      • EndpointsConfigurationBuilderAddInboundExtensions
      • EndpointsConfigurationBuilderAddKafkaEndpointsExtensions
      • EndpointsConfigurationBuilderAddMqttEndpointsExtensions
      • EndpointsConfigurationBuilderAddOutboundExtensions
      • ErrorPolicyBuilder
      • ErrorPolicyBuilderMoveToKafkaTopicExtensions
      • ErrorPolicyBuilderMoveToMqttTopicExtensions
      • ErrorPolicyChainBuilder
      • ErrorPolicyChainBuilderMoveToKafkaTopicExtensions
      • ErrorPolicyChainBuilderMoveToMqttTopicExtensions
      • ExactlyOnceStrategy
      • ExactlyOnceStrategyBuilder
      • IAvroMessageDeserializerBuilder
      • IAvroMessageSerializerBuilder
      • IBinaryFileMessageSerializerBuilder
      • IBusOptions
      • IConsumerEndpointBuilder<TBuilder>
      • IEndpointBuilder<TBuilder>
      • IEndpointsConfigurationBuilder
      • IEndpointsConfigurator
      • IErrorPolicyBuilder
      • IErrorPolicyChainBuilder
      • IExactlyOnceStrategyBuilder
      • IJsonMessageSerializerBuilder
      • ILogLevelConfigurator
      • INewtonsoftJsonMessageSerializerBuilder
      • IProducerEndpointBuilder<TBuilder>
      • ISilverbackBuilder
      • IValidatableEndpointSettings
      • JsonMessageSerializerBuilder
      • KafkaBrokerOptionsConfigurator
      • NewtonsoftJsonMessageSerializerBuilder
      • ProducerEndpointBuilderEncryptUsingExtensions
      • ProducerEndpointBuilderProduceBinaryFilesExtensions
      • ProducerEndpointBuilderSerializeAsAvroExtensions
      • ProducerEndpointBuilderSerializeAsJsonExtensions
      • ProducerEndpointBuilderSerializeAsJsonUsingNewtonsoftExtensions
      • ProducerEndpointBuilder<TEndpoint, TBuilder>
      • RabbitBrokerOptionsConfigurator
      • SilverbackBuilderHandleMessageOfTypeExtensions
      • SilverbackBuilderPublishOutboundMessagesToInternalBusExtensions
      • SilverbackBuilderWithCustomHeaderNameExtensions
    • Silverback.Messaging.Configuration.Kafka
      • ConfluentClientConfigProxy
      • ConfluentConsumerConfigProxy
      • ConfluentProducerConfigProxy
      • IKafkaConsumerEndpointBuilder
      • IKafkaEndpointsConfigurationBuilder
      • IKafkaProducerEndpointBuilder
      • IMockedKafkaOptions
      • IMockedKafkaOptionsBuilder
      • KafkaClientConfig
      • KafkaConsumerConfig
      • KafkaConsumerEndpointBuilder
      • KafkaProducerConfig
      • KafkaProducerEndpointBuilder
    • Silverback.Messaging.Configuration.Mqtt
      • IMockedMqttOptions
      • IMockedMqttOptionsBuilder
      • IMqttClientConfigBuilder
      • IMqttConsumerEndpointBuilder
      • IMqttEndpointsConfigurationBuilder
      • IMqttLastWillMessageBuilder
      • IMqttProducerEndpointBuilder
      • MqttBrokerOptionsConfigurator
      • MqttClientConfig
      • MqttClientConfigBuilder
      • MqttConsumerEndpointBuilder
      • MqttLastWillMessageBuilder
      • MqttProducerEndpointBuilder
    • Silverback.Messaging.Configuration.Rabbit
      • RabbitConnectionConfig
      • RabbitEndpointConfig
      • RabbitExchangeConfig
      • RabbitQueueConfig
      • RabbitSslOption
    • Silverback.Messaging.Diagnostics
      • ActivityConsumerBehavior
      • ActivityProducerBehavior
      • ActivityTagNames
      • ConsumerPipelineFatalException
      • FatalExceptionLoggerConsumerBehavior
      • IActivityEnricherFactory
      • IBrokerActivityEnricher
      • IBrokerActivityEnricher<TEndpoint>
    • Silverback.Messaging.Encryption
      • DecryptorConsumerBehavior
      • EncryptionSettings
      • EncryptorProducerBehavior
      • ISilverbackCryptoStreamFactory
      • SilverbackCryptoStream
      • SilverbackCryptoStreamFactory
      • SymmetricDecryptStream
      • SymmetricDecryptionSettings
      • SymmetricEncryptStream
      • SymmetricEncryptionSettings
      • SymmetricEncryptionSettingsBase
    • Silverback.Messaging.Headers
      • CustomHeadersMapperConsumerBehavior
      • CustomHeadersMapperProducerBehavior
      • HeadersReaderConsumerBehavior
      • HeadersWriterProducerBehavior
      • ICustomHeadersMappings
    • Silverback.Messaging.HealthChecks
      • ConsumersHealthCheck
      • ConsumersHealthCheckService
      • EndpointCheckResult
      • IConsumersHealthCheckService
      • IOutboundEndpointsHealthCheckService
      • IOutboundQueueHealthCheckService
      • OutboundEndpointsHealthCheck
      • OutboundEndpointsHealthCheckService
      • OutboundQueueHealthCheckService
      • OutboxQueueHealthCheck
      • PingMessage
    • Silverback.Messaging.Inbound
      • PublisherConsumerBehavior
    • Silverback.Messaging.Inbound.ErrorHandling
      • ErrorPolicyBase
      • ErrorPolicyChain
      • ErrorPolicyImplementation
      • IErrorPolicy
      • IErrorPolicyImplementation
      • MoveMessageErrorPolicy
      • RetryErrorPolicy
      • RetryableErrorPolicyBase
      • SkipMessageErrorPolicy
      • StopConsumerErrorPolicy
    • Silverback.Messaging.Inbound.ExactlyOnce
      • ExactlyOnceGuardConsumerBehavior
      • IExactlyOnceStrategy
      • IExactlyOnceStrategyImplementation
      • LogExactlyOnceStrategy
      • OffsetStoreExactlyOnceStrategy
    • Silverback.Messaging.Inbound.ExactlyOnce.Repositories
      • DbInboundLog
      • DbOffsetStore
      • IInboundLog
      • IOffsetStore
      • InMemoryInboundLog
      • InMemoryOffsetStore
    • Silverback.Messaging.Inbound.Transaction
      • ConsumerTransactionManager
      • IConsumerTransactionManager
      • ITransactional
      • TransactionHandlerConsumerBehavior
    • Silverback.Messaging.Messages
      • BinaryFileMessage
      • DefaultMessageHeaders
      • EnvelopeFactory
      • HeaderAttribute
      • IBinaryFileMessage
      • IBrokerEnvelope
      • ICommand
      • ICommand<TResult>
      • IEnvelope
      • IEvent
      • IInboundEnvelope
      • IInboundEnvelope<TMessage>
      • IIntegrationCommand
      • IIntegrationEvent
      • IIntegrationMessage
      • ILazyMessageStreamEnumerable<TMessage>
      • IMessage
      • IMessageStreamEnumerable<TMessage>
      • IMessageStreamObservable<TMessage>
      • IMessageStreamProvider
      • IMessageWithSource
      • IMessagesSource
      • IOutboundEnvelope
      • IOutboundEnvelope<TMessage>
      • IQuery<TResult>
      • IRawBrokerEnvelope
      • IRawInboundEnvelope
      • IRawOutboundEnvelope
      • ISilverbackEvent
      • KafkaKeyMemberAttribute
      • KafkaMessageHeaders
      • MessageHeader
      • MessageHeaderCollection
      • MessageHeaderEnumerableExtensions
      • MessagesSource<TBaseEvent>
      • RabbitMessageHeaders
      • RabbitRoutingKeyAttribute
      • Tombstone
      • Tombstone<TMessage>
      • TransactionAbortedEvent
      • TransactionCompletedEvent
      • TransactionStartedEvent
    • Silverback.Messaging.Outbound
      • IProduceStrategy
      • IProduceStrategyImplementation
      • IntegrationBehaviorsSortIndexes
      • KafkaMessageKeyInitializerProducerBehavior
      • RabbitRoutingKeyInitializerProducerBehavior
    • Silverback.Messaging.Outbound.Enrichers
      • GenericOutboundHeadersEnricher
      • GenericOutboundHeadersEnricher<TMessage>
      • IBrokerOutboundMessageEnrichersFactory
      • IMovePolicyMessageEnricher
      • IMovePolicyMessageEnricher<TEndpoint>
      • IOutboundMessageEnricher
      • MessageEnricherProducerBehavior
      • OutboundMessageIdHeadersEnricher<TMessage>
      • OutboundMessageKafkaKeyEnricher<TMessage>
      • OutboundMessageRabbitRoutingKeyEnricher<TMessage>
    • Silverback.Messaging.Outbound.Routing
      • DictionaryOutboundRouter<TMessage, TEndpoint>
      • DictionaryOutboundRouter<TMessage, TEndpoint>.RouterFunction
      • DictionaryOutboundRouter<TMessage, TEndpoint>.SingleEndpointRouterFunction
      • EndpointNameResolverProducerBehavior
      • IKafkaProducerEndpointNameResolver
      • IOutboundRoute
      • IOutboundRouter
      • IOutboundRouter<TMessage>
      • IOutboundRoutingConfiguration
      • IProducerEndpointNameResolver
      • KafkaOutboundEndpointRouter<TMessage>
      • KafkaPartitionResolverProducerBehavior
      • KafkaProducerEndpointNameResolver<TMessage>
      • MqttOutboundEndpointRouter<TMessage>
      • OutboundQueueProducer
      • OutboundRoute
      • OutboundRouterBehavior
      • OutboundRouter<TMessage>
      • ProduceBehavior
      • ProducerEndpointNameResolver<TMessage>
      • SimpleOutboundRouter<TMessage>
      • StaticOutboundRouter
    • Silverback.Messaging.Outbound.TransactionalOutbox
      • IOutboxWorker
      • OutboxProduceStrategy
      • OutboxTransactionManager
      • OutboxWorker
      • OutboxWorkerService
      • TransactionalOutboxBroker
    • Silverback.Messaging.Outbound.TransactionalOutbox.Repositories
      • DbOutboxReader
      • DbOutboxWriter
      • IOutboxReader
      • IOutboxWriter
      • InMemoryOutbox
    • Silverback.Messaging.Outbound.TransactionalOutbox.Repositories.Model
      • DbOutboxStoredMessage
      • OutboxStoredMessage
    • Silverback.Messaging.Publishing
      • BehaviorsProvider
      • CommandPublisher
      • EventPublisher
      • IBehavior
      • IBehaviorsProvider
      • ICommandPublisher
      • IEventPublisher
      • IPublisher
      • IQueryPublisher
      • MessageHandler
      • Publisher
      • QueryPublisher
      • UnhandledMessageException
    • Silverback.Messaging.Sequences
      • AddToSequenceResult
      • ISequence
      • ISequenceReader
      • ISequenceStore
      • ISequenceWriter
      • IncompleteSequence
      • RawSequence
      • RawSequencerConsumerBehavior
      • Sequence
      • SequenceAbortReason
      • SequenceBase<TEnvelope>
      • SequenceException
      • SequenceReaderBase
      • SequenceSettings
      • SequencerConsumerBehavior
      • SequencerConsumerBehaviorBase
      • SequencerProducerBehavior
    • Silverback.Messaging.Sequences.Batch
      • BatchSequence
      • BatchSequenceReader
      • BatchSettings
    • Silverback.Messaging.Sequences.Chunking
      • ChunkSequence
      • ChunkSequenceReader
      • ChunkSequenceWriter
      • ChunkSettings
      • ChunkStream
    • Silverback.Messaging.Serialization
      • AvroMessageDeserializerBase
      • AvroMessageDeserializer<TMessage>
      • AvroMessageSerializerBase
      • AvroMessageSerializer<TMessage>
      • DefaultKafkaMessageSerializer
      • DeserializerConsumerBehavior
      • IKafkaMessageSerializer
      • IMessageSerializer
      • JsonMessageSerializer
      • JsonMessageSerializerBase
      • JsonMessageSerializer<TMessage>
      • MessageEncoding
      • MessageSerializationContext
      • MessageSerializerException
      • NewtonsoftJsonMessageSerializer
      • NewtonsoftJsonMessageSerializerBase
      • NewtonsoftJsonMessageSerializer<TMessage>
      • NullMessageHandlingStrategy
      • SerializerProducerBehavior
    • Silverback.Messaging.Subscribers
      • IMessageFilter
      • ISubscribedMethodsCache
      • KafkaGroupIdFilterAttribute
      • MessageFilterAttribute
      • MqttClientIdFilterAttribute
      • SubscribeAttribute
      • SubscribedMethod
      • SubscribedMethodInvocationException
      • SubscribedMethodsLoaderService
    • Silverback.Messaging.Subscribers.ArgumentResolvers
      • DefaultAdditionalArgumentResolver
      • IAdditionalArgumentResolver
      • IArgumentResolver
      • ILazyArgumentValue
      • IMessageArgumentResolver
      • ISingleMessageArgumentResolver
      • IStreamEnumerableMessageArgumentResolver
      • ObservableStreamMessageArgumentResolver
      • SingleMessageArgumentResolver
      • StreamEnumerableMessageArgumentResolver
    • Silverback.Messaging.Subscribers.ReturnValueHandlers
      • AsyncEnumerableMessagesReturnValueHandler
      • EnumerableMessagesReturnValueHandler
      • IReturnValueHandler
      • ObservableMessagesReturnValueHandler
      • ReadOnlyCollectionMessagesReturnValueHandler
      • SingleMessageReturnValueHandler
    • Silverback.Messaging.Subscribers.Subscriptions
      • ISubscription
      • SubscriptionOptions
      • TypeSubscriptionOptions
    • Silverback.Messaging.Validation
      • MessageValidationException
      • MessageValidationMode
      • ValidatorConsumerBehavior
      • ValidatorProducerBehavior
    • Silverback.Testing
      • IIntegrationSpy
      • IKafkaTestingHelper
      • IMqttTestingHelper
      • ITestingHelper<TBroker>
      • InboundSpyBrokerBehavior
      • InboundSpySubscriber
      • IntegrationSpy
      • KafkaTestingHelper
      • MqttTestingHelper
      • OutboundSpyBrokerBehavior
      • RawInboundSpyBrokerBehavior
      • RawOutboundSpyBrokerBehavior
      • TestingHelper<TBroker>
    • Silverback.Util
      • TransactionalDictionarySharedItems<TKey, TValue>
      • TransactionalDictionary<TKey, TValue>
      • TransactionalListItem<T>
      • TransactionalListSharedItems<T>
      • TransactionalList<T>

    Class IntegrationLogEvents

    Contains the LogEvent constants of all events logged by the Silverback.Integration package.

    Inheritance
    object
    IntegrationLogEvents
    Inherited Members
    object.Equals(object)
    object.Equals(object, object)
    object.GetHashCode()
    object.GetType()
    object.MemberwiseClone()
    object.ReferenceEquals(object, object)
    object.ToString()
    Namespace: Silverback.Diagnostics
    Assembly: Silverback.Integration.dll
    Syntax
    public static class IntegrationLogEvents

    Properties

    | Improve this doc View source

    BrokerConnected

    Gets the LogEvent representing the log that is written when connected to the message broker.

    Declaration
    public static LogEvent BrokerConnected { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    BrokerConnecting

    Gets the LogEvent representing the log that is written when connecting to the message broker.

    Declaration
    public static LogEvent BrokerConnecting { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    BrokerConnectionError

    Gets the LogEvent representing the log that is written when an exception is thrown when connecting to the message broker.

    Declaration
    public static LogEvent BrokerConnectionError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    BrokerDisconnected

    Gets the LogEvent representing the log that is written when disconnected from the message broker.

    Declaration
    public static LogEvent BrokerDisconnected { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    BrokerDisconnecting

    Gets the LogEvent representing the log that is written when disconnecting from the message broker.

    Declaration
    public static LogEvent BrokerDisconnecting { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    CallbackHandlerError

    Gets the LogEvent representing the log that is written when an exception is thrown by a broker callback handler.

    Declaration
    public static LogEvent CallbackHandlerError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    CannotMoveSequences

    Gets the LogEvent representing the log that is written when the MoveMessageErrorPolicy cannot be applied because the failing message belongs to a sequences (it's either chunked, being processed in batch, etc.).

    Declaration
    public static LogEvent CannotMoveSequences { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerCommitError

    Gets the LogEvent representing the log that is written when an error occurs in the consumer during the commit operation.

    Declaration
    public static LogEvent ConsumerCommitError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerConnectError

    Gets the LogEvent representing the log that is written when an exception is thrown connecting the consumer.

    Declaration
    public static LogEvent ConsumerConnectError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerConnected

    Gets the LogEvent representing the log that is written when the consumer is connected to the endpoint and will start consuming.

    Declaration
    public static LogEvent ConsumerConnected { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerDisconnectError

    Gets the LogEvent representing the log that is written when an exception is thrown disconnecting the consumer.

    Declaration
    public static LogEvent ConsumerDisconnectError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerDisconnected

    Gets the LogEvent representing the log that is written when the consumer is disconnected from the endpoint.

    Declaration
    public static LogEvent ConsumerDisconnected { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerDisposingError

    Gets the LogEvent representing the log that is written when an error occurs while the consumer is disconnecting. This may in some cases cause inconsistencies, with some messages not being properly committed.

    Declaration
    public static LogEvent ConsumerDisposingError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerFatalError

    Gets the LogEvent representing the log that is written when an unhandled error occurs while consuming and the consumer will be stopped.

    Declaration
    public static LogEvent ConsumerFatalError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerRollbackError

    Gets the LogEvent representing the log that is written when an error occurs in the consumer during the rollback operation.

    Declaration
    public static LogEvent ConsumerRollbackError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerStartError

    Gets the LogEvent representing the log that is written when an exception is thrown starting the consumer.

    Declaration
    public static LogEvent ConsumerStartError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ConsumerStopError

    Gets the LogEvent representing the log that is written when an exception is thrown stopping the consumer.

    Declaration
    public static LogEvent ConsumerStopError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    CreatingNewConsumer

    Gets the LogEvent representing the log that is written when a new consumer is being instantiated.

    Declaration
    public static LogEvent CreatingNewConsumer { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    CreatingNewProducer

    Gets the LogEvent representing the log that is written when a new producer is being instantiated.

    Declaration
    public static LogEvent CreatingNewProducer { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    EndpointConfiguratorError

    Gets the LogEvent representing the log that is written when an exception is thrown from within an IEndpointsConfigurator.

    Declaration
    public static LogEvent EndpointConfiguratorError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ErrorInitializingActivity

    Reserved, not used anymore.

    Declaration
    [Obsolete("Not used anymore.", true)]
    public static LogEvent ErrorInitializingActivity { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ErrorProcessingInboundMessage

    Gets the LogEvent representing the log that is written when an error occurs while processing an inbound message.

    Declaration
    public static LogEvent ErrorProcessingInboundMessage { get; }
    Property Value
    Type Description
    LogEvent
    Remarks

    If the message belongs to a sequence the ErrorProcessingInboundSequence event is logged instead.

    | Improve this doc View source

    ErrorProcessingInboundSequence

    Gets the LogEvent representing the log that is written when an error occurs while processing an inbound sequence.

    Declaration
    public static LogEvent ErrorProcessingInboundSequence { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ErrorProcessingOutbox

    Gets the LogEvent representing the log that is written when an error occurs while the IOutboxWorker processes the outbox queue.

    Declaration
    public static LogEvent ErrorProcessingOutbox { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ErrorProducingMessage

    Gets the LogEvent representing the log that is written when an error occurs producing a message.

    Declaration
    public static LogEvent ErrorProducingMessage { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ErrorProducingOutboxStoredMessage

    Gets the LogEvent representing the log that is written when an error occurs while producing the message stored in the outbox.

    Declaration
    public static LogEvent ErrorProducingOutboxStoredMessage { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ErrorReconnectingConsumer

    Gets the LogEvent representing the log that is written when an exception is thrown reconnecting the consumer (auto recovery from errors).

    Declaration
    public static LogEvent ErrorReconnectingConsumer { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    IncompleteSequenceAborted

    Gets the LogEvent representing the log that is written when an incomplete sequence is aborted because a new sequence starts before the current one is completed or the timeout elapses before the sequence can be completed).

    Declaration
    public static LogEvent IncompleteSequenceAborted { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    InvalidEndpointConfiguration

    Gets the LogEvent representing the log that is written when trying to connect an endpoint with an invalid configuration.

    Declaration
    public static LogEvent InvalidEndpointConfiguration { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    InvalidMessageProcessed

    Gets the LogEvent representing the log that is written when an invalid message has been processed (see MessageValidationMode).

    Declaration
    public static LogEvent InvalidMessageProcessed { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    InvalidMessageProduced

    Gets the LogEvent representing the log that is written when an invalid message has been produced (see MessageValidationMode).

    Declaration
    public static LogEvent InvalidMessageProduced { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    LowLevelTracing

    Gets the EventId of the low level tracing logs.

    Declaration
    public static LogEvent LowLevelTracing { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    MessageAddedToSequence

    Gets the LogEvent representing the log that is written when an inbound message is added to a sequence (e.g. ChunkSequence or a BatchSequence).

    Declaration
    public static LogEvent MessageAddedToSequence { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    MessageAlreadyProcessed

    Gets the LogEvent representing the log that is written when the message is being skipped since already processed (according to the stored offsets or message id).

    Declaration
    public static LogEvent MessageAlreadyProcessed { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    MessageMoved

    Gets the LogEvent representing the log that is written when a message couldn't be processed and is moved to another endpoint. This event occurs when the MoveMessageErrorPolicy is applied.

    Declaration
    public static LogEvent MessageMoved { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    MessageProduced

    Gets the LogEvent representing the log that is written when a message is produced.

    Declaration
    public static LogEvent MessageProduced { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    MessageSkipped

    Gets the LogEvent representing the log that is written when a message couldn't be processed and is skipped. This event occurs when the SkipMessageErrorPolicy is applied.

    Declaration
    public static LogEvent MessageSkipped { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    MessageWrittenToOutbox

    Gets the LogEvent representing the log that is written when the message is being written to the outbox.

    Declaration
    public static LogEvent MessageWrittenToOutbox { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    NullMessageSkipped

    Gets the LogEvent representing the log that is written when a null message is skipped (see Skip.

    Declaration
    public static LogEvent NullMessageSkipped { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    OutboxEmpty

    Gets the LogEvent representing the log that is written when the IOutboxWorker doesn't find any message in the outbox.

    Declaration
    public static LogEvent OutboxEmpty { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    PolicyApplyRuleReturnedFalse

    Gets the LogEvent representing the log that is written during the evaluation of an error policy, when the policy isn't applied because of it's apply rule.

    Declaration
    public static LogEvent PolicyApplyRuleReturnedFalse { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    PolicyChainCompleted

    Gets the LogEvent representing the log that is written when all chained policies have been applied but the processing still failed and the consumer will therefore be stopped.

    Declaration
    public static LogEvent PolicyChainCompleted { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    PolicyExceptionExcluded

    Gets the LogEvent representing the log that is written during the evaluation of an error policy, when the policy isn't applied because the current exception type is in the exclusion list.

    Declaration
    public static LogEvent PolicyExceptionExcluded { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    PolicyExceptionNotIncluded

    Gets the LogEvent representing the log that is written during the evaluation of an error policy, when the policy isn't applied because the current exception type is not in the inclusion list.

    Declaration
    public static LogEvent PolicyExceptionNotIncluded { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    PolicyMaxFailedAttemptsExceeded

    Gets the LogEvent representing the log that is written during the evaluation of an error policy, when the maximum configured failed attempts for the policies are exceeded and the policy isn't applied anymore.

    Declaration
    public static LogEvent PolicyMaxFailedAttemptsExceeded { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ProcessingInboundMessage

    Gets the LogEvent representing the log that is written when an inbound message is being processed.

    Declaration
    public static LogEvent ProcessingInboundMessage { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ProcessingOutboxStoredMessage

    Gets the LogEvent representing the log that is written when the message stored in the outbox is being processed.

    Declaration
    public static LogEvent ProcessingOutboxStoredMessage { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ProducerConnected

    Gets the LogEvent representing the log that is written when the producer is connected to the endpoint and ready to produce.

    Declaration
    public static LogEvent ProducerConnected { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ProducerDisconnected

    Gets the LogEvent representing the log that is written when the producer is disconnected from the endpoint.

    Declaration
    public static LogEvent ProducerDisconnected { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    ReadingMessagesFromOutbox

    Gets the LogEvent representing the log that is written when the IOutboxWorker loads a batch of enqueued messages.

    Declaration
    public static LogEvent ReadingMessagesFromOutbox { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    RetryDelayed

    Gets the LogEvent representing the log that is written when a message couldn't be processed and a delay is applied before retrying it.

    Declaration
    public static LogEvent RetryDelayed { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    RetryMessageProcessing

    Gets the LogEvent representing the log that is written when a message couldn't be processed and the retry policy is applied, processing the message again. This event occurs when the RetryErrorPolicy is applied.

    Declaration
    public static LogEvent RetryMessageProcessing { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    RollbackToRetryFailed

    Gets the LogEvent representing the log that is written when a the rollback initiated by the RetryErrorPolicy fails with an exception. This will cause the consumer to be disconnected and reconnected.

    Declaration
    public static LogEvent RollbackToRetryFailed { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    RollbackToSkipFailed

    Gets the LogEvent representing the log that is written when a the rollback initiated by the SkipMessageErrorPolicy fails with an exception. This will cause the consumer to be disconnected and reconnected.

    Declaration
    public static LogEvent RollbackToSkipFailed { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    SequenceCompleted

    Gets the LogEvent representing the log that is written when all messages belonging to the sequence have been consumed and published to the internal bus.

    Declaration
    public static LogEvent SequenceCompleted { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    SequenceProcessingAborted

    Gets the LogEvent representing the log that is written when the processing of a sequence of messages is aborted, but not because of an error (an ErrorProcessingInboundSequence is logged instead) or an incomplete sequence that gets discarded (an IncompleteSequenceAborted or an SkippingIncompleteSequence is logged instead).

    Declaration
    public static LogEvent SequenceProcessingAborted { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    SequenceStarted

    Gets the LogEvent representing the log that is written when the first message of a new sequence is consumed.

    Declaration
    public static LogEvent SequenceStarted { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    SequenceTimeoutError

    Gets the LogEvent representing the log that is written when an error occurs while executing the timeout action on an inbound sequence.

    Declaration
    public static LogEvent SequenceTimeoutError { get; }
    Property Value
    Type Description
    LogEvent
    | Improve this doc View source

    SkippingIncompleteSequence

    Gets the LogEvent representing the log that is written when an incomplete sequence is skipped because first consumed message of that sequence doesn't correspond to the actual sequence beginning (e.g. the first chunk).

    Declaration
    public static LogEvent SkippingIncompleteSequence { get; }
    Property Value
    Type Description
    LogEvent
    • Improve this doc
    • View source
    In this article
    • Properties
      • BrokerConnected
      • BrokerConnecting
      • BrokerConnectionError
      • BrokerDisconnected
      • BrokerDisconnecting
      • CallbackHandlerError
      • CannotMoveSequences
      • ConsumerCommitError
      • ConsumerConnectError
      • ConsumerConnected
      • ConsumerDisconnectError
      • ConsumerDisconnected
      • ConsumerDisposingError
      • ConsumerFatalError
      • ConsumerRollbackError
      • ConsumerStartError
      • ConsumerStopError
      • CreatingNewConsumer
      • CreatingNewProducer
      • EndpointConfiguratorError
      • ErrorInitializingActivity
      • ErrorProcessingInboundMessage
      • ErrorProcessingInboundSequence
      • ErrorProcessingOutbox
      • ErrorProducingMessage
      • ErrorProducingOutboxStoredMessage
      • ErrorReconnectingConsumer
      • IncompleteSequenceAborted
      • InvalidEndpointConfiguration
      • InvalidMessageProcessed
      • InvalidMessageProduced
      • LowLevelTracing
      • MessageAddedToSequence
      • MessageAlreadyProcessed
      • MessageMoved
      • MessageProduced
      • MessageSkipped
      • MessageWrittenToOutbox
      • NullMessageSkipped
      • OutboxEmpty
      • PolicyApplyRuleReturnedFalse
      • PolicyChainCompleted
      • PolicyExceptionExcluded
      • PolicyExceptionNotIncluded
      • PolicyMaxFailedAttemptsExceeded
      • ProcessingInboundMessage
      • ProcessingOutboxStoredMessage
      • ProducerConnected
      • ProducerDisconnected
      • ReadingMessagesFromOutbox
      • RetryDelayed
      • RetryMessageProcessing
      • RollbackToRetryFailed
      • RollbackToSkipFailed
      • SequenceCompleted
      • SequenceProcessingAborted
      • SequenceStarted
      • SequenceTimeoutError
      • SkippingIncompleteSequence
    GitHub E-Mail
    ↑ Back to top © 2020 Sergio Aquilini