Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- accept(ConsumerRecord<?, ?>, Exception) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaLoggingConsumerRecordRecoverer
- accept(ConsumerRecord<?, ?>, Exception) - Method in class com.broadleafcommerce.common.messaging.retry.kafka.KafkaBlockingRetryDeadLetterRecoverer
- accept(Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.kafka.KafkaNonBlockingRetryConsumer
- accept(Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.pubsub.PubSubDelayedRetryConsumer
- accept(ErrorMessage) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryErrorHandler
- accept(ErrorMessage) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
- ACTIVE - Enum constant in enum class com.broadleafcommerce.common.messaging.repository.LockStatus
-
Lock exists and is active.
- addConsumers(List<Consumer<RetryHandlerStatus>>) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryHandler
- addConsumers(List<Consumer<RetryHandlerStatus>>) - Method in interface com.broadleafcommerce.common.messaging.notification.RetryHandler
-
Register a list of consumers of retry handler lifecycle events.
- afterSuccessfulAcknowledgement(Object, NotificationStateAware, NotificationStateRepository) - Method in class com.broadleafcommerce.common.messaging.PersistenceMessageNotificationHandler
-
Invokes each
PersistenceMessageAckedHandler
. - afterSuccessfulAcknowledgement(Object, NotificationStateAware, NotificationStateRepository) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationHandler
-
A hook point intended to allow implementations to perform some behavior after a message has been successfully sent and the
NotificationState
has been marked as acknowledged. - afterSuccessfulAcknowledgement(Object, NotificationStateAware, NotificationStateRepository) - Method in interface com.broadleafcommerce.common.messaging.PersistenceMessageAckedHandler
-
A hook point intended to allow implementations to perform some behavior after a
PersistenceMessage
has been successfully sent and theNotificationState
has been marked as acknowledged. - attemptTakeover(String, Class<?>, String, String, Duration) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- attemptTakeover(String, Class<?>, String, String, Duration) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Attempt to take over a lock that has not reached a completed state.
- authenticationMessageOutput() - Method in interface com.broadleafcommerce.common.messaging.authentication.AuthenticationMessageProducer
- AuthenticationMessageProducer - Interface in com.broadleafcommerce.common.messaging.authentication
-
Spring cloud data channel description for messaging output.
B
- BackOffAwareRetryConsumer - Class in com.broadleafcommerce.common.messaging.retry
-
Support for all non-blocking retry consumer implementations (per-binder)
- BackOffAwareRetryConsumer(TimeoutAwareStreamBridge) - Constructor for class com.broadleafcommerce.common.messaging.retry.BackOffAwareRetryConsumer
- Binder() - Constructor for class com.broadleafcommerce.common.messaging.retry.Constants.KnownTypes.Binder
- BinderUtils - Class in com.broadleafcommerce.common.messaging.retry
-
Utility methods for working with various binder libraries
- BindingModificationAware - Interface in com.broadleafcommerce.common.messaging
-
Component that is aware of Spring Cloud Stream channel destination modifications.
- BlockingFixedRetryInfo - Class in com.broadleafcommerce.common.messaging.retry.blocking
-
Retry configuration for the blocking retry case
- BlockingFixedRetryInfo() - Constructor for class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
- BlockingFixedRetryInfo.Kafka - Class in com.broadleafcommerce.common.messaging.retry.blocking
- BlockingRetryConsumerBeanDefinitionRegistryPostProcessor - Class in com.broadleafcommerce.common.messaging.retry.blocking
-
Setup bean definitions for Spring Cloud Stream functions for blocking consumption retry based on
BlockingRetryProperties
- BlockingRetryConsumerBeanDefinitionRegistryPostProcessor() - Constructor for class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- blockingRetryConsumerMergedBeanDefinitionPostProcessor() - Static method in class com.broadleafcommerce.common.messaging.retry.autoconfigure.RetryAutoConfiguration
- BlockingRetryEnvironmentPostProcessor - Class in com.broadleafcommerce.common.messaging.retry.blocking
-
Setup environment based on
BlockingRetryProperties
- BlockingRetryEnvironmentPostProcessor() - Constructor for class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryEnvironmentPostProcessor
- BlockingRetryErrorHandler - Class in com.broadleafcommerce.common.messaging.retry.blocking
-
Error handler for the blocking retry case.
- BlockingRetryErrorHandler(String, String, BlockingRetryProperties, TimeoutAwareStreamBridge, Converter<String, String>) - Constructor for class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryErrorHandler
- BlockingRetryProperties - Class in com.broadleafcommerce.common.messaging.retry.blocking
-
Configure blocking retry.
- BlockingRetryProperties() - Constructor for class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- BlockingRetryProperties.PubSub - Class in com.broadleafcommerce.common.messaging.retry.blocking
- buildErrorHandler(String, NonBlockingFixedRetryInfo) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Establish the error handler bean definition responsible for navigating the retry lifecycle for the non-blocking case.
- buildExceptionClassifier(NonBlockingFixedRetryInfo) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
-
Build the
BinaryExceptionClassifier
instance responsible for inspecting exceptions and determining inclusion or exclusion, if applicable. - buildKafkaConsumer() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Set up the Kafka specific bean definition for the retry consumer for the non-blocking case.
- buildPubSubConsumer() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Set up the PubSub specific bean definition for the retry consumer for the non-blocking case.
- buildRetryConsumerBeanDefinition(String) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Set up the bean definition for the retry consumer for the non-blocking case.
- buildRetryHandler(NotificationStateRepository) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- buildScheduledJobCompletedEvent(ScheduledJobRef, String, boolean, String) - Static method in class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
-
Builds a
ScheduledJobCompletedEvent
to record the execution details - buildScheduledJobStartedEvent(ScheduledJobRef, String) - Static method in class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
-
Builds a
ScheduledJobStartedEvent
to record the execution details
C
- camelContextEarlySetup(Environment) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.CamelSetupAutoConfiguration
- CamelEnvironmentPostProcessor - Class in com.broadleafcommerce.common.messaging.autoconfigure
-
Configure which camel cluster service implementation is active from the default supported: file, zookeeper, and kubernetes.
- CamelEnvironmentPostProcessor() - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.CamelEnvironmentPostProcessor
- CamelSetupAutoConfiguration - Class in com.broadleafcommerce.common.messaging.autoconfigure
-
Workaround for a camel idiosyncrasy.
- CamelSetupAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.CamelSetupAutoConfiguration
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.ChannelModifierProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationHandlerResponse
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.LockState
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo.Kafka
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties.PubSub
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties.PubSub
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.Kafka
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties
- canEqual(Object) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- CHANNEL - Static variable in interface com.broadleafcommerce.common.messaging.authentication.AuthenticationMessageProducer
- CHANNEL - Static variable in interface com.broadleafcommerce.common.messaging.checkout.CheckoutCompletionProducer
- CHANNEL - Static variable in interface com.broadleafcommerce.common.messaging.service.messaging.PurgeLockTriggeredJobEventConsumer
- CHANNEL - Static variable in interface com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobCompletedEventProducer
- CHANNEL - Static variable in interface com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobStartedEventProducer
- ChannelModifierProperties - Class in com.broadleafcommerce.common.messaging.notification
-
Configuration related to channel modifier keys for sorting relevant messages.
- ChannelModifierProperties() - Constructor for class com.broadleafcommerce.common.messaging.notification.ChannelModifierProperties
- ChannelSupplier - Interface in com.broadleafcommerce.common.messaging.notification
-
General supplier representing the acquisition of a
MessageChannel
from a producer. - checkoutCompletionOutput() - Method in interface com.broadleafcommerce.common.messaging.checkout.CheckoutCompletionProducer
- CheckoutCompletionProducer - Interface in com.broadleafcommerce.common.messaging.checkout
-
Spring cloud data channel description for messaging output.
- CLUSTER_SERVICE - Enum constant in enum class com.broadleafcommerce.common.messaging.notification.RetryClusterServiceRequirementType
-
The
CamelClusterService
has issued an event denoting the targetedRetryClusterService
is the leader. - com.broadleafcommerce.common.messaging - package com.broadleafcommerce.common.messaging
- com.broadleafcommerce.common.messaging.authentication - package com.broadleafcommerce.common.messaging.authentication
- com.broadleafcommerce.common.messaging.autoconfigure - package com.broadleafcommerce.common.messaging.autoconfigure
- com.broadleafcommerce.common.messaging.autoconfigure.kafka - package com.broadleafcommerce.common.messaging.autoconfigure.kafka
- com.broadleafcommerce.common.messaging.checkout - package com.broadleafcommerce.common.messaging.checkout
- com.broadleafcommerce.common.messaging.data - package com.broadleafcommerce.common.messaging.data
- com.broadleafcommerce.common.messaging.domain - package com.broadleafcommerce.common.messaging.domain
- com.broadleafcommerce.common.messaging.environment - package com.broadleafcommerce.common.messaging.environment
- com.broadleafcommerce.common.messaging.error - package com.broadleafcommerce.common.messaging.error
- com.broadleafcommerce.common.messaging.exception - package com.broadleafcommerce.common.messaging.exception
- com.broadleafcommerce.common.messaging.notification - package com.broadleafcommerce.common.messaging.notification
- com.broadleafcommerce.common.messaging.notification.domain - package com.broadleafcommerce.common.messaging.notification.domain
- com.broadleafcommerce.common.messaging.provider.jpa.autoconfigure - package com.broadleafcommerce.common.messaging.provider.jpa.autoconfigure
- com.broadleafcommerce.common.messaging.provider.jpa.domain - package com.broadleafcommerce.common.messaging.provider.jpa.domain
- com.broadleafcommerce.common.messaging.provider.jpa.repository - package com.broadleafcommerce.common.messaging.provider.jpa.repository
- com.broadleafcommerce.common.messaging.repository - package com.broadleafcommerce.common.messaging.repository
- com.broadleafcommerce.common.messaging.repository.autoconfigure - package com.broadleafcommerce.common.messaging.repository.autoconfigure
- com.broadleafcommerce.common.messaging.retry - package com.broadleafcommerce.common.messaging.retry
- com.broadleafcommerce.common.messaging.retry.autoconfigure - package com.broadleafcommerce.common.messaging.retry.autoconfigure
- com.broadleafcommerce.common.messaging.retry.blocking - package com.broadleafcommerce.common.messaging.retry.blocking
- com.broadleafcommerce.common.messaging.retry.kafka - package com.broadleafcommerce.common.messaging.retry.kafka
- com.broadleafcommerce.common.messaging.retry.nonblocking - package com.broadleafcommerce.common.messaging.retry.nonblocking
- com.broadleafcommerce.common.messaging.retry.pubsub - package com.broadleafcommerce.common.messaging.retry.pubsub
- com.broadleafcommerce.common.messaging.service - package com.broadleafcommerce.common.messaging.service
- com.broadleafcommerce.common.messaging.service.autoconfigure - package com.broadleafcommerce.common.messaging.service.autoconfigure
- com.broadleafcommerce.common.messaging.service.messaging - package com.broadleafcommerce.common.messaging.service.messaging
- com.broadleafcommerce.common.messaging.util.scheduledjob - package com.broadleafcommerce.common.messaging.util.scheduledjob
- CommonMessagingAutoConfiguration - Class in com.broadleafcommerce.common.messaging.autoconfigure
-
Autoconfiguration entry point for the messaging library
- CommonMessagingAutoConfiguration(MessagingProperties) - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.CommonMessagingAutoConfiguration
- CommonMessagingDefaultRepositoryAutoConfiguration - Class in com.broadleafcommerce.common.messaging.repository.autoconfigure
- CommonMessagingDefaultRepositoryAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.repository.autoconfigure.CommonMessagingDefaultRepositoryAutoConfiguration
- CommonMessagingJpaAutoConfiguration - Class in com.broadleafcommerce.common.messaging.provider.jpa.autoconfigure
-
Auto configuration entry point for jpa data tracking library
- CommonMessagingJpaAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.provider.jpa.autoconfigure.CommonMessagingJpaAutoConfiguration
- CommonMessagingRepositorySupportAutoConfiguration - Class in com.broadleafcommerce.common.messaging.repository.autoconfigure
-
Beans that are common to repository implementations of data-tracking
- CommonMessagingRepositorySupportAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.repository.autoconfigure.CommonMessagingRepositorySupportAutoConfiguration
- CommonMessagingServiceAutoConfiguration - Class in com.broadleafcommerce.common.messaging.service.autoconfigure
- CommonMessagingServiceAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.service.autoconfigure.CommonMessagingServiceAutoConfiguration
- compileChangeDetails() - Element in annotation interface com.broadleafcommerce.common.messaging.notification.SuppressNotification
-
Whether or not entities managed by the ignored repository should have change details compiled at the time of edit.
- compressAndEncode(List<String>) - Static method in class com.broadleafcommerce.common.messaging.MessageUtils
- configure(AbstractMessageListenerContainer<?, ?>, String, String) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaListenerContainerCustomizer
- configureRetryableExceptions(BlockingFixedRetryInfo, DefaultErrorHandler) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaListenerContainerCustomizer
-
Configure the error handler for retryable exception behavior.
- Constants - Class in com.broadleafcommerce.common.messaging.retry
-
Constants related to messaging failure retry
- Constants() - Constructor for class com.broadleafcommerce.common.messaging.retry.Constants
- Constants.Header - Class in com.broadleafcommerce.common.messaging.retry
- Constants.KnownTypes - Class in com.broadleafcommerce.common.messaging.retry
- Constants.KnownTypes.Binder - Class in com.broadleafcommerce.common.messaging.retry
- Constants.Spring - Class in com.broadleafcommerce.common.messaging.retry
- constructErrorHandler(String) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Establish the error handler bean definition responsible for navigating the retry lifecycle for the blocking case when using Spring retry.
- constructRetryTemplate(BlockingFixedRetryInfo) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Create the bean definition informed by the Spring retry related config for the blocking case.
- consumeMessage(Message<T>, String, Consumer<Message<T>>) - Method in class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- consumeMessage(Message<T>, String, Consumer<Message<T>>) - Method in interface com.broadleafcommerce.common.messaging.service.IdempotentMessageConsumptionService
-
Executes the provided operation if the message's idempotency check passes.
- consumeMessage(Message<T>, String, Function<Message<T>, R>) - Method in class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- consumeMessage(Message<T>, String, Function<Message<T>, R>) - Method in interface com.broadleafcommerce.common.messaging.service.IdempotentMessageConsumptionService
-
Executes the provided operation if the message's idempotency check passes.
- convert(String) - Method in class com.broadleafcommerce.common.messaging.retry.StackTraceTruncator
- convertHeader(String, byte[]) - Method in class com.broadleafcommerce.common.messaging.retry.kafka.KafkaBlockingRetryDeadLetterRecoverer
-
Convert the byte array version of a header from
ConsumerRecord
to a string - create(CamelClusterService, DurableNotificationProperties, List<NotificationStateRepository>, NotificationHandler, String, List<IgnoredNotificationStateRepository>, DataRouteReference) - Static method in class com.broadleafcommerce.common.messaging.notification.RetryServiceFactory
-
Create a new
RetryClusterService
instance - create(CamelClusterService, DurableNotificationProperties, List<NotificationStateRepository>, NotificationHandler, String, List<IgnoredNotificationStateRepository>, DataRouteReference, List<Consumer<RetryHandlerStatus>>) - Static method in class com.broadleafcommerce.common.messaging.notification.RetryServiceFactory
- createBackoff(BlockingFixedRetryInfo) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaListenerContainerCustomizer
-
The
Backoff
instance to use between retries. - createLeadershipListener(Consumer<Boolean>) - Static method in class com.broadleafcommerce.common.messaging.MessageUtils
-
Create a listener with a different shape depending on the detected Spring Boot version.
- createMessage(Object) - Method in interface com.broadleafcommerce.common.messaging.notification.MessageFactory
-
Create a
Message
based on an entity instance. - createMessage(Object) - Method in class com.broadleafcommerce.common.messaging.PersistenceMessageFactory
- createMessage(Object, Map<String, Object>) - Method in interface com.broadleafcommerce.common.messaging.notification.MessageFactory
-
Create a
Message
based on an entity instance. - createMessageSafely(NotificationStateAware, NotificationState) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- createMessageSupplier(NotificationStateAware, NotificationState) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- createRecordRecoverer(String, String, BlockingFixedRetryInfo) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaListenerContainerCustomizer
-
Establish the recoverer used to handle a message after any applicable retry attempts are exhausted.
D
- decodeAndUncompress(String) - Static method in class com.broadleafcommerce.common.messaging.MessageUtils
- DEFAULT_THREAD_POOL_SIZE - Static variable in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
- DefaultIdempotentMessageConsumptionService - Class in com.broadleafcommerce.common.messaging.service
-
Service responsible for enforcing idempotency checks on a message before executing an operation against the message.
- DefaultIdempotentMessageConsumptionService(MessageLockService) - Constructor for class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- DefaultMessageLockService - Class in com.broadleafcommerce.common.messaging.service
-
Service that is responsible for managing locks for the processing of a
Message
. - DefaultMessageLockService(ResourceLockRepository<?, ?>) - Constructor for class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- DefaultNotificationHandler - Class in com.broadleafcommerce.common.messaging.notification
- DefaultNotificationHandler(ChannelSupplier, DurableNotificationProperties, String, List<IgnoredNotificationStateRepository>, MessageFactory<?>, MessageSerializationHelper) - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- DefaultNotificationHandler(ChannelSupplier, DurableNotificationProperties, String, List<IgnoredNotificationStateRepository>, MessageSerializationHelper) - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- DefaultNotificationManager - Class in com.broadleafcommerce.common.messaging.notification
- DefaultNotificationManager(List<NotificationHandler>) - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
- DefaultNotificationManager.VoidWork - Interface in com.broadleafcommerce.common.messaging.notification
-
Perform a task without response or exception notification
- DefaultNotificationStateService - Class in com.broadleafcommerce.common.messaging.notification
-
Default implementation of
NotificationStateService
. - DefaultNotificationStateService(TypeFactory) - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultNotificationStateService
- DefaultRetryClusterService - Class in com.broadleafcommerce.common.messaging.notification
- DefaultRetryClusterService(List<NotificationStateRepository>, NotificationHandler, DurableNotificationProperties, String, List<IgnoredNotificationStateRepository>, DataRouteReference) - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- DefaultRetryClusterServiceLifecycleManager - Class in com.broadleafcommerce.common.messaging.notification
-
Responsible for setting a late-phase requirement on all instances of
RetryClusterService
. - DefaultRetryClusterServiceLifecycleManager(List<RetryClusterService>) - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterServiceLifecycleManager
- DefaultRetryHandler - Class in com.broadleafcommerce.common.messaging.notification
- DefaultRetryHandler(NotificationStateRepository, NotificationHandler, DurableNotificationProperties, String, TaskScheduler, DataRouteReference) - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultRetryHandler
- DefaultSuppressNotificationAspect - Class in com.broadleafcommerce.common.messaging.notification
-
Handle establishment of
SuppressNotificationContext
whenSuppressNotification
annotation is detected. - DefaultSuppressNotificationAspect() - Constructor for class com.broadleafcommerce.common.messaging.notification.DefaultSuppressNotificationAspect
- delegate(Object[], Consumer<Boolean>) - Method in class com.broadleafcommerce.common.messaging.MessageUtils.LeadershipChangedHandler
- DELIMITER - Static variable in class com.broadleafcommerce.common.messaging.notification.IdInformation
- deserializeMessage(String) - Static method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- DetachedDurableMessageSender - Interface in com.broadleafcommerce.common.messaging.notification
-
Utility for sending a durable message without requiring an explicit
NotificationStateAware
entity in which to deposit the durable trackingNotificationState
instance for the message send. - determineBinderType(String) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Determine the implementation type of the binder associated with a consumer binding
- determineBinderType(String) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
-
Determine the implementation type of the binder associated with a consumer binding
- determineBinderType(String, ConfigurableEnvironment) - Static method in class com.broadleafcommerce.common.messaging.retry.BinderUtils
- determineBinderType(String, ConfigurableEnvironment) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryEnvironmentPostProcessor
-
Determine the implementation type of the binder associated with a consumer binding
- determineBinderType(String, ConfigurableEnvironment) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Determine the implementation type of the binder associated with a consumer binding
- DLQ() - Constructor for class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- DOES_NOT_EXIST - Enum constant in enum class com.broadleafcommerce.common.messaging.repository.LockStatus
-
Lock does not exist in the database.
- doWithLock(String, Class<?>, String, String, Supplier<V>) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- doWithLock(String, Class<?>, String, String, Supplier<V>) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- doWithLock(String, Class<?>, String, String, Supplier<V>) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
A convenience method for
ResourceLockRepository.lockResource(String, Class, String, String)
andResourceLockRepository.unlockResource(String)
to obtainin a lock, perform an operation and then unlock - doWithTemporaryLock(String, Class<?>, String, String, Supplier<V>) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- doWithTemporaryLock(String, Class<?>, String, String, Duration, Supplier<V>) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- doWithTemporaryLock(String, Class<?>, String, String, Duration, Supplier<V>) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- doWithTemporaryLock(String, Class<?>, String, String, Duration, Supplier<V>) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
A convenience method for
ResourceLockRepository.lockResource(String, Class, String, String)
andResourceLockRepository.unlockResource(String)
to obtainin a lock, perform an operation and then unlock - doWithTemporaryLock(String, Class<?>, String, String, Supplier<V>) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- doWithTemporaryLock(String, Class<?>, String, String, Supplier<V>) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
A convenience method for
ResourceLockRepository.lockResource(String, Class, String, String)
andResourceLockRepository.unlockResource(String)
to obtain a temporary lock, perform an operation and then unlock - DurableNotificationAutoConfiguration - Class in com.broadleafcommerce.common.messaging.autoconfigure
- DurableNotificationAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.DurableNotificationAutoConfiguration
- DurableNotificationProperties - Interface in com.broadleafcommerce.common.messaging.notification
-
Properties that control behavior of the combination of a
NotificationHandler
and aRetryHandler
.
E
- ENABLED_PROP - Static variable in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- ENABLED_PROP - Static variable in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- EntityAwareNotificationState - Interface in com.broadleafcommerce.common.messaging.notification.domain
- EntityUtils - Class in com.broadleafcommerce.common.messaging
-
Dynamically perform operations related to repository domain classes.
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.ChannelModifierProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationHandlerResponse
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.LockState
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo.Kafka
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties.PubSub
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties.PubSub
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.Kafka
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties
- equals(Object) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- ErrorMessagingAutoConfiguration - Class in com.broadleafcommerce.common.messaging.error
-
Autoconfiguration for common messaging error handling.
- ErrorMessagingAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.error.ErrorMessagingAutoConfiguration
- ErrorMessagingAutoConfiguration.LoggingGlobalErrorConfiguration - Class in com.broadleafcommerce.common.messaging.error
-
A configuration that logs global error messages to standard output.
- exec() - Method in interface com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager.VoidWork
- exec(ThrowingSupplier<V, T>, boolean, String...) - Static method in class com.broadleafcommerce.common.messaging.notification.SuppressNotificationContext
- exec(ThrowingSupplier<V, T>, String...) - Static method in class com.broadleafcommerce.common.messaging.notification.SuppressNotificationContext
- execute() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryHandler
- execute() - Method in interface com.broadleafcommerce.common.messaging.notification.RetryHandler
-
Perform the retry processing logic
- EXECUTED - Enum constant in enum class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatusType
- executeJobWithTrackingExecutionDetails(ScheduledJobRef, Consumer<Message<?>>, Consumer<Message<?>>, Consumer<ScheduledJobRef>) - Static method in class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
-
Executes the scheduled job using the given
scheduledJobExecutor
with the ability to track its execution details by sending theScheduledJobStartedEvent
andScheduledJobCompletedEvent
. - executePostTransactionCommitOrNow(DefaultNotificationManager.VoidWork) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
-
Do a unit of work upon successful completion of the current transaction, or, execute the work immediately if transaction synchronization is not currently active.
F
- FailedTakeoverException - Exception in com.broadleafcommerce.common.messaging.exception
-
Indicates a takeover attempt failed.
- FailedTakeoverException() - Constructor for exception com.broadleafcommerce.common.messaging.exception.FailedTakeoverException
- findId(Object) - Static method in class com.broadleafcommerce.common.messaging.EntityUtils
- findIdField(Class<?>) - Static method in class com.broadleafcommerce.common.messaging.EntityUtils
-
Find the field marked with the Spring or JPA @Id annotation in the entity class.
- findMessageSupportingRoutes() - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
-
Identifies all data routes that support messaging domain
- findNotificationReadyMembers(Object, int, String, Duration, Class<?>) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationStateRepository
-
Find any entity instances that are unacknowledged and qualified for retry for message sending.
- findNotificationState(String) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationStateAware
-
Looks up a NotificationState from the states within this collection
- finishLock(String) - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- finishLock(String) - Method in interface com.broadleafcommerce.common.messaging.service.MessageLockService
-
Update the status of the lock to indicate the associated process is complete.
- FixedRetryInfo - Class in com.broadleafcommerce.common.messaging.retry
-
Retry configuration.
- FixedRetryInfo() - Constructor for class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
- formatOriginalMessageHeaders(Message<?>) - Method in class com.broadleafcommerce.common.messaging.error.LoggingGlobalErrorChannelListener
-
Converts the message headers from the original message into a display friendly string.
- formatOriginalMessagePayload(Message<?>) - Method in class com.broadleafcommerce.common.messaging.error.LoggingGlobalErrorChannelListener
-
Formats the original message's payload into a display friendly string.
G
- get() - Method in interface com.broadleafcommerce.common.messaging.notification.ChannelSupplier
- get() - Method in interface com.broadleafcommerce.common.messaging.notification.MessageSupplier
- get() - Static method in class com.broadleafcommerce.common.messaging.notification.SuppressNotificationContext
- get_baseClass() - Method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- get_class() - Method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- get_id() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
- getAdditionalHeaders() - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- getAdditionalLockTypesToPurge(ScheduledJobRef) - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- getAdditionalParameters() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
Additional information that can be used to add parameters for the scheduled job listeners.
- getAssignableTo() - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
-
Class, interface or superclass that the target repository can be assigned to
- getAttempts() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The number of times the system has attempted sending a message for this state change.
- getAttributes() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
A map to hold additional information on the event about the execution detail
- getAttributes() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
A map to hold additional information on the execution detail
- getAttributes() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
A map to hold additional information on the event about the execution detail
- getAttributes() - Method in interface com.broadleafcommerce.common.messaging.notification.MessageAdditionalInformationAware
-
The attributes to leverage during message construction at
MessageFactory.createMessage(Object, Map)
- getBackOff() - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
The backOff timeframe to wait before retrying a message.
- getBackOffCheckInterval() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
-
The amount of time to wait between polling attempts when consuming the retry bindings defined in
NonBlockingRetryProperties.getBindings()
. - getBeanFactory() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- getBindings() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
-
The retry configurations associated by the original consumer bindings
- getBindings() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
-
The ordered list of retry configurations associated by the original consumer binding
- getChangeTimestamp() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Retrieve the last time this entity was updated in a way that requires notification via a message bus.
- getChangeTimestampAck() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Retrieve the last time a message was sent for a state change to the message bus.
- getChannelModifier() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- getChannelModifier() - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationHandler
-
Retrieve any modifier for the channel associated with this handler.
- getClassifier() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- getClusterK8sAppLabel() - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
If using
kubernetes
cluster service implementation type, this is the name of the pod label used to group common service instances. - getClusterK8sAppLabelValue() - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
If using
kubernetes
cluster service implementation type, this is the value for the pod label. - getClusterServiceImplementationType() - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
Specify which camel cluster service implementation to support.
- getClustServiceImplementation() - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
Deprecated.
- getConceptKey() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
A generally descriptive key that identifies the overall concept for which the lock is taking place.
- getConceptKeyOrDefault(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- getConsumerBinding() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
-
The consumer binding from which to poll for candidate retryable messages.
- getContextId() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The contextId of the Trackable resource to lock
- getCurrentStatus() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.LockState
- getDefaultStagnationThreshold() - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
-
The time, once elapsed, in which the system will consider a lock abandoned and allow another requester to acquire the lock.
- getDefaultStagnationThreshold() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- getDelayAtStartup() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The amount of time after initialization of the application that must pass before the retry scheduler starts.
- getDetails() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- getDlq() - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
Optional.
- getDlq() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- getEndTime() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The time at which the scheduled job finished its execution
- getEntity() - Method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- getEntityType() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.EntityAwareNotificationState
- getEnvironment() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- getError() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The message to be set on the scheduled job execution detail in case an error occurs.
- getExclude() - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
Optional.
- getExecutionId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The Context ID of the scheduled job execution detail
- getExpirationTimestamp() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The time at which the lock will naturally expire
- getFailureRateThreshold() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the failure rate threshold in percentage above which the CircuitBreaker should trip open and start short-circuiting calls.
- getFileLockRootPath() - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
Deprecated.Not required. Use
MessagingProperties.clusterServiceImplementationType
support instead. If using FileLockClusterService, the root path to store the lock files - getHandlersInScope(Object) - Method in class com.broadleafcommerce.common.messaging.PersistenceMessageNotificationHandler
- getId() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The persisted representation of a
NotificationState
typically has its own globally unique identifier. - getId() - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- getId() - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- getIdempotentConsumptionService() - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- getInclude() - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
Optional.
- getIncludeListenerNames() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- getInitialFaultThreshold() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The amount of time that must elapse before the retry mechanism can kick in on a newly altered and unacknowledged record.
- getJobExecutionDetailId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The Context ID of the scheduled job execution detail
- getJobExecutionDetailId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The Context ID of the scheduled job execution detail
- getJobId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The Context ID of the scheduled job for which this completion event is emitted
- getJobId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
The Context ID of the scheduled job
- getJobId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The Context ID of the scheduled job for which this completion event is emitted
- getJobType() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The type of the job for which this completion event is emitted
- getJobType() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The type of the job for which the completion event is emitted
- getKafka() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
- getKafka() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- getLastExecuted() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
The date on which the job last executed.
- getLastExecutionDetail() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
A reference to the latest scheduled job execution detail of the current scheduled job
- getLastUpdatedTime() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The time at which the scheduled job is last updated
- getLifecycleRequirementsMet() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- getLifecycleRequirementsMet() - Method in interface com.broadleafcommerce.common.messaging.notification.RetryClusterService
-
Retrieve the list of lifecycle requirements that have been met.
- getLock(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- getLock(String, Class<?>, String, String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- getLocked() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
Whether or not the resource is locked
- getLockPurgePageSize() - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
- getLockTypesToPurge(String) - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- getMaxAckExtensionPeriod() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties.PubSub
- getMaxAckExtensionPeriod() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties.PubSub
- getMaxAttempts() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The maximum number of failed attempts that should be made before ceasing to attempt to send a message for an unacknowledged record.
- getMaxAttempts() - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
The maximum number of retry attempts.
- getMaxAttemptWaitTime() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The maximum amount of time that should elapse before making another attempt on an unacknowledged record.
- getMaxTraceLineCount() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- getMessage() - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- getMessageLockService() - Method in class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- getMessageLockService() - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- getMessageType() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The fully qualified
Type
for the message information - getMessageType() - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
-
The type of message the repository should be ignored for.
- getMessageType() - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
-
The unique identifier for the type of message being handled
- getMessageTypes() - Method in class com.broadleafcommerce.common.messaging.notification.SuppressNotificationContext
- getMessageValue() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
If message serialization is used, this is the JSON string version of the message information
- getMessageValue() - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- getModifier() - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- getName() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
-
The name of this detail.
- getName() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The name identifying this particular message state.
- getNamespaceModByBindingProperty() - Method in interface com.broadleafcommerce.common.messaging.BindingModificationAware
-
A map keyed by the original, fully-qualified property binding (before modification) whose value is the modification string.
- getNextAttempt() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The time at which (or beyond which) another retry attempt should be made
- getNote() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
A note/message to be set on the scheduled job execution detail.
- getNote() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The execution note/message to be set on the execution detail.
- getNote() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
A note/message to be set on the scheduled job execution detail.
- getNotification() - Method in interface com.broadleafcommerce.common.messaging.notification.DurableNotificationProperties
-
Configuration for the
NotificationHandler
- getNotification() - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- getNotificationStates() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationStateAware
-
Retrieve the message sending status for one or more
NotificationState
instances. - getNotificationStates(boolean) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationStateAware
-
Retrieve the message sending status for one or more
NotificationState
instances. - getObjectMapper() - Method in interface com.broadleafcommerce.common.messaging.PersistenceHandler
-
Return the
ObjectMapper
to use when handling the message json. - getObjectRepresentation(String, Class<T>) - Method in class com.broadleafcommerce.common.messaging.notification.MessageSerializationHelper
-
Get an object version of some JSON.
- getObjectRepresentation(String, String) - Method in class com.broadleafcommerce.common.messaging.notification.MessageSerializationHelper
-
Get an object version of some JSON using a string-based class name.
- getOptional() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
Optional information related to the lock.
- getOptionalOrDefault(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- getOrder() - Method in class com.broadleafcommerce.common.messaging.error.ErrorMessagingAutoConfiguration.LoggingGlobalErrorConfiguration
- getOrder() - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationHandler
- getOrder() - Method in interface com.broadleafcommerce.common.messaging.PersistenceMessageAckedHandler
- getOrder() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- getOrder() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- getOriginalProducerBinding() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
-
The producer binding used to send the message back to the original channel to re-attempt processing.
- getOrInitializeNotificationState(NotificationStateAware, String) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationStateService
- getOrInitializeNotificationState(NotificationStateAware, String) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationStateService
-
Search the
NotificationState
on theNotificationStateAware
by its name. - getPageSize() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The number of valid, unacknowledged records to batch process per interval.
- getPersistenceMessageAckedHandlers() - Method in class com.broadleafcommerce.common.messaging.PersistenceMessageNotificationHandler
- getPhase() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- getPhase() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterServiceLifecycleManager
- getPollTimeout() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.Kafka
-
The amount of time in milliseconds the kafka consumer will block waiting for poll max records to be returned.
- getProducerBinding() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
-
The producer binding used to send a message to park in the retry queue defined here.
- getProducerBinding() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- getPubSub() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- getPubSub() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- getRecordProcessingWait() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The amount of time to pause between the processing of each unacknowledged record in the batch.
- getReference() - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- getRepository() - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
-
The repository associated with the durable notification state for the message
- getResourceLockRepository() - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- getRetry() - Method in interface com.broadleafcommerce.common.messaging.notification.DurableNotificationProperties
-
Configuration for the
RetryHandler
- getRetry() - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- getRetryClusterServiceNamespace() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
Name used to identify the cluster singleton lock
- getRetryInterval() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The length of time to wait between each batch retry attempt.
- getRingBufferSizeInClosedState() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the size of the ring buffer when the CircuitBreaker is closed.
- getRingBufferSizeInHalfOpenState() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the size of the ring buffer when the CircuitBreaker is half open.
- getRoot(Exception) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryErrorHandler
-
Retrieve the relevant root exception for reporting as a header on the message
- getRoot(Exception) - Method in class com.broadleafcommerce.common.messaging.retry.kafka.KafkaBlockingRetryDeadLetterRecoverer
-
Retrieve the relevant root exception for reporting as a header on the message
- getRoot(Exception) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
-
Retrieve the relevant root exception for reporting as a header on the message
- getSendTimeout() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
The length of time a message send attempt should block before timing out.
- getSerializedRepresentation(Object) - Method in class com.broadleafcommerce.common.messaging.notification.MessageSerializationHelper
-
The message information to convert to JSON string.
- getSource() - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
-
The handler responsible for the activity
- getStackTraceFiltersRegex() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- getStagnationThresholds() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- getStartTime() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The time at which the scheduled job started its execution
- getStatus() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The execution status of the scheduled job
- getStatus() - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
-
The lifecycle event type being reported
- getSuffix() - Method in class com.broadleafcommerce.common.messaging.notification.ChannelModifierProperties
-
If no modifier is provided via MicroCloudStreamBindingCommon configuration, then apply this suffix value as a modifier key during all attempts to match relevant notification state messages.
- getSupportedSimpleTypeNames() - Method in interface com.broadleafcommerce.common.messaging.PersistenceHandler
-
The simple entity type names supported by this service.
- getTakeover() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties
- getTenantId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The ID of the associated tenant
- getTenantId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
The ID of the associated tenant.
- getTenantId() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The ID of the associated tenant
- getThreadPoolSize() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
-
The thread pool size used for async handling.
- getTimestamp() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The time at which the lock was set to true
- getToken() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The token assigned the last time the lock was set to true.
- getToken() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.LockState
- getToken() - Method in interface com.broadleafcommerce.common.messaging.Securable
-
A Base64 encoded JWT token generally containing the following claims: user - the user name for the user that generated the message via some action.
- getType() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- getTypeAlias() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
An alias used to represent the Java type of the resource being locked.
- getValue() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
-
A value for this detail.
- getWaitDurationInOpenState() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the wait duration which specifies how long the CircuitBreaker should stay open, before it switches to half open.
- getWaitTimeExp(int) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
-
Provide an exponential backoff wait period based on the number of attempts
- GlobalErrorChannelListener - Interface in com.broadleafcommerce.common.messaging.error
-
This is a marker interface for a listener that listens to the global error channel.
H
- handle(NotificationStateRepository, NotificationStateAware, String) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- handle(NotificationStateRepository, NotificationStateAware, String) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
- handle(NotificationStateRepository, NotificationStateAware, String) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationHandler
-
Notify the system in some way about the state change for the notifiable param.
- handle(NotificationStateRepository, NotificationStateAware, String) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationManager
-
Notify the system in some way about the state change for the notifiable param.
- handle(String) - Method in interface com.broadleafcommerce.common.messaging.PersistenceHandler
-
Entry point for the handler.
- handleAsync(NotificationStateRepository, NotificationStateAware, String) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
- handleAsync(NotificationStateRepository, NotificationStateAware, String) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationManager
-
Notify the system in some way about the state change for the notifiable param.
- handleAsync(NotificationStateRepository, NotificationStateAware, String, Runnable) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
- handleAsync(NotificationStateRepository, NotificationStateAware, String, Runnable) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationManager
-
Notify the system in some way about the state change for the notifiable param.
- handleMessageInternal(Message<?>) - Method in class com.broadleafcommerce.common.messaging.error.LoggingGlobalErrorChannelListener
- handleMessageInternal(Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
-
Handle message failure.
- hashCode() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
- hashCode() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
- hashCode() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
- hashCode() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- hashCode() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
- hashCode() - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.ChannelModifierProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationHandlerResponse
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
- hashCode() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- hashCode() - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
- hashCode() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.LockState
- hashCode() - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo.Kafka
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties.PubSub
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties.PubSub
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.Kafka
- hashCode() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties
- hashCode() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- Header() - Constructor for class com.broadleafcommerce.common.messaging.retry.Constants.Header
- hook(String) - Method in interface com.broadleafcommerce.common.messaging.PersistenceHandler
-
Hook point for message listeners to bind to the input channel with
@StreamListener
.
I
- IdempotentMessage - Class in com.broadleafcommerce.common.messaging.notification
- IdempotentMessage() - Constructor for class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- IdempotentMessage(String, Map<String, String>, Object) - Constructor for class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- idempotentMessageConsumptionService(MessageLockService) - Method in class com.broadleafcommerce.common.messaging.service.autoconfigure.CommonMessagingServiceAutoConfiguration
- IdempotentMessageConsumptionService - Interface in com.broadleafcommerce.common.messaging.service
-
Service responsible for enforcing idempotency checks on a message before executing an operation against the message.
- identifyLastRetryPhase(List<NonBlockingFixedRetryInfo>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
-
Identify the last retry config in the list of retry configs
- identifyLocksToBePurged(Class<?>, Duration, String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
-
Deprecated, for removal: This API element is subject to removal in a future version.
- identifyLocksToBePurged(Set<String>, Duration, String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
-
Identifies locks that are eligible to be purged
- identifyRetryPhase(List<NonBlockingFixedRetryInfo>, MessagingException, AtomicInteger) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
-
Based on the count, identify the current retry config that should be considered
- IdInformation - Class in com.broadleafcommerce.common.messaging.notification
-
For
NotificationState
handling (especiallyNotificationStateRepository.setFailedNotificationAttempt(Object, String, int, Instant, Class, boolean)
), support a robust identification structure that includes optional modifiers for the message value. - IdInformation(Object, String, String) - Constructor for class com.broadleafcommerce.common.messaging.notification.IdInformation
- IgnoredNotificationStateRepository - Class in com.broadleafcommerce.common.messaging.notification
-
Identify a repository that should not be included in the operation of
NotificationHandler
andRetryHandler
. - IgnoredNotificationStateRepository(Class<?>) - Constructor for class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
- IgnoredNotificationStateRepository(Class<?>, String) - Constructor for class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
- INACTIVE - Enum constant in enum class com.broadleafcommerce.common.messaging.repository.LockStatus
-
Lock record exists, but is inactive.
- init() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
- InternalPersistenceEvent - Class in com.broadleafcommerce.common.messaging.notification.domain
-
Spring level event (local to the current JVM) that is fired upon
Trackable
entity persistence. - InternalPersistenceEvent(NotificationStateAware) - Constructor for class com.broadleafcommerce.common.messaging.notification.domain.InternalPersistenceEvent
- isAcked() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Whether or not this state has been acknowledged as successfully being sent to the message broker
- isAsyncEnabled() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
-
Whether calls to
NotificationManager.handleAsync(NotificationStateRepository, NotificationStateAware, String)
will actually use async threading. - isAutoStartup() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- isBackOffSatisfied(Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.BackOffAwareRetryConsumer
-
Inspect the message and detect if the backoff period has expired via the
Constants.Header.NEXT_ATTEMPT_TIMESTAMP_HEADER
header. - isCompileChangeDetails() - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
-
Whether or not entities managed by the ignored repository should have change details compiled at the time of edit.
- isCompileChangeDetails() - Method in class com.broadleafcommerce.common.messaging.notification.SuppressNotificationContext
- isDeveloperMode() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
Deprecated.Development state is now handled through the
broadleaf.messaging.cluster-service-implementation-type
property. The default for that property isfile
, which is appropriate for local development. - isEnabled() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
-
Whether the blocking retry feature is enabled
- isEnabled() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
-
Whether the non-blocking retry feature is enabled
- isEnabled() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- isHandled() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationHandlerResponse
-
Whether or not the handler was qualified and processed the handle request
- isHasRestrictions() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- isLeader(Object) - Static method in class com.broadleafcommerce.common.messaging.MessageUtils
-
Determines whether the
CamelClusterMember
representation is the current cluster leader. - isRunning() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- isRunning() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterServiceLifecycleManager
- isSeekToCurrentRecordOnFailure() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo.Kafka
-
Optional.
- isSendEnabled() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Whether or not sending on the producer channel is allowed.
- isStarted() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- isStarted() - Method in interface com.broadleafcommerce.common.messaging.notification.RetryClusterService
-
Whether the cluster service is already started.
- isStop() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationHandlerResponse
-
Whether or not other handlers should be allowed to process as well, or if handling should stop now
- isStopped() - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Whether or not retry attempts should cease for this state
- isSuccess() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
A flag indicating whether the scheduled job finished successfully
- isTrackExecutionDetails() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
A flag to indicate whether the execution details of this scheduled-job should be tracked
- isUseDefaults() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
-
If the default values are all satisfactory, the retry configuration can simply set this property to true, which will establish a
BlockingRetryInfo
associated with the targeted binding inBlockingRetryProperties.getBindings()
. - isValidType(String, String) - Method in interface com.broadleafcommerce.common.messaging.PersistenceHandler
-
Determine if the type (i.e.
J
- JpaCustomizedResourceLockRepository - Class in com.broadleafcommerce.common.messaging.provider.jpa.repository
-
Specialized implementation of
JpaResourceLockRepository
. - JpaCustomizedResourceLockRepository(TransactionTemplate, ResourceLockProperties) - Constructor for class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- JpaResourceLock - Class in com.broadleafcommerce.common.messaging.provider.jpa.domain
-
Represents a single lock on a resource held in the current datastore.
- JpaResourceLock() - Constructor for class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
- JpaResourceLockRepository - Interface in com.broadleafcommerce.common.messaging.provider.jpa.repository
- jpaResourceLockRepositoryImpl(PlatformTransactionManager, ResourceLockProperties) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.autoconfigure.CommonMessagingJpaAutoConfiguration
K
- Kafka() - Constructor for class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo.Kafka
- Kafka() - Constructor for class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.Kafka
- KAFKA - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.KnownTypes.Binder
- KafkaBlockingRetryDeadLetterRecoverer - Class in com.broadleafcommerce.common.messaging.retry.kafka
-
Recoverer for blocking retry that will forward the message to a dead letter queue.
- KafkaBlockingRetryDeadLetterRecoverer(TimeoutAwareStreamBridge, String, String, String, Converter<String, String>) - Constructor for class com.broadleafcommerce.common.messaging.retry.kafka.KafkaBlockingRetryDeadLetterRecoverer
- KafkaCommonMessagingAutoConfiguration - Class in com.broadleafcommerce.common.messaging.autoconfigure.kafka
-
Kafka specific messaging configuration.
- KafkaCommonMessagingAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaCommonMessagingAutoConfiguration
- KafkaCommonMessagingAutoConfiguration.SpringKafkaRetryConfiguration - Class in com.broadleafcommerce.common.messaging.autoconfigure.kafka
-
Configuration that disables Spring Kafka retries.
- KafkaListenerContainerCustomizer - Class in com.broadleafcommerce.common.messaging.autoconfigure.kafka
-
Configures the kafka container for retry when
BlockingRetryProperties.isEnabled()
is true. - KafkaListenerContainerCustomizer(TimeoutAwareStreamBridge, ConsumerRecordRecoverer, Environment, BlockingRetryProperties, CommonErrorHandler, Converter<String, String>, StandardRetryProperties) - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaListenerContainerCustomizer
- KafkaLoggingConsumerRecordRecoverer - Class in com.broadleafcommerce.common.messaging.autoconfigure.kafka
-
Simple logging recoverer
- KafkaLoggingConsumerRecordRecoverer() - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaLoggingConsumerRecordRecoverer
- KafkaNonBlockingRetryConsumer - Class in com.broadleafcommerce.common.messaging.retry.kafka
-
Message consumer for a retry binding in the non-blocking case.
- KafkaNonBlockingRetryConsumer(TimeoutAwareStreamBridge, NonBlockingRetryProperties) - Constructor for class com.broadleafcommerce.common.messaging.retry.kafka.KafkaNonBlockingRetryConsumer
- KnownTypes() - Constructor for class com.broadleafcommerce.common.messaging.retry.Constants.KnownTypes
L
- LATE_PHASE_SPRING - Enum constant in enum class com.broadleafcommerce.common.messaging.notification.RetryClusterServiceRequirementType
-
Spring lifecycle has reached a late phase in startup.
- LeadershipChangedHandler() - Constructor for class com.broadleafcommerce.common.messaging.MessageUtils.LeadershipChangedHandler
- leadershipConstructor - Static variable in class com.broadleafcommerce.common.messaging.MessageUtils
- listen(Message<ScheduledJobRef>) - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- LOCK_INSERT - Static variable in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- LOCK_UPDATE - Static variable in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- lockResource(String, Class<?>, String, String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- lockResource(String, Class<?>, String, String) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- lockResource(String, Class<?>, String, String) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Lock a resource indefinitely based on identifying information.
- lockResourceTemporarily(String, Class<?>, String, String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- lockResourceTemporarily(String, Class<?>, String, String, Duration) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- lockResourceTemporarily(String, Class<?>, String, String) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- lockResourceTemporarily(String, Class<?>, String, String) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Lock a resource temporarily based on identifying information.
- lockResourceTemporarily(String, Class<?>, String, String, Duration) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- lockResourceTemporarily(String, Class<?>, String, String, Duration) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Lock a resource temporarily based on identifying information.
- LockState - Class in com.broadleafcommerce.common.messaging.provider.jpa.repository
-
If a takeover is successful, this state reports the new token for the lock, as well as the last status reported by the previous lock owner.
- LockState(String, String) - Constructor for class com.broadleafcommerce.common.messaging.provider.jpa.repository.LockState
- LockStatus - Enum Class in com.broadleafcommerce.common.messaging.repository
-
Report on the status of a lock.
- log - Static variable in interface com.broadleafcommerce.common.messaging.PersistenceHandler
- logErrorMessage(ErrorMessage) - Method in class com.broadleafcommerce.common.messaging.error.LoggingGlobalErrorChannelListener
-
Logs the given error message.
- LoggingGlobalErrorChannelListener - Class in com.broadleafcommerce.common.messaging.error
-
A global error channel listener that logs the errored messages.
- LoggingGlobalErrorChannelListener() - Constructor for class com.broadleafcommerce.common.messaging.error.LoggingGlobalErrorChannelListener
- LoggingGlobalErrorConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.error.ErrorMessagingAutoConfiguration.LoggingGlobalErrorConfiguration
M
- MESSAGE_CONSUMER_BINDING - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Header
- MESSAGE_FAILURE_MESSAGE - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Header
- MESSAGE_FAILURE_TRACE - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Header
- MESSAGE_IDEMPOTENCY_KEY - Static variable in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- MESSAGE_LOCK_COMPLETION_STATE - Static variable in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- MESSAGE_LOCK_TTL_IN_SEC - Static variable in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- MESSAGE_LOCK_TYPES - Static variable in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- MESSAGE_VALUE_KEY - Static variable in class com.broadleafcommerce.common.messaging.notification.IdInformation
- MessageAdditionalInformationAware - Interface in com.broadleafcommerce.common.messaging.notification
-
An entity can be wrapped with this interface before passing to
DefaultNotificationHandler
for processing. - MessageFactory<T> - Interface in com.broadleafcommerce.common.messaging.notification
-
Factory for creating a
Message
to be sent viaNotificationHandler
, based on an entity. - MessageLockProperties - Class in com.broadleafcommerce.common.messaging.service
-
Properties related to configuration of message lock behavior
- MessageLockProperties() - Constructor for class com.broadleafcommerce.common.messaging.service.MessageLockProperties
- MessageLockProperties.Takeover - Class in com.broadleafcommerce.common.messaging.service
-
Properties related to message lock takeover behavior
- messageLockService - Variable in class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- messageLockService - Variable in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- messageLockService(ResourceLockRepository<?, ?>) - Method in class com.broadleafcommerce.common.messaging.service.autoconfigure.CommonMessagingServiceAutoConfiguration
- MessageLockService - Interface in com.broadleafcommerce.common.messaging.service
-
Service that is responsible for managing locks for the processing of a
Message
. - messageSerializationHelper(ObjectMapper) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.CommonMessagingAutoConfiguration
- MessageSerializationHelper - Class in com.broadleafcommerce.common.messaging.notification
-
Helper class for managing serialized state of message information.
- MessageSerializationHelper(ObjectMapper) - Constructor for class com.broadleafcommerce.common.messaging.notification.MessageSerializationHelper
- MessageSupplier<T> - Interface in com.broadleafcommerce.common.messaging.notification
- MessageUtils - Class in com.broadleafcommerce.common.messaging
-
Utility methods useful for creating and working with messages, such as compression and decompression of large payloads.
- MessageUtils.LeadershipChangedHandler - Class in com.broadleafcommerce.common.messaging
- MessagingDataRouteSupporting - Interface in com.broadleafcommerce.common.messaging.data
- MessagingProperties - Class in com.broadleafcommerce.common.messaging.environment
- MessagingProperties() - Constructor for class com.broadleafcommerce.common.messaging.environment.MessagingProperties
- MODIFIER_KEY - Static variable in class com.broadleafcommerce.common.messaging.notification.IdInformation
- MutableDurableNotificationProperties - Interface in com.broadleafcommerce.common.messaging.notification
-
Represents
DurableNotificationProperties
whosenotification
andretry
fields may be reset to new objects.
N
- NEXT_ATTEMPT_TIMESTAMP_HEADER - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Header
- NonBlockingFixedRetryInfo - Class in com.broadleafcommerce.common.messaging.retry.nonblocking
-
Retry configuration for the non-blocking case
- NonBlockingFixedRetryInfo() - Constructor for class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
- NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor - Class in com.broadleafcommerce.common.messaging.retry.nonblocking
-
Setup bean definitions for Spring Cloud Stream functions for non-blocking consumption retry
- NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor() - Constructor for class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- nonBlockingRetryConsumerMergedBeanDefinitionPostProcessor() - Static method in class com.broadleafcommerce.common.messaging.retry.autoconfigure.RetryAutoConfiguration
- NonBlockingRetryEnvironmentPostProcessor - Class in com.broadleafcommerce.common.messaging.retry.nonblocking
-
Setup environment based on
NonBlockingRetryProperties
- NonBlockingRetryEnvironmentPostProcessor() - Constructor for class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
- NonBlockingRetryErrorHandler - Class in com.broadleafcommerce.common.messaging.retry.nonblocking
-
For the non-blocking retry case.
- NonBlockingRetryErrorHandler(String, String, String, NonBlockingRetryProperties, TimeoutAwareStreamBridge, Converter<String, String>) - Constructor for class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
- NonBlockingRetryErrorHandler.RetryClassifier - Class in com.broadleafcommerce.common.messaging.retry.nonblocking
- NonBlockingRetryProperties - Class in com.broadleafcommerce.common.messaging.retry.nonblocking
-
Configuration for non-blocking retries for Spring Cloud Stream message processing.
- NonBlockingRetryProperties() - Constructor for class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- NonBlockingRetryProperties.PubSub - Class in com.broadleafcommerce.common.messaging.retry.nonblocking
- NoOpResourceLockRepository - Class in com.broadleafcommerce.common.messaging.repository
-
Simple
ResourceLockRepository
implementation that DOES NOTHING. - NoOpResourceLockRepository() - Constructor for class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- NotificationHandler - Interface in com.broadleafcommerce.common.messaging.notification
-
Notify the system about a state change for a
NotificationStateAware
entity. - NotificationHandlerResponse - Class in com.broadleafcommerce.common.messaging.notification
-
Response information from a
NotificationHandler.handle(NotificationStateRepository, NotificationStateAware, MessageType)
call. - NotificationHandlerResponse(boolean, boolean) - Constructor for class com.broadleafcommerce.common.messaging.notification.NotificationHandlerResponse
- notificationManager(List<NotificationHandler>) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.DurableNotificationAutoConfiguration
- NotificationManager - Interface in com.broadleafcommerce.common.messaging.notification
-
Management component for processing a state change on an object through one or more ordered
NotificationHandler
instances. - NotificationManagerProperties - Class in com.broadleafcommerce.common.messaging.notification
-
Configuration for instances of
NotificationManager
- NotificationManagerProperties() - Constructor for class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
- NotificationProperties - Class in com.broadleafcommerce.common.messaging.notification
-
Configuration for a
NotificationHandler
- NotificationProperties() - Constructor for class com.broadleafcommerce.common.messaging.notification.NotificationProperties
- NotificationState - Interface in com.broadleafcommerce.common.messaging.notification.domain
-
Keep track of message bus notification of state change of a
NotificationStateAware
entity. - NotificationStateAware - Interface in com.broadleafcommerce.common.messaging.notification.domain
-
A domain that keeps track of
NotificationState
- NotificationStateRepository - Interface in com.broadleafcommerce.common.messaging.notification
-
Additional interface for repository instances that are capable of interacting with
NotificationState
related information onNotificationStateAware
domain. - NotificationStateRepositoryFragment - Interface in com.broadleafcommerce.common.messaging.notification
-
Marker interface used to differentiate between a full repository implementing
NotificationStateRepository
and a internal repository fragment component providing the actual implementation. - notificationStateService(TypeFactory) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.CommonMessagingAutoConfiguration
- NotificationStateService - Interface in com.broadleafcommerce.common.messaging.notification
-
Used to retrieve the
NotificationState
from theNotificationStateAware
. - notify(NotificationStateAware, NotificationState, NotificationStateRepository) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
-
Validate the state requires notification, and if so, send the notification.
O
- obtainLock(Message<?>, String) - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- obtainLock(Message<?>, String) - Method in interface com.broadleafcommerce.common.messaging.service.MessageLockService
- of(T) - Static method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- ORIGINAL_PRODUCER_BINDING_HEADER - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Header
P
- PACKAGE_FRAGMENT - Static variable in interface com.broadleafcommerce.common.messaging.data.MessagingDataRouteSupporting
- PersistenceHandler - Interface in com.broadleafcommerce.common.messaging
-
PersistenceHandlers are responsible for listening for
PersistenceConsumer
channel events associated with a specific repository domain type. - PersistenceMessage<T> - Class in com.broadleafcommerce.common.messaging
-
Formats the message in a way that the
PersistenceConsumer
expects to receive the payload in - PersistenceMessage(T) - Constructor for class com.broadleafcommerce.common.messaging.PersistenceMessage
- PersistenceMessageAckedHandler - Interface in com.broadleafcommerce.common.messaging
-
Every component implementing this interface is injected and invoked by
PersistenceMessageNotificationHandler.afterSuccessfulAcknowledgement(Object, NotificationStateAware, NotificationStateRepository)
following successful acknowledgement of aNotificationState
for aPersistenceMessage
. - persistenceMessageFactory() - Method in class com.broadleafcommerce.common.messaging.autoconfigure.PersistenceNotificationAutoConfiguration
- PersistenceMessageFactory - Class in com.broadleafcommerce.common.messaging
-
MessageFactory
for creating messages suitable for thePersistenceProducer
channel - PersistenceMessageFactory() - Constructor for class com.broadleafcommerce.common.messaging.PersistenceMessageFactory
- PersistenceMessageNotificationHandler - Class in com.broadleafcommerce.common.messaging
-
The
NotificationHandler
implementation specifically for sendingPersistenceMessage
viaPersistenceProducer
. - PersistenceMessageNotificationHandler(ChannelSupplier, DurableNotificationProperties, List<IgnoredNotificationStateRepository>, MessageFactory<?>, MessageSerializationHelper, List<PersistenceMessageAckedHandler>, DataRouteReference) - Constructor for class com.broadleafcommerce.common.messaging.PersistenceMessageNotificationHandler
- PersistenceNotificationAutoConfiguration - Class in com.broadleafcommerce.common.messaging.autoconfigure
-
Configure the durable notification components related to
PersistenceProducer
- PersistenceNotificationAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.PersistenceNotificationAutoConfiguration
- persistenceNotificationHandler(PersistenceProducer, PersistenceNotificationProperties, List<IgnoredNotificationStateRepository>, MessageFactory<PersistenceMessage<Object>>, MessageSerializationHelper, List<PersistenceMessageAckedHandler>, DataRouteReference) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.PersistenceNotificationAutoConfiguration
- PersistenceNotificationProperties - Class in com.broadleafcommerce.common.messaging
-
Configuration properties for the
NotificationHandler
andRetryHandler
related toPersistenceProducer
- PersistenceNotificationProperties() - Constructor for class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- persistenceOutput() - Method in interface com.broadleafcommerce.common.messaging.PersistenceProducer
- PersistenceProducer - Interface in com.broadleafcommerce.common.messaging
-
Spring cloud data channel description for messaging output.
- persistenceRetryClusterService(CamelClusterService, PersistenceNotificationProperties, List<NotificationStateRepository>, NotificationHandler, List<IgnoredNotificationStateRepository>, DataRouteReference) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.PersistenceNotificationAutoConfiguration
- postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class com.broadleafcommerce.common.messaging.error.ErrorMessagingAutoConfiguration.LoggingGlobalErrorConfiguration
- postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class com.broadleafcommerce.common.messaging.error.ErrorMessagingAutoConfiguration.LoggingGlobalErrorConfiguration
- postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- postProcessEnvironment(ConfigurableEnvironment, SpringApplication) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.CamelEnvironmentPostProcessor
- postProcessEnvironment(ConfigurableEnvironment, SpringApplication) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryEnvironmentPostProcessor
- postProcessEnvironment(ConfigurableEnvironment, SpringApplication) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
- PREFIX - Static variable in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- PREFIX - Static variable in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- PREFIX - Static variable in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- processStateChange(JsonNode) - Method in interface com.broadleafcommerce.common.messaging.PersistenceHandler
-
Handle the entityJson representation of the change that has been deemed appropriate for this handler based on comparing the expected
_class
parameter in the JSON against the generic type of the handler implementation. - properties - Variable in class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- properties - Variable in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- PubSub() - Constructor for class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties.PubSub
- PubSub() - Constructor for class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties.PubSub
- PUBSUB - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.KnownTypes.Binder
- PubSubDelayedRetryConsumer - Class in com.broadleafcommerce.common.messaging.retry.pubsub
-
Message consumer for a retry binding in Google PubSub.
- PubSubDelayedRetryConsumer(TimeoutAwareStreamBridge) - Constructor for class com.broadleafcommerce.common.messaging.retry.pubsub.PubSubDelayedRetryConsumer
- PURGE_MESSAGE_LOCKS_JOB_TYPE - Static variable in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
- purgeLocks(Set<String>, Duration) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
-
This table will be highly susceptible to deadlocks.
- purgeLocks(Class<?>, Duration) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Deletes all non-expiring locks that are out of date according to the
lockTtl
and haveJpaResourceLock.getTypeAlias()
equal to the providedtype
. - purgeLocks(Duration) - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- purgeLocks(Duration) - Method in interface com.broadleafcommerce.common.messaging.service.MessageLockService
-
Deprecated.in favor of
MessageLockService.purgeLocks(Duration, Set)
- purgeLocks(Duration, Set<String>) - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- purgeLocks(Duration, Set<String>) - Method in interface com.broadleafcommerce.common.messaging.service.MessageLockService
-
Deletes all message locks that are out of date according to the
messageLockTtl
. - purgeLocks(Set<String>, Duration) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- purgeLocks(Set<String>, Duration) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Deletes all non-expiring locks that are out of date according to the
lockTtl
and haveJpaResourceLock.getTypeAlias()
equal to the providedlockTypes
. - purgeLocks(Message<ScheduledJobRef>) - Method in class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
-
Gathers the message lock TTL from the provided
ScheduledJobRef
and purges all relevant message locks - PurgeLockTriggeredJobEventConsumer - Interface in com.broadleafcommerce.common.messaging.service.messaging
-
Spring cloud stream messaging interface for receiving triggered job execution from the scheduled job microservice.
- PurgeMessageLocksListener - Class in com.broadleafcommerce.common.messaging.service.messaging
-
Scheduled Job listener that is responsible for initiating the purging of message locks for all relevant data routes.
- PurgeMessageLocksListener(IdempotentMessageConsumptionService, MessageLockService, DataRouteReference) - Constructor for class com.broadleafcommerce.common.messaging.service.messaging.PurgeMessageLocksListener
R
- releaseLock(JpaResourceLock) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
-
Deletes the provided lock
- releaseLock(String) - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- releaseLock(String) - Method in interface com.broadleafcommerce.common.messaging.service.MessageLockService
-
Releases the lock so that the relevant message can be processed again.
- resend(Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.BackOffAwareRetryConsumer
-
Send the message to the original consumer binding for re-processing.
- reset(MessageBuilder<S>, Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.BackOffAwareRetryConsumer
-
Perform last minute adjustments before resending the message to the original consumer binding
- ResourceLockException - Exception in com.broadleafcommerce.common.messaging.exception
-
Exception thrown when the system is unable to acquire a lock on a resource.
- ResourceLockException() - Constructor for exception com.broadleafcommerce.common.messaging.exception.ResourceLockException
- ResourceLockException(String) - Constructor for exception com.broadleafcommerce.common.messaging.exception.ResourceLockException
- ResourceLockProperties - Class in com.broadleafcommerce.common.messaging.repository
-
Configuration for
ResourceLockRepository
. - ResourceLockProperties() - Constructor for class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
- resourceLockRepository() - Method in class com.broadleafcommerce.common.messaging.repository.autoconfigure.CommonMessagingDefaultRepositoryAutoConfiguration
-
Should only be initialized if a legitimate bean has not been instantiated
- ResourceLockRepository<D,
ID> - Interface in com.broadleafcommerce.common.messaging.repository -
Repository responsible for allowing requesters to lock and unlock a resource.
- RETRY_ATTEMPT_HEADER - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Header
- RetryAutoConfiguration - Class in com.broadleafcommerce.common.messaging.retry.autoconfigure
- RetryAutoConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.retry.autoconfigure.RetryAutoConfiguration
- RetryBreakException - Exception in com.broadleafcommerce.common.messaging.notification
-
Generally thrown during retry processing to allow the
RetryHandler
to break out of a processing loop. - RetryBreakException() - Constructor for exception com.broadleafcommerce.common.messaging.notification.RetryBreakException
- RetryBreakException(String) - Constructor for exception com.broadleafcommerce.common.messaging.notification.RetryBreakException
- RetryClassifier(boolean, BinaryExceptionClassifier, String) - Constructor for class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- RetryClusterService - Interface in com.broadleafcommerce.common.messaging.notification
-
Used to keep track of start/stop behavior that determines node leadership in a cluster.
- retryClusterServiceLifecycleManager(List<RetryClusterService>) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.PersistenceNotificationAutoConfiguration
- RetryClusterServiceRequirementType - Enum Class in com.broadleafcommerce.common.messaging.notification
-
Denotes several key lifecycle events that should occur before a
RetryClusterService
starts. - retryHandler(NotificationStateRepository, NotificationHandler, DurableNotificationProperties, String, TaskScheduler, DataRouteReference) - Method in class com.broadleafcommerce.common.messaging.autoconfigure.DurableNotificationAutoConfiguration
- RetryHandler - Interface in com.broadleafcommerce.common.messaging.notification
-
Retry notification on a set schedule for unacknowledged
NotificationStateAware
instances belonging to a specificNotificationStateRepository
instance. - RetryHandlerStatus - Class in com.broadleafcommerce.common.messaging.notification
-
Status description of a retry handler lifecycle event.
- RetryHandlerStatus(RetryHandler, RetryHandlerStatusType, NotificationStateRepository, String) - Constructor for class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
- RetryHandlerStatusType - Enum Class in com.broadleafcommerce.common.messaging.notification
-
Lifecycle event that occurred
- RetryProperties - Class in com.broadleafcommerce.common.messaging.notification
-
Configuration for a
RetryHandler
- RetryProperties(String) - Constructor for class com.broadleafcommerce.common.messaging.notification.RetryProperties
- retryScheduler() - Method in class com.broadleafcommerce.common.messaging.autoconfigure.DurableNotificationAutoConfiguration
- RetryServiceFactory - Class in com.broadleafcommerce.common.messaging.notification
-
Factory for constructing new
RetryClusterService
instances. - RetryServiceFactory() - Constructor for class com.broadleafcommerce.common.messaging.notification.RetryServiceFactory
S
- ScheduledJobCompletedEvent - Class in com.broadleafcommerce.common.messaging.domain
-
A DTO containing information about an event emitted when a ScheduledJob (from ScheduledJobServices) finishes its execution.
- ScheduledJobCompletedEvent() - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
- ScheduledJobCompletedEvent(String, String, String, String, Instant, boolean, String, String, Map<String, Object>) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
- scheduledJobCompletedEventOutput() - Method in interface com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobCompletedEventProducer
- ScheduledJobCompletedEventProducer - Interface in com.broadleafcommerce.common.messaging.util.scheduledjob
-
Spring cloud data channel description for messaging output.
- ScheduledJobDetailRef - Class in com.broadleafcommerce.common.messaging.domain
-
Detailed information for a
ScheduledJobRef
, which corresponds to a ScheduledJobDetail of the scheduled job microservice. - ScheduledJobDetailRef() - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
- ScheduledJobDetailRef(String, Object) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
- ScheduledJobExecutionDetailRef - Class in com.broadleafcommerce.common.messaging.domain
-
A reference to the ScheduledJobExecutionDetail from the ScheduledJobService.
- ScheduledJobExecutionDetailRef() - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
- ScheduledJobExecutionDetailRef(String, String, Instant, String, Map<String, Object>) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
- ScheduledJobProcessingUtil - Class in com.broadleafcommerce.common.messaging.util.scheduledjob
-
A utility class to execute a scheduled job while sending
ScheduledJobStartedEvent
andScheduledJobCompletedEvent
to facilitate tracking scheduled job execution details. - ScheduledJobProcessingUtil() - Constructor for class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
- ScheduledJobRef - Class in com.broadleafcommerce.common.messaging.domain
-
A reference to a ScheduledJob of the scheduled job microservice.
- ScheduledJobRef() - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- ScheduledJobRef(String, List<ScheduledJobDetailRef>) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- ScheduledJobRef(String, List<ScheduledJobDetailRef>, String) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- ScheduledJobRef(String, List<ScheduledJobDetailRef>, String, Instant) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- ScheduledJobRef(String, List<ScheduledJobDetailRef>, String, Instant, String, boolean, ScheduledJobExecutionDetailRef) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- ScheduledJobRef(String, List<ScheduledJobDetailRef>, String, Instant, String, boolean, ScheduledJobExecutionDetailRef, Map<String, Object>) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- ScheduledJobStartedEvent - Class in com.broadleafcommerce.common.messaging.domain
-
A DTO containing information about an event emitted when a ScheduledJob (from ScheduledJobServices) starts its execution.
- ScheduledJobStartedEvent() - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
- ScheduledJobStartedEvent(String, String, String, String, Instant, String, Map<String, Object>) - Constructor for class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
- scheduledJobStartedEventOutput() - Method in interface com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobStartedEventProducer
- ScheduledJobStartedEventProducer - Interface in com.broadleafcommerce.common.messaging.util.scheduledjob
-
Spring cloud data channel description for messaging output.
- Securable - Interface in com.broadleafcommerce.common.messaging
-
A Spring Cloud Stream message containing a JWT token that can be verified for authenticity and that contains claims about the messages originating user that can be validated for suitability of consumption in the current context.
- send(Object, String, String, String) - Method in interface com.broadleafcommerce.common.messaging.notification.DetachedDurableMessageSender
-
Send a durable message.
- send(Object, String, String, String, Map<String, String>) - Method in interface com.broadleafcommerce.common.messaging.notification.DetachedDurableMessageSender
-
Send a durable message.
- sendRemote(Message<?>, long) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
-
Send the message on the remote channel.
- sendRemoteMessageSafely(Message<?>) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- sendScheduledJobCompletedEventMessageIfNeeded(ScheduledJobRef, String, boolean, String, Consumer<Message<?>>) - Static method in class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
-
Sends a
ScheduledJobCompletedEvent
to record the execution details if enabled. - sendScheduledJobStartedEventMessageIfNeeded(ScheduledJobRef, Consumer<Message<?>>) - Static method in class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
-
Sends a
ScheduledJobStartedEvent
to record the execution details if enabled. - sendSuccessfulScheduledJobCompletedEventMessageIfNeeded(ScheduledJobRef, Consumer<Message<?>>) - Static method in class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
-
Sends a successful
ScheduledJobCompletedEvent
to record the execution details if enabled. - sendSuccessfulScheduledJobCompletedEventMessageIfNeeded(ScheduledJobRef, String, Consumer<Message<?>>) - Static method in class com.broadleafcommerce.common.messaging.util.scheduledjob.ScheduledJobProcessingUtil
-
Sends a successful
ScheduledJobCompletedEvent
with a note message to record the execution details if enabled. - sendToDlq(BlockingFixedRetryInfo, ErrorMessage, Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryErrorHandler
-
Send the message to the DLQ.
- sendToDlq(NonBlockingFixedRetryInfo, int, ErrorMessage, Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
-
Send a failed message to a DLQ
- sendToRetryChannel(NonBlockingFixedRetryInfo, int, Message<?>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler
-
Send a failed message to a configured retry channel
- serializeMessage() - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- set_id(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
- setAcked(boolean) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Whether or not this state has been acknowledged as successfully being sent to the message broker
- setAdditionalHeaders(Map<String, String>) - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- setAdditionalParameters(Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
Additional information that can be used to add parameters for the scheduled job listeners.
- setAsyncEnabled(boolean) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
-
Whether calls to
NotificationManager.handleAsync(NotificationStateRepository, NotificationStateAware, String)
will actually use async threading. - setAttempts(int) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The number of times the system has attempted sending a message for this state change.
- setAttributes(Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
A map to hold additional information on the event about the execution detail
- setAttributes(Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
A map to hold additional information on the execution detail
- setAttributes(Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
A map to hold additional information on the event about the execution detail
- setBackOff(Duration) - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
The backOff timeframe to wait before retrying a message.
- setBackOffCheckInterval(Duration) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
-
The amount of time to wait between polling attempts when consuming the retry bindings defined in
NonBlockingRetryProperties.getBindings()
. - setBeanFactory(BeanFactory) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- setBeanFactory(ListableBeanFactory) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- setBindings(Map<String, BlockingFixedRetryInfo>) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
-
The retry configurations associated by the original consumer bindings
- setBindings(Map<String, List<NonBlockingFixedRetryInfo>>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
-
The ordered list of retry configurations associated by the original consumer binding
- setChangeTimestamp(Instant) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Set the last time this entity was updated in a way that requires notification via a message bus.
- setChangeTimestampAck(Instant) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Set the last time a message was sent for a state change to the message bus.
- setChannelModifierProperties(ChannelModifierProperties) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- setClusterK8sAppLabel(String) - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
If using
kubernetes
cluster service implementation type, this is the name of the pod label used to group common service instances. - setClusterK8sAppLabelValue(String) - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
If using
kubernetes
cluster service implementation type, this is the value for the pod label. - setClusterServiceImplementationType(String) - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
Specify which camel cluster service implementation to support.
- setClustServiceImplementation(Class<?>) - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
Deprecated.cluster service implementation now supported by
MessagingProperties.clusterServiceImplementationType
Implementation of CamelClusterService to utilize - setCompileChangeDetails(boolean) - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
-
Whether or not entities managed by the ignored repository should have change details compiled at the time of edit.
- setConceptKey(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
A generally descriptive key that identifies the overall concept for which the lock is taking place.
- setConsumerBinding(String) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
-
The consumer binding from which to poll for candidate retryable messages.
- setContextId(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The contextId of the Trackable resource to lock
- setDefaultStagnationThreshold(Duration) - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
-
The time, once elapsed, in which the system will consider a lock abandoned and allow another requester to acquire the lock.
- setDefaultStagnationThreshold(Duration) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- setDelayAtStartup(Duration) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The amount of time after initialization of the application that must pass before the retry scheduler starts.
- setDetails(List<ScheduledJobDetailRef>) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- setDeveloperMode(boolean) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
Deprecated.Development state is now handled through the
broadleaf.messaging.cluster-service-implementation-type
property. The default for that property isfile
, which is appropriate for local development. - setDlq(StandardRetryProperties.DLQ) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- setDlq(String) - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
Optional.
- setEnabled(boolean) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
-
Whether the blocking retry feature is enabled
- setEnabled(boolean) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
-
Whether the non-blocking retry feature is enabled
- setEnabled(boolean) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- setEndTime(Instant) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The time at which the scheduled job finished its execution
- setEntityType(String) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.EntityAwareNotificationState
- setEnvironment(Environment) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- setEnvironment(Environment) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- setEnvironment(Environment) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryConsumerBeanDefinitionRegistryPostProcessor
- setError(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The message to be set on the scheduled job execution detail in case an error occurs.
- setEventPublisher(ApplicationEventPublisher) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
- setExclude(List<Class<? extends Throwable>>) - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
Optional.
- setExecutionId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The Context ID of the scheduled job execution detail
- setExpirationTimestamp(Instant) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The time at which the lock will naturally expire
- setFailedNotificationAttempt(Object, String, int, Instant, Class<?>, boolean) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationStateRepository
-
Notate a failed message send attempt for a messageType on the
NotificationState
of an entity of a particular type. - setFailureRateThreshold(float) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the failure rate threshold in percentage above which the CircuitBreaker should trip open and start short-circuiting calls.
- setFileLockRootPath(String) - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
-
Deprecated.Not required. Use
MessagingProperties.clusterServiceImplementationType
support instead. If using FileLockClusterService, the root path to store the lock files - setId(String) - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- setInclude(List<Class<? extends Throwable>>) - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
Optional.
- setIncludeListenerNames(List<String>) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- setInitialFaultThreshold(Duration) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The amount of time that must elapse before the retry mechanism can kick in on a newly altered and unacknowledged record.
- setJobExecutionDetailId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The Context ID of the scheduled job execution detail
- setJobExecutionDetailId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The Context ID of the scheduled job execution detail
- setJobId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The Context ID of the scheduled job for which this completion event is emitted
- setJobId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
The Context ID of the scheduled job
- setJobId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The Context ID of the scheduled job for which this completion event is emitted
- setJobType(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The type of the job for which this completion event is emitted
- setJobType(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The type of the job for which the completion event is emitted
- setKafka(BlockingFixedRetryInfo.Kafka) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
- setKafka(StandardRetryProperties.Kafka) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- setLastExecuted(Instant) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
The date on which the job last executed.
- setLastExecutionDetail(ScheduledJobExecutionDetailRef) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
A reference to the latest scheduled job execution detail of the current scheduled job
- setLastUpdatedTime(Instant) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The time at which the scheduled job is last updated
- setLifecycleRequirementMet(RetryClusterServiceRequirementType) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- setLifecycleRequirementMet(RetryClusterServiceRequirementType) - Method in interface com.broadleafcommerce.common.messaging.notification.RetryClusterService
-
Notify a retry cluster service instance that a particular lifecycle event has been met.
- setLocked(Boolean) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
Whether or not the resource is locked
- setLockPurgePageSize(int) - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
- setMaxAckExtensionPeriod(long) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties.PubSub
- setMaxAckExtensionPeriod(long) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties.PubSub
- setMaxAttempts(int) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The maximum number of failed attempts that should be made before ceasing to attempt to send a message for an unacknowledged record.
- setMaxAttempts(int) - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
-
The maximum number of retry attempts.
- setMaxAttemptWaitTime(Duration) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The maximum amount of time that should elapse before making another attempt on an unacknowledged record.
- setMaxTraceLineCount(int) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- setMessage(Object) - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- setMessageType(String) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The fully qualified
Type
for the message information - setMessageType(String) - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
-
The type of message the repository should be ignored for.
- setMessageValue(String) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
If message serialization is used, this is the JSON string version of the message information
- setName(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
-
The name of this detail.
- setName(String) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The name identifying this particular message state.
- setNextAttempt(Instant) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
The time at which (or beyond which) another retry attempt should be made
- setNote(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
A note/message to be set on the scheduled job execution detail.
- setNote(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The execution note/message to be set on the execution detail.
- setNote(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
A note/message to be set on the scheduled job execution detail.
- setNotification(NotificationProperties) - Method in interface com.broadleafcommerce.common.messaging.notification.MutableDurableNotificationProperties
-
Configuration for the
NotificationHandler
- setNotification(NotificationProperties) - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- setNotificationAcknowledged(Object, String, int, Class<?>) - Method in interface com.broadleafcommerce.common.messaging.notification.NotificationStateRepository
-
Establish acknowledged state for a
NotificationState
of a particular messageType on an entity of a particular type. - setNotificationStates(List<NotificationState>) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationStateAware
-
Set the message sending status for one or more
NotificationState
instances. - setOptional(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
Optional information related to the lock.
- setOriginalProducerBinding(String) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
-
The producer binding used to send the message back to the original channel to re-attempt processing.
- setPageSize(int) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The number of valid, unacknowledged records to batch process per interval.
- setPollTimeout(long) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.Kafka
-
The amount of time in milliseconds the kafka consumer will block waiting for poll max records to be returned.
- setProducerBinding(String) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
-
The producer binding used to send a message to park in the retry queue defined here.
- setProperties(NotificationManagerProperties) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationManager
- setProperties(MessageLockProperties) - Method in class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- setProperties(MessageLockProperties) - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- setPubSub(BlockingRetryProperties.PubSub) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- setPubSub(NonBlockingRetryProperties.PubSub) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- setRecordProcessingWait(Duration) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The amount of time to pause between the processing of each unacknowledged record in the batch.
- setRetry(RetryProperties) - Method in interface com.broadleafcommerce.common.messaging.notification.MutableDurableNotificationProperties
-
Configuration for the
RetryHandler
- setRetry(RetryProperties) - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- setRetryClusterServiceNamespace(String) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
Name used to identify the cluster singleton lock
- setRetryInterval(Duration) - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
-
The length of time to wait between each batch retry attempt.
- setRingBufferSizeInClosedState(int) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the size of the ring buffer when the CircuitBreaker is closed.
- setRingBufferSizeInHalfOpenState(int) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the size of the ring buffer when the CircuitBreaker is half open.
- setSeekToCurrentRecordOnFailure(boolean) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo.Kafka
-
Optional.
- setSendEnabled(boolean) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Whether or not sending on the producer channel is allowed.
- setSendTimeout(Duration) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
The length of time a message send attempt should block before timing out.
- setStackTraceFiltersRegex(List<String>) - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- setStagnationThresholds(Map<String, Duration>) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- setStartTime(Instant) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The time at which the scheduled job started its execution
- setStatus(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
-
The execution status of the scheduled job
- setStatusConsumers(List<Consumer<RetryHandlerStatus>>) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- setStatusConsumers(List<Consumer<RetryHandlerStatus>>) - Method in interface com.broadleafcommerce.common.messaging.notification.RetryClusterService
-
Set the list of consumers for
RetryHandlerStatus
on the cluster service. - setStopped(boolean) - Method in interface com.broadleafcommerce.common.messaging.notification.domain.NotificationState
-
Whether or not retry attempts should cease for this state
- setSuccess(boolean) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
A flag indicating whether the scheduled job finished successfully
- setSuffix(String) - Method in class com.broadleafcommerce.common.messaging.notification.ChannelModifierProperties
-
If no modifier is provided via MicroCloudStreamBindingCommon configuration, then apply this suffix value as a modifier key during all attempts to match relevant notification state messages.
- setTakeover(MessageLockProperties.Takeover) - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties
- setTenantId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
-
The ID of the associated tenant
- setTenantId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
The ID of the associated tenant.
- setTenantId(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
-
The ID of the associated tenant
- setThreadPoolSize(int) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
-
The thread pool size used for async handling.
- setTimestamp(Instant) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The time at which the lock was set to true
- setToken(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
The token assigned the last time the lock was set to true.
- setToken(String) - Method in interface com.broadleafcommerce.common.messaging.Securable
-
A Base64 encoded JWT token generally containing the following claims: user - the user name for the user that generated the message via some action.
- setTrackExecutionDetails(boolean) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
-
A flag to indicate whether the execution details of this scheduled-job should be tracked
- setType(String) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- setTypeAlias(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
-
An alias used to represent the Java type of the resource being locked.
- setupAckDeadline(BlockingRetryProperties, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryEnvironmentPostProcessor
-
Set up the
spring.cloud.gcp.pubsub.subscriber.max-ack-extension-period
property based onBlockingRetryProperties.PubSub.getMaxAckExtensionPeriod()
value, if not already defined. - setupAckDeadline(NonBlockingRetryProperties, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Set up the
spring.cloud.gcp.pubsub.subscriber.max-ack-extension-period
property based onNonBlockingRetryProperties.PubSub.getMaxAckExtensionPeriod()
value, if not already defined. - setupDlq(String, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryEnvironmentPostProcessor
-
Establish the producer binding property for DLQ, if not already defined.
- setupDlq(String, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Set up the spring cloud stream DLQ producer binding property, if it does not already exist.
- setupErrorHandler(String, String, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryEnvironmentPostProcessor
-
Establish the error handler definition property for the original consumer binding.
- setupKafkaConsumer(NonBlockingFixedRetryInfo, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Set up spring cloud stream properties related to retry consumption for kafka for the non-blocking case.
- setupPubSubConsumer(NonBlockingFixedRetryInfo, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Set up spring cloud stream properties related to retry consumption for pubsub for the non-blocking case.
- setupRetryBindingIfApplicable(String, NonBlockingFixedRetryInfo, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Set up the spring cloud stream retry binding consumer, producer, and DLQ properties, if they don't already exist.
- setupRetryConsumer(String, NonBlockingFixedRetryInfo, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Set up the spring cloud stream retry consumer binding property, if it does not already exist.
- setupRetryProducer(NonBlockingFixedRetryInfo, ConfigurableEnvironment, Map<String, Object>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Set up the spring cloud stream retry producer binding property, if it does not already exist.
- setUseDefaults(boolean) - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
-
If the default values are all satisfactory, the retry configuration can simply set this property to true, which will establish a
BlockingRetryInfo
associated with the targeted binding inBlockingRetryProperties.getBindings()
. - setValue(Object) - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
-
A value for this detail.
- setWaitDurationInOpenState(Duration) - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
-
Configures the wait duration which specifies how long the CircuitBreaker should stay open, before it switches to half open.
- Spring() - Constructor for class com.broadleafcommerce.common.messaging.retry.Constants.Spring
- SPRING_CLOUD_STREAM_BINDING_PREFIX - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Spring
- SPRING_CLOUD_STREAM_KAFKA_BINDING_PREFIX - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Spring
- SPRING_CLOUD_STREAM_PUBSUB_BINDING_PREFIX - Static variable in class com.broadleafcommerce.common.messaging.retry.Constants.Spring
- SpringKafkaRetryConfiguration() - Constructor for class com.broadleafcommerce.common.messaging.autoconfigure.kafka.KafkaCommonMessagingAutoConfiguration.SpringKafkaRetryConfiguration
- StackTraceTruncator - Class in com.broadleafcommerce.common.messaging.retry
-
Custom logic to filter and truncate a stack trace to make it suitable for inclusion as an informative message header
- StackTraceTruncator(StandardRetryProperties) - Constructor for class com.broadleafcommerce.common.messaging.retry.StackTraceTruncator
- STAGNATE - Enum constant in enum class com.broadleafcommerce.common.messaging.repository.LockStatus
-
Lock exists and is active, but it's TTL has expired.
- StandardRetryProperties - Class in com.broadleafcommerce.common.messaging.retry
-
Properties that apply to all broadleaf messaging retry features (both blocking and non-blocking)
- StandardRetryProperties() - Constructor for class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- StandardRetryProperties.DLQ - Class in com.broadleafcommerce.common.messaging.retry
- StandardRetryProperties.Kafka - Class in com.broadleafcommerce.common.messaging.retry
- start() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- start() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterServiceLifecycleManager
- start() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryHandler
- start() - Method in interface com.broadleafcommerce.common.messaging.notification.RetryClusterService
-
Deprecated.Use
Lifecycle.start()
instead - start() - Method in interface com.broadleafcommerce.common.messaging.notification.RetryHandler
-
Commence the scheduled processing via a new thread
- start(List<Consumer<RetryHandlerStatus>>) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- start(List<Consumer<RetryHandlerStatus>>) - Method in interface com.broadleafcommerce.common.messaging.notification.RetryClusterService
-
Start the cluster service with a list of consumers for retry handler status events
- STARTED - Enum constant in enum class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatusType
- status(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- status(String) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- status(String) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Report on the status of the lock.
- stop() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- stop() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterServiceLifecycleManager
- stop() - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryHandler
- stop() - Method in interface com.broadleafcommerce.common.messaging.notification.RetryClusterService
-
Stop the node as a leader in the cluster.
- stop() - Method in interface com.broadleafcommerce.common.messaging.notification.RetryHandler
-
Stop scheduled processing and exit the processing thread
- stop(Runnable) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultRetryClusterService
- STOPPED - Enum constant in enum class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatusType
- SuppressNotification - Annotation Interface in com.broadleafcommerce.common.messaging.notification
-
Demarcate a flow during which notification via
NotificationHandler
should be suppressed for one or more message types. - suppressNotificationAspect() - Method in class com.broadleafcommerce.common.messaging.autoconfigure.CommonMessagingAutoConfiguration
- SuppressNotificationContext - Class in com.broadleafcommerce.common.messaging.notification
-
Threadlocal describing one or more message types for which notification should be suppressed during a flow.
- SuppressNotificationContext(String[]) - Constructor for class com.broadleafcommerce.common.messaging.notification.SuppressNotificationContext
- SuppressNotificationContext(String[], boolean) - Constructor for class com.broadleafcommerce.common.messaging.notification.SuppressNotificationContext
T
- Takeover() - Constructor for class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- toString() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobCompletedEvent
- toString() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobDetailRef
- toString() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobExecutionDetailRef
- toString() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobRef
- toString() - Method in class com.broadleafcommerce.common.messaging.domain.ScheduledJobStartedEvent
- toString() - Method in class com.broadleafcommerce.common.messaging.environment.MessagingProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.ChannelModifierProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.IdempotentMessage
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.IdInformation
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationHandlerResponse
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationManagerProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.NotificationProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatus
- toString() - Method in class com.broadleafcommerce.common.messaging.notification.RetryProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.PersistenceMessage
- toString() - Method in class com.broadleafcommerce.common.messaging.PersistenceNotificationProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.domain.JpaResourceLock
- toString() - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.LockState
- toString() - Method in class com.broadleafcommerce.common.messaging.repository.ResourceLockProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo.Kafka
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingFixedRetryInfo
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties.PubSub
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.blocking.BlockingRetryProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.FixedRetryInfo
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingFixedRetryInfo
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryErrorHandler.RetryClassifier
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties.PubSub
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.DLQ
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties.Kafka
- toString() - Method in class com.broadleafcommerce.common.messaging.retry.StandardRetryProperties
- toString() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties.Takeover
- toString() - Method in class com.broadleafcommerce.common.messaging.service.MessageLockProperties
- triggeredJobEventInputPurgeLock() - Method in interface com.broadleafcommerce.common.messaging.service.messaging.PurgeLockTriggeredJobEventConsumer
- TYPE - Static variable in interface com.broadleafcommerce.common.messaging.checkout.CheckoutCompletionProducer
- TYPE - Static variable in interface com.broadleafcommerce.common.messaging.PersistenceProducer
U
- unlockResource(String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- unlockResource(String) - Method in class com.broadleafcommerce.common.messaging.repository.NoOpResourceLockRepository
- unlockResource(String) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Unlock the resource so that other requesters can acquire the lock on the resource.
- unwrap() - Method in interface com.broadleafcommerce.common.messaging.notification.MessageAdditionalInformationAware
-
Unwrap the proxy exposing this interface, if applicable, and expose the underlying entity instance.
- unwrapNotificationState(NotificationStateAware) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultNotificationHandler
- updateState(String, String) - Method in class com.broadleafcommerce.common.messaging.provider.jpa.repository.JpaCustomizedResourceLockRepository
- updateState(String, String) - Method in interface com.broadleafcommerce.common.messaging.repository.ResourceLockRepository
-
Update the state for the process associated with this lock
V
- validate(JsonNode) - Method in interface com.broadleafcommerce.common.messaging.PersistenceHandler
-
Verify the signed JWT token and validate the user claims (especially authorities) against the consumption functionality.
- validate(ProceedingJoinPoint) - Method in class com.broadleafcommerce.common.messaging.notification.DefaultSuppressNotificationAspect
- validateRetryInfo(NonBlockingFixedRetryInfo, List<String>) - Method in class com.broadleafcommerce.common.messaging.retry.nonblocking.NonBlockingRetryEnvironmentPostProcessor
-
Validate the non-blocking retry configuration
- validateStatusAware(String) - Method in class com.broadleafcommerce.common.messaging.service.DefaultIdempotentMessageConsumptionService
- validateTakeoverRequest(String) - Method in class com.broadleafcommerce.common.messaging.service.DefaultMessageLockService
- value() - Element in annotation interface com.broadleafcommerce.common.messaging.notification.SuppressNotification
-
The message types for which suppression should be enacted.
- valueOf(String) - Static method in enum class com.broadleafcommerce.common.messaging.notification.RetryClusterServiceRequirementType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatusType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.broadleafcommerce.common.messaging.repository.LockStatus
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.broadleafcommerce.common.messaging.notification.RetryClusterServiceRequirementType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.broadleafcommerce.common.messaging.notification.RetryHandlerStatusType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.broadleafcommerce.common.messaging.repository.LockStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
W
- withCompileChangeDetails(boolean) - Method in class com.broadleafcommerce.common.messaging.notification.IgnoredNotificationStateRepository
Z
- ZK_DIGEST_PASSWORD - Static variable in class com.broadleafcommerce.common.messaging.autoconfigure.CamelSetupAutoConfiguration
- ZK_DIGEST_USERNAME - Static variable in class com.broadleafcommerce.common.messaging.autoconfigure.CamelSetupAutoConfiguration
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
MessagingProperties.clusterServiceImplementationType
Implementation of CamelClusterService to utilize