Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractBatchIdQueueLoader<ID extends Serializable,
T extends BatchIdHolder<ID>> - Class in com.broadleafcommerce.search.index.core.queue -
Abstract component to handle reading ID ranges from a source and populating a Queue for further retrieval.
- AbstractBatchIdQueueLoader(IndexableType, long, int, int, int) - Constructor for class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
- AbstractDelegatingQueue<T> - Class in com.broadleafcommerce.search.index.core.queue
-
Abstract implementation of a ReindexQueue that delegates its work to any implementation of a BlockingQueue.
- AbstractDelegatingQueue(IndexableType, BlockingQueue<T>) - Constructor for class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- AbstractDocumentBuilder<T> - Class in com.broadleafcommerce.search.index.core.document
-
Builds documents from indexables based on
FieldDefinitions
for theirIndexableType
. - AbstractDocumentBuilder(IndexerSearchService<FieldDefinition>, ProcessStateService, List<DocumentBuilderContributor<T>>, List<DocumentBuilderPreProcessor>) - Constructor for class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- AbstractDocumentBuilder(IndexerSearchService<FieldDefinition>, ProcessStateService, List<DocumentBuilderContributor<T>>, List<DocumentBuilderPreProcessor>, Configuration, int) - Constructor for class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- AbstractDocumentBuilderPreProcessor - Class in com.broadleafcommerce.search.index.core.document
-
Abstract processor for updating indexables sharing the same contextId.
- AbstractDocumentBuilderPreProcessor() - Constructor for class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilderPreProcessor
- AbstractFullIndexMessageListener - Class in com.broadleafcommerce.search.index.core.messaging
-
An abstract message listener that triggers when a full index message is received.
- AbstractFullIndexMessageListener(IdempotentMessageConsumptionService, ObjectMapper, ReindexDelegationService) - Constructor for class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- AbstractProcessStateService - Class in com.broadleafcommerce.search.index.core
-
Mechanism to safely access or update process state across threads within a single JVM.
- AbstractProcessStateService() - Constructor for class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- AbstractQueueLoader<FROM,
TO> - Class in com.broadleafcommerce.search.index.core.queue -
Abstract component to allow reading data in batch from a data source or web service, converting those values, and putting them on a
ReindexQueue
. - AbstractQueueLoader(long, int) - Constructor for class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
- AbstractQueueProvider - Class in com.broadleafcommerce.search.index.core.queue
-
Abstract provider which stores queues in a map based on their
IndexableType
. - AbstractQueueProvider(int) - Constructor for class com.broadleafcommerce.search.index.core.queue.AbstractQueueProvider
- AbstractReindexSinceDateJobListener - Class in com.broadleafcommerce.search.index.core.messaging
-
An abstract message listener that is triggered from a scheduled job event to reindex
Indexables
starting from a configured timeframe. - AbstractReindexSinceDateJobListener(IdempotentMessageConsumptionService, ObjectMapper, ReindexDelegationService) - Constructor for class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
- AbstractWorker<T> - Class in com.broadleafcommerce.search.index.core.worker
-
Represents an abstract
Runnable
object for data off of aReindexQueue
and processing the data. - AbstractWorker(ProcessStateService, Semaphore, IndexableType, ReindexQueue<T>, long, int) - Constructor for class com.broadleafcommerce.search.index.core.worker.AbstractWorker
- add(T) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- addAll(Collection<? extends T>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- addError(String, String, Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
Adds an error to the error list for this Reindex job.
- addStateHolderProperties(ProcessStateHolder) - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
Adds properties set on the
context
map to the ProcessStateHolder. - author(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The user that initiated this reindex process.
- AUTHOR_KEY - Static variable in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Key for the author of a reindex job.
- AUTHOR_PATH - Static variable in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- authorize(OAuth2AuthorizeRequest) - Method in class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.SynchronizedDelegatingOAuth2AuthorizedClientManager
B
- BATCH_SIZE_FLD - Static variable in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
- BatchCompletedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Event to notify that a batch of
Indexables
have been processed. - BatchCompletedEvent(IndexableType, long) - Constructor for class com.broadleafcommerce.search.index.core.event.BatchCompletedEvent
- BatchCompletedEvent(Object, IndexableType, long) - Constructor for class com.broadleafcommerce.search.index.core.event.BatchCompletedEvent
- BatchCompletedEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
BatchCompletedEvent
, and updates theProcessStateHolder
with the number of items processed. - BatchCompletedEventListener(ProcessStateService) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.BatchCompletedEventListener
- BatchIdHolder<ID extends Serializable> - Class in com.broadleafcommerce.search.index.core.queue
-
Convenience class to hold a list of IDs for processing as a batch.
- BatchIdHolder(IndexableType, List<ID>) - Constructor for class com.broadleafcommerce.search.index.core.queue.BatchIdHolder
- BlockingRejectedExecutionHandler - Class in com.broadleafcommerce.search.index.core
-
This is a component to optionally configure a ThreadPoolTaskExecutor.
- BlockingRejectedExecutionHandler() - Constructor for class com.broadleafcommerce.search.index.core.BlockingRejectedExecutionHandler
- build() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
- buildAdditionalProperties(ContextInfo, ReindexRequest) - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
-
Creates a map of properties to be passed to the reindex process.
- buildDocuments(Indexable<?>) - Method in interface com.broadleafcommerce.search.index.core.document.DocumentBuilder
- buildDocuments(List<? extends Indexable<?>>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- buildDocuments(List<? extends Indexable<?>>) - Method in interface com.broadleafcommerce.search.index.core.document.DocumentBuilder
-
Build documents to be indexed by the search engine.
- builder() - Static method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- buildFieldRef(FieldDefinition) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
-
Builds the
FieldRef
object based on aFieldDefinition
- buildId(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
Build an ID value which routes documents based on context ID and is a unique representation of its context.
- buildSearchFieldUri(String) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
C
- CACHE_BY_INDEXABLE_TYPE - Static variable in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerWebClientProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder.ProcessFailure
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.SSLVerificationProperties
- canEqual(Object) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- canHandle(Indexable<?>) - Method in interface com.broadleafcommerce.search.index.core.document.DocumentBuilderContributor
-
Determines whether this contributor should contribute
- canHandle(Indexable<?>) - Method in interface com.broadleafcommerce.search.index.core.document.IndexableTypeDocumentBuilderContributor
- CHANNEL - Static variable in interface com.broadleafcommerce.search.index.core.messaging.FieldPersistenceConsumer
- clear() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- clearCache(IndexableType) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- clearCache(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerSearchService
-
Clear any cached fields for the indexable type.
- clearCache(String) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
- clearCache(String) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerTenantService
-
Clear any cached locales for the tenant ID.
- CLIENT_REGISTRATION_ID - Static variable in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
-
Deprecated.
- CLIENT_REGISTRATION_ID - Static variable in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
-
Deprecated.
- CollectionIndexerProperties - Class in com.broadleafcommerce.search.index.autoconfigure
- CollectionIndexerProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
- CollectionIndexerWebClientProperties - Class in com.broadleafcommerce.search.index.autoconfigure
- CollectionIndexerWebClientProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerWebClientProperties
- com.broadleafcommerce.search.index.autoconfigure - package com.broadleafcommerce.search.index.autoconfigure
- com.broadleafcommerce.search.index.core - package com.broadleafcommerce.search.index.core
- com.broadleafcommerce.search.index.core.cache - package com.broadleafcommerce.search.index.core.cache
- com.broadleafcommerce.search.index.core.document - package com.broadleafcommerce.search.index.core.document
- com.broadleafcommerce.search.index.core.document.helper - package com.broadleafcommerce.search.index.core.document.helper
- com.broadleafcommerce.search.index.core.domain - package com.broadleafcommerce.search.index.core.domain
- com.broadleafcommerce.search.index.core.endpoint - package com.broadleafcommerce.search.index.core.endpoint
- com.broadleafcommerce.search.index.core.endpoint.autoconfigure - package com.broadleafcommerce.search.index.core.endpoint.autoconfigure
- com.broadleafcommerce.search.index.core.event - package com.broadleafcommerce.search.index.core.event
- com.broadleafcommerce.search.index.core.event.listener - package com.broadleafcommerce.search.index.core.event.listener
- com.broadleafcommerce.search.index.core.master - package com.broadleafcommerce.search.index.core.master
- com.broadleafcommerce.search.index.core.messaging - package com.broadleafcommerce.search.index.core.messaging
- com.broadleafcommerce.search.index.core.messaging.autoconfigure - package com.broadleafcommerce.search.index.core.messaging.autoconfigure
- com.broadleafcommerce.search.index.core.messaging.handler - package com.broadleafcommerce.search.index.core.messaging.handler
- com.broadleafcommerce.search.index.core.oauth2.client.endpoint - package com.broadleafcommerce.search.index.core.oauth2.client.endpoint
- com.broadleafcommerce.search.index.core.queue - package com.broadleafcommerce.search.index.core.queue
- com.broadleafcommerce.search.index.core.repository - package com.broadleafcommerce.search.index.core.repository
- com.broadleafcommerce.search.index.core.service - package com.broadleafcommerce.search.index.core.service
- com.broadleafcommerce.search.index.core.service.autoconfigure - package com.broadleafcommerce.search.index.core.service.autoconfigure
- com.broadleafcommerce.search.index.core.worker - package com.broadleafcommerce.search.index.core.worker
- contains(Object) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- containsAll(Collection<?>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- contribute(Indexable<?>, T, DocumentContext, List<FieldDefinition>) - Method in interface com.broadleafcommerce.search.index.core.document.DocumentBuilderContributor
-
Enhances an indexable document with additional information.
- contributeInternal(Indexable<?>, T, DocumentContext, List<FieldDefinition>) - Method in interface com.broadleafcommerce.search.index.core.document.DocumentBuilderContributor
-
Enhances an indexable document with additional information.
- CoreIndexerAutoConfiguration - Class in com.broadleafcommerce.search.index.autoconfigure
-
Core Spring Configuration for this module.
- CoreIndexerAutoConfiguration() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- countIndexablesToProcess(List<T>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
- countIndexablesToProcess(List<TO>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Determine how many
Indexable
s are being processed. - create(IndexableType) - Method in class com.broadleafcommerce.search.index.core.DefaultSemaphoreProvider
- create(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.SemaphoreProvider
-
Creates a semaphore with zero permits.
- create(IndexableType, int) - Method in class com.broadleafcommerce.search.index.core.DefaultSemaphoreProvider
- create(IndexableType, int) - Method in interface com.broadleafcommerce.search.index.core.SemaphoreProvider
-
Creates a semaphore with the given permits.
- create(ReindexJob) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- createAll(List<ReindexJob>) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- createAllAllowingPartialSuccess(List<ReindexJob>) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- createContextFromIndexable(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- createDocument(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
Creates a new document.
- createExecutor() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Creates an Executor to allow us to populate the queue on different threads than what is reading the data.
- createExecutor(int, IndexableType) - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
This creates a
ThreadPoolTaskExecutor
by default. - createNewTask(ProcessStateService, Semaphore, IndexableType, ReindexQueue<T>) - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Launch a worker process.
- createQueue(IndexableType) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueProvider
-
Create a new queue for the given
IndexableType
. - createQueue(IndexableType) - Method in class com.broadleafcommerce.search.index.core.queue.DefaultLocalQueueProvider
D
- DEFAULT_SOURCE - Static variable in class com.broadleafcommerce.search.index.core.event.SearchIndexProcessEvent
- DefaultDocumentBuilderHelper - Class in com.broadleafcommerce.search.index.core.document.helper
-
Helper methods used to support building the document for indexing.
- DefaultDocumentBuilderHelper() - Constructor for class com.broadleafcommerce.search.index.core.document.helper.DefaultDocumentBuilderHelper
- DefaultIndexerSearchService - Class in com.broadleafcommerce.search.index.core.service
- DefaultIndexerSearchService(WebClient, String, String, ObjectMapper, CacheStateManager) - Constructor for class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- DefaultIndexerTenantService - Class in com.broadleafcommerce.search.index.core.service
- DefaultIndexerTenantService(WebClient, String, String) - Constructor for class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
- DefaultIndexerTenantService.Tenant - Class in com.broadleafcommerce.search.index.core.service
-
Basic tenant representation used only to retrieve locales.
- DefaultLocalArrayBlockingDelegatingQueue<T> - Class in com.broadleafcommerce.search.index.core.queue
-
Default non-distributed implementation of
AbstractDelegatingQueue
, backed by anArrayBlockingQueue
. - DefaultLocalArrayBlockingDelegatingQueue(IndexableType, int) - Constructor for class com.broadleafcommerce.search.index.core.queue.DefaultLocalArrayBlockingDelegatingQueue
- DefaultLocalJvmLockService - Class in com.broadleafcommerce.search.index.core
-
This component allows for the tracking of a lock reference for a single process ID or reference.
- DefaultLocalJvmLockService() - Constructor for class com.broadleafcommerce.search.index.core.DefaultLocalJvmLockService
- DefaultLocalQueueProvider - Class in com.broadleafcommerce.search.index.core.queue
-
A local QueueProvider that uses a
DefaultLocalArrayBlockingDelegatingQueue
. - DefaultLocalQueueProvider(int) - Constructor for class com.broadleafcommerce.search.index.core.queue.DefaultLocalQueueProvider
- DefaultProcessStateService - Class in com.broadleafcommerce.search.index.core
-
Default implementation of the ProcessStateService interface.
- DefaultProcessStateService() - Constructor for class com.broadleafcommerce.search.index.core.DefaultProcessStateService
- DefaultReindexDelegationService - Class in com.broadleafcommerce.search.index.core.service
- DefaultReindexDelegationService(List<SearchIndexMasterProcessLauncher>, List<SearchIndexWorkerProcessLauncher>, ReindexService) - Constructor for class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- DefaultSemaphoreProvider - Class in com.broadleafcommerce.search.index.core
-
Default semaphore provider to allow shared access to a semaphore between the
SearchIndexMasterProcessLauncher
and theWorkerCompletedEventListener
. - DefaultSemaphoreProvider() - Constructor for class com.broadleafcommerce.search.index.core.DefaultSemaphoreProvider
- delete(String) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- deleteByField(String, String, IndexableType) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexService
-
Delete documents matching a field name and value.
- destroy(IndexableType) - Method in class com.broadleafcommerce.search.index.core.DefaultSemaphoreProvider
- destroy(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.SemaphoreProvider
-
Removes the semaphore from the local registry.
- destroyExecutor(Executor) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Provides a mechanism to shutdown the Executor.
- destroyExecutor(Executor) - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
This is always called to close the Executor when it's finished.
- destroyQueue(ReindexQueue<?>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueProvider
- destroyQueue(ReindexQueue<?>) - Method in interface com.broadleafcommerce.search.index.core.queue.QueueProvider
-
Takes the necessary steps to remove or destroy the Queue, if necessary.
- destroyQueue(ReindexQueue<T>) - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
Attempts to destroy the queue.
- destroyQueueInternal(ReindexQueue<?>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueProvider
-
Takes the necessary steps to remove or destroy the Queue, if necessary.
- destroyQueueInternal(ReindexQueue<?>) - Method in class com.broadleafcommerce.search.index.core.queue.DefaultLocalQueueProvider
- determineName(ReindexRequest) - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
- Distributable - Interface in com.broadleafcommerce.search.index.core
-
Interface to indicate if the component is distributable.
- DocumentBuilder<T> - Interface in com.broadleafcommerce.search.index.core.document
-
Documents builder to be used when building data to be indexed.
- DocumentBuilderContributor<T> - Interface in com.broadleafcommerce.search.index.core.document
-
Responsible for further contributing to a populated search document.
- documentBuilderHelper() - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- DocumentBuilderHelper - Interface in com.broadleafcommerce.search.index.core.document.helper
-
Helper methods used to support building the document for indexing.
- DocumentBuilderPreProcessor - Interface in com.broadleafcommerce.search.index.core.document
-
Pre-process indexables sharing the same contextId.
- drainTo(Collection<? super T>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- drainTo(Collection<? super T>, int) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
E
- element() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- ENABLE_PARTIAL_INDEX_WITH_FILTERS_KEY - Static variable in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Key for toggling a partial reindex based on applicable filters.
- END_DATE_KEY - Static variable in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Key for the end date of a reindex job.
- endProcessState(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- endProcessState(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
End's a process for a given IndexableType.
- endTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The completion time of the process
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerWebClientProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
- equals(Object) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- equals(Object) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
- equals(Object) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder.ProcessFailure
- equals(Object) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.SSLVerificationProperties
- equals(Object) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- errors(List<ReindexErrorDetails>) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
A list of errors that may have occurred during the reindex process.
- EventPublisher - Interface in com.broadleafcommerce.search.index.core
-
Generic, lightweight API for publishing events.
- executeContributors(List<DocumentBuilderContributor<T>>, Indexable<?>, T, DocumentContext, List<FieldDefinition>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
Execute all of the defined
DocumentBuilderContributors
on the indexable. - executeInternal(T) - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
-
Arbitrarily allows the processing of a queue entry.
- executeInternal(T, ProcessStateHolder) - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
-
Arbitrarily allows the processing of a queue entry.
- executeInternally() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
Method in this class that does the heavy lifting.
- executeInternally() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
- executePreProcessors(List<? extends Indexable<?>>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
Execute all of the defined
DocumentBuilderPreProcessors
on the indexables together. - expectedCount(Long) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The expected number of items to be processed (May be an estimate, such as with Products)
F
- FAILED - Enum constant in enum class com.broadleafcommerce.search.index.core.domain.ReindexStatus
- failFast() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Tells the system to arbitrarily fail without a specific exception.
- failFast(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- failFast(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Notifies that the process has failed and does not require a Throwable to be provided.
- failFast(IndexableType, String) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- failFast(IndexableType, String) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Provides an opportunity to fail without an exception, but rather with a message.
- failFast(IndexableType, Throwable) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- failFast(IndexableType, Throwable) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Notifies that the process has failed and keeps track of the Throwables passed in.
- failFast(String) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
- failFast(Throwable) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Notifies that the process has failed and keeps track of the Throwables passed in.
- FieldPersistenceConsumer - Interface in com.broadleafcommerce.search.index.core.messaging
-
Spring cloud data channel description for messaging input.
- fieldPersistenceHandler(IndexerSearchService<FieldDefinition>, ObjectMapper) - Method in class com.broadleafcommerce.search.index.core.messaging.autoconfigure.IndexerMessagingAutoConfiguration
- FieldPersistenceHandler - Class in com.broadleafcommerce.search.index.core.messaging.handler
-
Clear the
FieldDefinition
cache inIndexerSearchService
if a production change has been made to a field definition. - FieldPersistenceHandler(IndexerSearchService<FieldDefinition>, ObjectMapper) - Constructor for class com.broadleafcommerce.search.index.core.messaging.handler.FieldPersistenceHandler
- findByNameContainingIgnoreCase(String, Node, Pageable, ContextInfo) - Method in interface com.broadleafcommerce.search.index.core.repository.ReindexJobRepository
-
Retrieves a paged list of reindex jobs filtered by the name
- finishedLoadingQueueTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The time taken to load the queue for this job.
- finishedProcessingQueueTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The instant in time this queue was finished processing.
- forceStop() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- forceStop() - Method in interface com.broadleafcommerce.search.index.core.master.SearchIndexMasterProcessLauncher
-
Method to forcibly stop a running index job.
- fullReindex(ReindexRequest, ContextInfo) - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
G
- generateName(ReindexRequest) - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
- GenericSearchIndexMasterProcessLauncher<T> - Class in com.broadleafcommerce.search.index.core.master
-
This is an abstract component to allow for the full reindexing of a specific index.
- GenericSearchIndexMasterProcessLauncher(ProcessStateService, LockService, QueueProvider, QueueLoader<T>, SemaphoreProvider, long) - Constructor for class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- GenericSearchIndexWorkerProcessLauncher<T> - Class in com.broadleafcommerce.search.index.core.worker
-
Abstract implementation of SearchIndexWorkerProcessLauncher.
- GenericSearchIndexWorkerProcessLauncher(IndexableType, ProcessStateService, QueueProvider, int, long, int) - Constructor for class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Deprecated, for removal: This API element is subject to removal in a future version.
- GenericSearchIndexWorkerProcessLauncher(IndexableType, ProcessStateService, QueueProvider, int, long, int, long) - Constructor for class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
- getAdditionalProperties() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Returns an unmodifiable map of all additional properties.
- getAdditionalProperties(ScheduledJobRef) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Determine the additional properties needed for a reindex
- getAdditionalProperties(DocumentContext) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Determine the additional properties needed for a reindex
- getAdditionalProperty(String) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Returns an arbitrary Object in a map, based on the provided key.
- getAllFailures() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
More than one thread may have reported an error before realizing that the process failed.
- getAllowedLocales() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- getAuthor() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The user that initiated this reindex process.
- getAuthor(ContextInfo) - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
-
Returns the user who started this full reindex.
- getBatchIdReader() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- getBatchSize() - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
-
The size of each batch to read for queue loading.
- getBatchSize(ScheduledJobRef) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Gets the batch size to use when fetching orders.
- getCacheStateManager() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- getChunkSize() - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
-
The size of each chunk to be put on the queue.
- getClassName() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Get the class name to identify this listener for handling message idempotency.
- getClassName() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Get the class name to identify this listener for handling message idempotency.
- getClusterMemberCount(IndexableType) - Method in class com.broadleafcommerce.search.index.core.DefaultProcessStateService
- getClusterMemberCount(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Returns the number of cluster members that may be working together to process data.
- getCompletionPauseTime() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
-
This is the time that the main control thread will pause on indexing process completion to allow other threads to finish what they are doing or catch up.
- getCompletionPauseTime() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
This is the time that the main control thread will pause on indexing process completion to allow other threads to finish what they are doing or catch up.
- getContributorsForIndexableType(IndexableType) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- getCorrelationId() - Method in class com.broadleafcommerce.search.index.core.event.ProcessFailedEvent
-
The ID which uniquely identifies this reindex process.
- getCorrelationId() - Method in class com.broadleafcommerce.search.index.core.event.WorkerCompletedEvent
-
The ID which uniquely identifies this reindex process.
- getCorrelationId() - Method in class com.broadleafcommerce.search.index.core.event.WorkerStartedEvent
-
The ID which uniquely identifies this reindex process.
- getCorrelationId() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
UUID that is assigned per process, per node.
- getCorrelationId(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- getCorrelationId(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
This returns the unique correlation.
- getCurrentProcessStateHolder(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- getCurrentProcessStateHolder(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Method to retrieve the current ProcessStateHolder for the currently executing process of reindexing a particular IndexableType.
- getCurrentSemaphore(IndexableType) - Method in class com.broadleafcommerce.search.index.core.DefaultSemaphoreProvider
- getCurrentSemaphore(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.SemaphoreProvider
-
Looks for an existing semaphore and returns it if available.
- getDefaultContributors() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- getDefaultJsonPathConfiguration() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- getDefaultLocale() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- getDelegate() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
-
The underlying queue which all work is delegated to.
- getDocumentContext(String) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Parses the message payload into a
DocumentContext
which allows for JsonPath parsing using Jackson providers. - getElapsedTime() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- getElapsedTime() - Method in interface com.broadleafcommerce.search.index.core.master.SearchIndexMasterProcessLauncher
-
Returns the elapsed time in millis, or -1 if the system is not running or if this is not the master instance.
- getEndDate() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
A date used to filter the reindex of items.
- getEndpoint() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- getEndpoint() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- getEndTime() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The completion time of the process
- getError() - Method in class com.broadleafcommerce.search.index.core.event.ProcessFailedEvent
-
The error which resulted in the failure of the reindex process.
- getError() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder.ProcessFailure
- getErrorMessage() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
-
The message associated with this error, populated from
Throwable.getMessage()
- getErrorMessage() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- getErrors() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
A list of errors that may have occurred during the reindex process.
- getErrorTime() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder.ProcessFailure
- getException() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
-
The fully qualified class name of this error.
- getExpectedCount() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The expected number of items to be processed (May be an estimate, such as with Products)
- getExpectedIndexableItems() - Method in class com.broadleafcommerce.search.index.core.event.QueueLoadedEvent
-
The number of indexable items expected to be processed based on the loaded queue.
- getExpectedIndexableItemsToProcess() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Get the number of expected indexable items to process.
- getFieldsByIndexableType() - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- getFinishedLoadingQueueTime() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The time taken to load the queue for this job.
- getFinishedProcessingQueueTime() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The instant in time this queue was finished processing.
- getFirstFailure() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
More than one thread can potentially report an error.
- getFirstFailureMessage() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
- getHeaders(ContextInfo) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- getId() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- getIdempotentConsumptionService() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- getIdempotentConsumptionService() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
- getIds() - Method in class com.broadleafcommerce.search.index.core.queue.BatchIdHolder
-
The IDs contained in this batch.
- getIndexableItemsProcessed() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Get the number of indexable items processed.
- getIndexablesProcessed() - Method in class com.broadleafcommerce.search.index.core.event.BatchCompletedEvent
-
The number of indexables processed in the batch.
- getIndexableType() - Method in interface com.broadleafcommerce.search.index.core.document.IndexableTypeDocumentBuilder
-
The indexable type this builder can build documents for.
- getIndexableType() - Method in interface com.broadleafcommerce.search.index.core.document.IndexableTypeDocumentBuilderContributor
-
The indexable type this builder can modify documents for.
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The IndexableType of this job (e.g.
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.event.SearchIndexProcessEvent
-
The IndexableType of the reindex process this event was generated by.
- getIndexableType() - Method in interface com.broadleafcommerce.search.index.core.IndexableTypeAware
-
Components that implement this method should return the same, non-null value on each invocation.
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Get the
IndexableType
identified for this listener. - getIndexableType() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Get the
IndexableType
identified for this listener. - getIndexableType() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
The indexable type for the reindex process this state holder belongs to.
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.queue.BatchIdHolder
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
- getIndexableType() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
- getIndexableTypeContributors() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
If any contributors have been defined for a specific
IndexableType
via anIndexableTypeDocumentBuilderContributor
, then the contributors listed here will be used instead ofAbstractDocumentBuilder.defaultContributors
. - getInstance(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
-
Get the process state holder for the given indexable type.
- getJsonPathConfiguration() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- getLastUpdated() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The last update time of the process
- getLoadMaxTries() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Defines the number of times that we'll try to put something from a bounded BlockingQueue with the given wait time before giving up, for example when nothing is reading from the Queue.
- getLoadWaitTime() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Time in milliseconds to wait put something on a bounded BlockingQueue.
- getLocalesByTenantId() - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- getLocalFieldDefCacheSize() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
The maximum size of the
LRUMap
that is used for local cachingFieldDefinitions
during reindexing. - getLockService() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- getMaxQueueSize() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
The maximum allowed size of the queue.
- getMaxTries() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Defines the number of times that we'll try to put something from a bounded BlockingQueue with the given wait time before giving up, for example when nothing is reading from the Queue.
- getMaxTries() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
-
Defines the number of times that we'll try to retrieve something from a queue with the given wait time before giving up.
- getMaxTries() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Defines the number of times that we'll try to retrieve something from a queue with the given wait time before giving up.
- getMessage() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder.ProcessFailure
- getName() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The display name which will identify this job to admin users.
- getName() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
The requested name to identify the requested reindex to administrators.
- getNodeCount() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The number of nodes involved in the reindex process.
- getNodeCount() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Get the number of nodes that workers are running on.
- getObjectMapper() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- getObjectMapper() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
- getObjectMapper() - Method in class com.broadleafcommerce.search.index.core.messaging.handler.FieldPersistenceHandler
- getObjectMapper() - Method in class com.broadleafcommerce.search.index.core.messaging.handler.TenantPersistenceHandler
- getObjectMapper() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- getOrCreateQueue(IndexableType) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueProvider
- getOrCreateQueue(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.queue.QueueProvider
-
Get the Queue for the given
IndexableType
. - getPauseBetweenThreadsStart() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
-
Time in millis between 2 threads are started.
- getPauseBetweenThreadsStart() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Time in millis between 2 threads are started.
- getPayload(Message<ScheduledJobRef>) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Get the message payload and customize it if needed.
- getPayload(Message<String>) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Get the message payload and customize it if needed.
- getPreProcessors() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- getProcessedCount() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The number of items processed during the full reindex.
- getProcessLauncherMap() - Method in class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.event.listener.BatchCompletedEventListener
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.event.listener.ProcessCompleteEventListener
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.event.listener.ProcessFailedEventListener
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.event.listener.ProcessStartedEventListener
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
- getProcessStateService() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
- getQueue() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- getQueue() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
- getQueueLoadTime() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- getQueueName() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- getQueueName() - Method in interface com.broadleafcommerce.search.index.core.queue.ReindexQueue
-
Any arbitrary Queue name.
- getQueueProcessTime() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- getQueueProvider() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- getQueueProvider() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
- getQueueRegistry() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueProvider
-
Get the registry map registering
ReindexQueue
toIndexableType
. - getQueueSize() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueProvider
-
The maximum allowed size of the queue.
- getRatePerSecond() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- getReadFieldsPath() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- getReadFieldsPath() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- getReadMaxTries() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Defines the number of times that we'll try to retrieve something from a queue with the given wait time before giving up.
- getReadTenantsPath() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- getReadTenantsPath() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
- getReadWaitTime() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Time in milliseconds to wait for something to arrive in the Queue.
- getReindexDelegationService() - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
- getReindexDelegationService() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- getReindexDelegationService() - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
- getReindexJobService() - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexJobStatusEndpoint
- getReindexService() - Method in class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- getSearch() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- getSearchFieldService() - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- getSearchService() - Method in class com.broadleafcommerce.search.index.core.messaging.handler.FieldPersistenceHandler
- getSearchServiceEndpoint() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- getSemaphore() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
- getSemaphoreProvider() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- getService() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties
- getService() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties
- getServiceClient() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- getServiceClient() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- getServiceClient() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
-
The service client to use when calling inventory services.
- getServiceClient() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
-
The service client to use when calling inventory services.
- getStartDate() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
A date used to filter the reindex of items.
- getStartDate(ScheduledJobRef) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Gets the starting date to read the
Indexables
from the givenScheduledJobRef.getDetails()
. - getStartTime() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The start time of the process
- getStatus() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The current status of the reindex process.
- getStatus() - Method in enum class com.broadleafcommerce.search.index.core.domain.ReindexStatus
- getSupportedSimpleTypeNames() - Method in class com.broadleafcommerce.search.index.core.messaging.handler.FieldPersistenceHandler
- getSupportedSimpleTypeNames() - Method in class com.broadleafcommerce.search.index.core.messaging.handler.TenantPersistenceHandler
- getTenant() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- getTenantService() - Method in class com.broadleafcommerce.search.index.core.messaging.handler.TenantPersistenceHandler
- getTenantServiceEndpoint() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
- getThreadCount() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The total number of threads used across all nodes.
- getThreads() - Method in class com.broadleafcommerce.search.index.core.event.WorkerStartedEvent
-
The number of threads executing for this worker.
- getTime() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
-
The time (Approximate) that this error occurred.
- getTimeStartedMillis() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
The time the process state holder was created.
- getTokenResponse(OAuth2ClientCredentialsGrantRequest) - Method in class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.OAuth2ClientCredentialsAccessTokenResponseClient
- getTotalThreadCount() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Get the number of worker threads across all nodes.
- getType() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
The
IndexableType
for which the reindex is requested. - getType() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
- getTypeFactory() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- getUTC_TIMESTAMP_FORMATTER() - Static method in class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
- getWaitTime() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Time in milliseconds to wait put something on a bounded BlockingQueue.
- getWaitTime() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
-
Time in milliseconds to wait for something to arrive in the Queue.
- getWaitTime() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Time in milliseconds to wait for something to arrive in the Queue.
- getWebClient() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- getWebClient() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
- getWebClientBufferLimitInBytes() - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerWebClientProperties
-
When a Solr collection is indexed, we make use of a
WebClient
to make batched calls to gather the indexable objects. - getWorkerThreads() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
-
The number of worker threads which should be started on a reindex process.
- getWorkerThreads() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
The number of worker threads which should be started on a reindex process.
H
- handleMessageInternal(Message<ScheduledJobRef>) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Message listener entry point.
- handleMessageInternal(Message<String>) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Message listener entry point.
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerWebClientProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
- hashCode() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- hashCode() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
- hashCode() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder.ProcessFailure
- hashCode() - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.SSLVerificationProperties
- hashCode() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- hook(String) - Method in class com.broadleafcommerce.search.index.core.messaging.handler.FieldPersistenceHandler
- hook(String) - Method in class com.broadleafcommerce.search.index.core.messaging.handler.TenantPersistenceHandler
- hydrateBackReferences(List<FieldDefinition>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
I
- id(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
- IN_PROGRESS - Enum constant in enum class com.broadleafcommerce.search.index.core.domain.ReindexStatus
- incrementIndexableItemsProcessed() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Increment the number of indexable items processed.
- incrementIndexableItemsProcessed(long) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Increment the number of indexable items processed by the given value.
- incrementNodeCount() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Increment the number of nodes that workers are running on.
- incrementOrDecrementIntPropertyVal(String, int) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Provides a thread-safe, atomic way to increment an arbitrary Integer value in the additional properties map.
- incrementOrDecrementLongPropertyVal(String, long) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Provides a thread-safe, atomic way to increment an arbitrary
Number
value in the additional properties map. - incrementTotalThreadCount(int) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Increment the number of worker threads across all nodes.
- INDEX_TYPE_PATH - Static variable in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- indexableType(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The IndexableType of this job (e.g.
- IndexableTypeAware - Interface in com.broadleafcommerce.search.index.core
-
Standard interface to allow components to return the IndexableType that they can operate on.
- IndexableTypeDocumentBuilder<I extends com.broadleafcommerce.search.api.domain.Indexable<?>,
T> - Interface in com.broadleafcommerce.search.index.core.document -
Identifies a
DocumentBuilder
which only applies to a specific indexable type. - IndexableTypeDocumentBuilderContributor<T> - Interface in com.broadleafcommerce.search.index.core.document
-
Identifies a
DocumentBuilderContributor
which only applies to a specific indexable type. - IndexCacheProperties - Class in com.broadleafcommerce.search.index.core.cache
-
Properties that influence cache settings for the indexer service
- IndexCacheProperties() - Constructor for class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- INDEXER_ROUTE_KEY - Static variable in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- INDEXER_ROUTE_KEY - Static variable in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
- IndexerCacheAutoConfiguration - Class in com.broadleafcommerce.search.index.core.service.autoconfigure
-
Configuration for engaging default Broadleaf support for Apache Ignite cache
- IndexerCacheAutoConfiguration() - Constructor for class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCacheAutoConfiguration
- indexerCacheManagerCustomizer(IgniteConfigurers.BasicIgniteConfigurer, IndexCacheProperties) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCacheAutoConfiguration
- IndexerCoreEndpointAutoConfiguration - Class in com.broadleafcommerce.search.index.core.endpoint.autoconfigure
- IndexerCoreEndpointAutoConfiguration() - Constructor for class com.broadleafcommerce.search.index.core.endpoint.autoconfigure.IndexerCoreEndpointAutoConfiguration
- IndexerCoreEnvironmentPostProcessor - Class in com.broadleafcommerce.search.index.autoconfigure
- IndexerCoreEnvironmentPostProcessor() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.IndexerCoreEnvironmentPostProcessor
- IndexerCoreServiceAutoConfiguration - Class in com.broadleafcommerce.search.index.core.service.autoconfigure
- IndexerCoreServiceAutoConfiguration() - Constructor for class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCoreServiceAutoConfiguration
- IndexerMessagingAutoConfiguration - Class in com.broadleafcommerce.search.index.core.messaging.autoconfigure
- IndexerMessagingAutoConfiguration() - Constructor for class com.broadleafcommerce.search.index.core.messaging.autoconfigure.IndexerMessagingAutoConfiguration
- IndexerMessagingAutoConfiguration.IndexerMessagingBindingAutoConfiguration - Class in com.broadleafcommerce.search.index.core.messaging.autoconfigure
- IndexerMessagingBindingAutoConfiguration() - Constructor for class com.broadleafcommerce.search.index.core.messaging.autoconfigure.IndexerMessagingAutoConfiguration.IndexerMessagingBindingAutoConfiguration
- indexerOauth2FilterFunctionSupplier(ClientRegistrationRepository, SSLVerificationProperties) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCoreServiceAutoConfiguration
-
We'll leave this with a general name as it can (and should) be reused in a flex package.
- IndexerProperties - Class in com.broadleafcommerce.search.index.autoconfigure
-
Properties used for indexer configuration.
- IndexerProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- IndexerProperties.QueueProperties - Class in com.broadleafcommerce.search.index.autoconfigure
- IndexerProperties.SearchProperties - Class in com.broadleafcommerce.search.index.autoconfigure
- IndexerProperties.SearchProperties.ServiceProperties - Class in com.broadleafcommerce.search.index.autoconfigure
- IndexerProperties.TenantProperties - Class in com.broadleafcommerce.search.index.autoconfigure
-
The service client to use when interacting with the search service.
- IndexerProperties.TenantProperties.ServiceProperties - Class in com.broadleafcommerce.search.index.autoconfigure
- indexerSearchService(WebClient, IndexerProperties, ObjectMapper, CacheStateManager) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCoreServiceAutoConfiguration
- IndexerSearchService<T extends com.broadleafcommerce.search.api.domain.FieldDefinition> - Interface in com.broadleafcommerce.search.index.core.service
-
Service used by the search indexer to interact with the search service.
- indexerTenantPersistenceHandler(IndexerTenantService, ObjectMapper) - Method in class com.broadleafcommerce.search.index.core.messaging.autoconfigure.IndexerMessagingAutoConfiguration
- indexerTenantService(WebClient, IndexerProperties) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCoreServiceAutoConfiguration
- IndexerTenantService - Interface in com.broadleafcommerce.search.index.core.service
-
Used by search indexer to retrieve locales from the tenant service.
- indexerWebClient(Supplier<ServletOAuth2AuthorizedClientExchangeFilterFunction>, ObjectMapper, SSLVerificationProperties) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCoreServiceAutoConfiguration
- initialize() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
- initialize() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
This will be called exactly once prior to a call to readPage.
- instance(IndexableType) - Static method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
Convenient way to access the
SearchIndexMasterProcessLauncher
associated with a particular IndexableType. - instance(IndexableType) - Static method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Convenient way to access the SearchIndexWorkerProcessLauncher associated with a particular IndexableType.
- isActive() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- isActive() - Method in interface com.broadleafcommerce.search.index.core.master.SearchIndexMasterProcessLauncher
-
Indicates if this process is currently executing.
- isActive() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
- isActive() - Method in interface com.broadleafcommerce.search.index.core.worker.SearchIndexWorkerProcessLauncher
-
Indicates if this process is currently executing.
- isDisabled() - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.SSLVerificationProperties
-
Dictates whether SSL verification should be disabled.
- isDistributed() - Method in class com.broadleafcommerce.search.index.core.DefaultLocalJvmLockService
- isDistributed() - Method in class com.broadleafcommerce.search.index.core.DefaultProcessStateService
- isDistributed() - Method in interface com.broadleafcommerce.search.index.core.Distributable
-
Indicates if this component is designed for use across JVMs.
- isDistributed() - Method in class com.broadleafcommerce.search.index.core.queue.DefaultLocalArrayBlockingDelegatingQueue
- isDistributed() - Method in class com.broadleafcommerce.search.index.core.queue.DefaultLocalQueueProvider
- isEmpty() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- isEnablePartialIndexWithFilters() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
Determines if the current reindex request has potential filters to limit the items indexed.
- isExecuting() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Whether or not this is currently executing.
- isFailed() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Indicates if the process has been notified as failing by one or more threads.
- isFailed(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- isFailed(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Indicates if the process has been notified as failing by one or more threads.
- isLoaded() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- isLoaded() - Method in interface com.broadleafcommerce.search.index.core.queue.ReindexQueue
-
Indicates whether more data will be added to the Queue.
- isLocked(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.LockService
-
Uses the provided
IndexableType
to find the lock. - isLocked(String) - Method in class com.broadleafcommerce.search.index.core.DefaultLocalJvmLockService
- isLocked(String) - Method in interface com.broadleafcommerce.search.index.core.LockService
-
Checks to see if a lock has already been acquired for the referenced object.
- isMaster() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Indicates if this JVM kicked off the process for this IndexableType.
- isMaster(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- isMaster(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Indicates if this JVM kicked off the process for this IndexableType.
- isProcessStateEnabled(IndexableType) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- isProcessStateEnabled(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Indicates if any thread has started a process state associated with this IndexableType, and not stopped it.
- isRunning() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Whether the loader is currently loading values into the queue.
- isUseAllTenants() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
A toggle used to filter the reindex of items.
- iterator() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
L
- lastUpdated(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The last update time of the process
- launchWorkers() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
- launchWorkers() - Method in interface com.broadleafcommerce.search.index.core.worker.SearchIndexWorkerProcessLauncher
-
Method to begin work by worker or slave processes.
- LOCAL_FIELD_DEFINITION_CACHE_NAME - Static variable in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
- LOCALES_CACHE_BY_TENANT_ID - Static variable in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
- lock(String) - Method in interface com.broadleafcommerce.search.index.core.LockService
-
Deprecated.
- LockException - Exception in com.broadleafcommerce.search.index.core
-
Indicates an error locking or unlocking the reindex process.
- LockException() - Constructor for exception com.broadleafcommerce.search.index.core.LockException
-
Constructs a new exception with
null
as its detail message. - LockException(String) - Constructor for exception com.broadleafcommerce.search.index.core.LockException
-
Constructs a new exception with the specified detail message.
- LockException(String, Throwable) - Constructor for exception com.broadleafcommerce.search.index.core.LockException
-
Constructs a new exception with the specified detail message and cause.
- LockException(String, Throwable, boolean, boolean) - Constructor for exception com.broadleafcommerce.search.index.core.LockException
-
Constructs a new exception with the specified detail message, cause, suppression enabled or disabled, and writable stack trace enabled or disabled.
- LockException(Throwable) - Constructor for exception com.broadleafcommerce.search.index.core.LockException
-
Constructs a new exception with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
- LockService - Interface in com.broadleafcommerce.search.index.core
-
Basic LockService interface, specifically to be used by the Index processes to ensure that no other threads or nodes can start a specific full index process.
M
- markLoaded() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- markLoaded() - Method in interface com.broadleafcommerce.search.index.core.queue.ReindexQueue
-
Mark that there is no more data to add to this queue.
N
- name(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The display name which will identify this job to admin users.
- NAME_KEY - Static variable in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Key for the name of a reindex job.
- NAME_KEY_PATH - Static variable in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
- nodeCount(Integer) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The number of nodes involved in the reindex process.
- NullReindexJobService - Class in com.broadleafcommerce.search.index.core.service
-
Null implementation for ReindexJob tracking if no implementation that supports persistence is defined.
- NullReindexJobService() - Constructor for class com.broadleafcommerce.search.index.core.service.NullReindexJobService
O
- OAuth2ClientCredentialsAccessTokenResponseClient - Class in com.broadleafcommerce.search.index.core.oauth2.client.endpoint
-
Alternative to
DefaultClientCredentialsTokenResponseClient
that usesWebClient
and allows for access token response that contain additional non-String parameters. - OAuth2ClientCredentialsAccessTokenResponseClient(WebClient) - Constructor for class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.OAuth2ClientCredentialsAccessTokenResponseClient
- obtainLockInstance(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.LockService
-
Provides a lock instance for the name provided by the provided
IndexableType
. - obtainLockInstance(String) - Method in class com.broadleafcommerce.search.index.core.DefaultLocalJvmLockService
- obtainLockInstance(String) - Method in interface com.broadleafcommerce.search.index.core.LockService
-
This returns an instance of
Lock
, specifically for use with the specified lock name. - obtainLockInterally(String) - Method in class com.broadleafcommerce.search.index.core.DefaultLocalJvmLockService
- offer(T) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- offer(T, long, TimeUnit) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- onApplicationEvent(BatchCompletedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.BatchCompletedEventListener
- onApplicationEvent(ProcessCompletedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.ProcessCompleteEventListener
- onApplicationEvent(ProcessFailedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.ProcessFailedEventListener
- onApplicationEvent(ProcessStartedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.ProcessStartedEventListener
- onApplicationEvent(QueueCreatedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.QueueCreatedEventListener
- onApplicationEvent(QueueLoadedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.QueueLoadedEventListener
- onApplicationEvent(WorkerCompletedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.WorkerCompletedEventListener
- onApplicationEvent(WorkerStartedEvent) - Method in class com.broadleafcommerce.search.index.core.event.listener.WorkerStartedEventListener
P
- pause() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
Pause this thread for the determined completionPauseTime.
- peek() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- performFullReindex(IndexableType) - Method in class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- performFullReindex(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexDelegationService
-
Performs a full reindex on a specific type.
- performFullReindex(IndexableType, Map<String, Serializable>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- performFullReindex(IndexableType, Map<String, Serializable>) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexDelegationService
-
Performs a full reindex on a specific type.
- persistenceInputField() - Method in interface com.broadleafcommerce.search.index.core.messaging.FieldPersistenceConsumer
- poll() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- poll(long, TimeUnit) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- populateDocument(Indexable<?>, T, List<FieldDefinition>, DocumentContext) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
Populate the document for the indexable with the given fields.
- populateQueue(ReindexQueue<T>, ProcessStateHolder) - Method in interface com.broadleafcommerce.search.index.core.queue.QueueLoader
-
Reads T from a source (e.g.
- populateQueue(ReindexQueue<TO>, ProcessStateHolder) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
- postProcessEnvironment(ConfigurableEnvironment, SpringApplication) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerCoreEnvironmentPostProcessor
- preProcess(List<? extends Indexable<?>>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilderPreProcessor
- preProcess(List<? extends Indexable<?>>) - Method in interface com.broadleafcommerce.search.index.core.document.DocumentBuilderPreProcessor
-
Process a collection of indexables sharing the same contextId with information which depends on the context of the other indexables.
- preProcessInternal(List<? extends Indexable<?>>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilderPreProcessor
-
Process a collection of indexables sharing the same contextId with information which depends on the context of the other indexables.
- process(ReindexQueue<T>, ProcessStateHolder) - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
Method to populate the
ReindexQueue
with data. - ProcessCompletedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Event to notify that the reindex process has been completed.
- ProcessCompletedEvent(IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessCompletedEvent
- ProcessCompletedEvent(Object, IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessCompletedEvent
- ProcessCompleteEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
ProcessCompletedEvent
, and ends the current process state. - ProcessCompleteEventListener(ProcessStateService) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.ProcessCompleteEventListener
- processedCount(Long) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The number of items processed during the full reindex.
- ProcessFailedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Event to notify that an error occurred during the reindex process.
- ProcessFailedEvent(IndexableType, String, Throwable) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessFailedEvent
- ProcessFailedEvent(Object, IndexableType, String, Throwable) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessFailedEvent
- ProcessFailedEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
ProcessFailedEvent
, and instructs theProcessStateHolder
to fail fast. - ProcessFailedEventListener(ProcessStateService) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.ProcessFailedEventListener
- processMessage(Message<ScheduledJobRef>) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Processes the received scheduled job message by reading the list of
Indexables
since the configured starting date and reindexing them. - processMessage(Message<String>) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Processes the received message by extracting fields relevant to executing a full re-index
- ProcessStartedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Event to indicate that a reindex process has started for a given
IndexableType
. - ProcessStartedEvent(IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessStartedEvent
- ProcessStartedEvent(Object, IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessStartedEvent
- ProcessStartedEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
ProcessStartedEvent
. - ProcessStartedEventListener(ProcessStateService) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.ProcessStartedEventListener
- processStateChange(JsonNode) - Method in class com.broadleafcommerce.search.index.core.messaging.handler.FieldPersistenceHandler
- processStateChange(JsonNode) - Method in class com.broadleafcommerce.search.index.core.messaging.handler.TenantPersistenceHandler
- ProcessStateHolder - Class in com.broadleafcommerce.search.index.core
-
This component is a container for allowing thread-safe access to state across a global, in JVM process (e.g.
- ProcessStateHolder(IndexableType, boolean) - Constructor for class com.broadleafcommerce.search.index.core.ProcessStateHolder
- ProcessStateHolder.ProcessFailure - Class in com.broadleafcommerce.search.index.core
- ProcessStateService - Interface in com.broadleafcommerce.search.index.core
-
Component to track the state of a given reindex process.
- ProcessSuccessEvent - Class in com.broadleafcommerce.search.index.core.event
-
Event to indicate if the reindex process completed without errors.
- ProcessSuccessEvent(IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessSuccessEvent
- ProcessSuccessEvent(Object, IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.ProcessSuccessEvent
- publishEvent(SearchIndexProcessEvent) - Method in class com.broadleafcommerce.search.index.core.DefaultProcessStateService
- publishEvent(SearchIndexProcessEvent) - Method in interface com.broadleafcommerce.search.index.core.EventPublisher
-
Lightweight interface to publish an event.
- put(T) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
Q
- QueueCreatedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Event to notify that a Queue is ready for use.
- QueueCreatedEvent(IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.QueueCreatedEvent
- QueueCreatedEvent(Object, IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.QueueCreatedEvent
- QueueCreatedEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
QueueCreatedEvent
, and trigger theSearchIndexWorkerProcessLauncher
to start new workers for the queue. - QueueCreatedEventListener(ProcessStateService) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.QueueCreatedEventListener
- QueueCreatedEventListener(ProcessStateService, boolean) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.QueueCreatedEventListener
- QueueLoadedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Event to indicate that the ID queue has been loaded and there is no more data to load.
- QueueLoadedEvent(IndexableType, long) - Constructor for class com.broadleafcommerce.search.index.core.event.QueueLoadedEvent
- QueueLoadedEvent(Object, IndexableType, long) - Constructor for class com.broadleafcommerce.search.index.core.event.QueueLoadedEvent
- QueueLoadedEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
QueueLoadedEvent
, and update theProcessStateHolder
with the expected number of items to process based on the loading event. - QueueLoadedEventListener(QueueProvider, ProcessStateService) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.QueueLoadedEventListener
- QueueLoader<T> - Interface in com.broadleafcommerce.search.index.core.queue
-
The purpose of this component is to coordinate or gather values from a data source or web service to put on a
ReindexQueue
for processing. - QueueProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
- QueueProvider - Interface in com.broadleafcommerce.search.index.core.queue
-
Component to provide access to a Queue, or specifically a
ReindexQueue
.
R
- readAll() - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- readAll(Pageable) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- readAll(Sort) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- readAllByIds(Iterable<String>) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- readAllByNameContaining(String, Node, Pageable, ContextInfo) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- readAllByNameContaining(String, Node, Pageable, ContextInfo) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Retrieves a paged list of reindex jobs filtered by the name
- readAllJobStatuses(Pageable, ContextInfo, String, Node) - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexJobStatusEndpoint
- readByActiveStatus(boolean, Pageable, ContextInfo) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- readByActiveStatus(boolean, Pageable, ContextInfo) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Returns either active or inactive
ReindexJobs
. - readById(String) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- readByStatus(ReindexStatus, Pageable, ContextInfo) - Method in interface com.broadleafcommerce.search.index.core.repository.ReindexJobRepository
-
Returns Reindex jobs whose
status
equals the value. - readByStatusNot(ReindexStatus, Pageable, ContextInfo) - Method in interface com.broadleafcommerce.search.index.core.repository.ReindexJobRepository
- readCombinedMultiValuePath(DocumentContext, String, List<String>, String) - Method in class com.broadleafcommerce.search.index.core.document.helper.DefaultDocumentBuilderHelper
-
Read the values at the root path on the given context object, using a combination of paths to produce a single delimited value for each of them.
- readCombinedSingleValuePath(DocumentContext, List<String>, String) - Method in class com.broadleafcommerce.search.index.core.document.helper.DefaultDocumentBuilderHelper
-
Read the value at the path on the given context object, using a combination of paths to produce a single delimited value.
- readFieldsByIndexable(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- readFieldsByIndexable(Indexable<?>) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerSearchService
-
Returns a list of Search fields by
Indexable
. - readFieldsByIndexable(Indexable<?>, ContextInfo) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- readFieldsByIndexable(Indexable<?>, ContextInfo) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerSearchService
-
Returns a list of Search fields by
Indexable
. - readFieldsByIndexableType(IndexableType) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
-
Deprecated.
- readFieldsByIndexableType(IndexableType) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerSearchService
-
Deprecated.
- readFieldsByIndexableType(IndexableType, ContextInfo) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- readFieldsByIndexableType(IndexableType, ContextInfo) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerSearchService
-
Returns a list of Search fields by IndexableType and
ContextInfo
, if applicable. - readFieldsByIndexableType(String) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
-
Deprecated.
- readFieldsByIndexableType(String, ContextInfo) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- readFieldsForIndexable(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
This adds a layer of primary caching to
FieldDefinitions
while full reindexing is occurring. - readIndexablesSinceDate(ScheduledJobRef, Instant, String, int) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
-
Reads the list of
Indexables
since the given date. - readJobById(String, ContextInfo) - Method in class com.broadleafcommerce.search.index.core.endpoint.ReindexJobStatusEndpoint
- readLocalesByTenantId(String) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
-
Deprecated.
- readLocalesByTenantId(String) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerTenantService
-
Returns a list of locales for the tenant with the given ID.
- readLocalesByTenantId(String, boolean) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
- readLocalesByTenantId(String, boolean) - Method in interface com.broadleafcommerce.search.index.core.service.IndexerTenantService
-
Returns a list of locales for the tenant with the given ID.
- readPage() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
- readPage() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Deprecated.in favor of
AbstractQueueLoader.readPage(ProcessStateHolder)
for the potential to utilize a additional process information. - readPage(ProcessStateHolder) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
- readPage(ProcessStateHolder) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Reads paged data to, optionally, transform and put on a
BlockingQueue
. - readPagedIds(ID, int) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
-
Reads pages of IDs.
- readPagedIds(ID, int, Map<String, Object>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
-
Reads pages of IDs.
- readValueByPath(DocumentContext, FieldDefinition) - Method in class com.broadleafcommerce.search.index.core.document.helper.DefaultDocumentBuilderHelper
-
Read the value of the field from the given context object.
- readValueByPath(DocumentContext, FieldDefinition) - Method in interface com.broadleafcommerce.search.index.core.document.helper.DocumentBuilderHelper
-
Read the value of the field from the given context object.
- readValueByPath(DocumentContext, String) - Method in class com.broadleafcommerce.search.index.core.document.helper.DefaultDocumentBuilderHelper
-
Read the value at the path on the given context object.
- readValueByPath(DocumentContext, String) - Method in interface com.broadleafcommerce.search.index.core.document.helper.DocumentBuilderHelper
-
Read the value at the path on the given context object.
- rebuildIndex() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- rebuildIndex() - Method in interface com.broadleafcommerce.search.index.core.master.SearchIndexMasterProcessLauncher
-
Rebuilds an entire index.
- rebuildIndex(Map<String, Serializable>) - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
The default behavior here is check whether this process is already running, and if not, delegate to a background thread.
- rebuildIndex(Map<String, Serializable>) - Method in interface com.broadleafcommerce.search.index.core.master.SearchIndexMasterProcessLauncher
-
Rebuilds an entire index.
- registerSearchIndexMasterProcessLauncher(SearchIndexMasterProcessLauncher) - Static method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
-
This is a static method to register new SearchIndexMasterProcessLauncher objects.
- registerSearchIndexWorkerProcessLauncher(SearchIndexWorkerProcessLauncher) - Static method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
-
Allows registration of a SearchIndexWorkerProcessLauncher that does not extend
GenericSearchIndexWorkerProcessLauncher
. - reindex(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- reindex(Indexable<?>) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexDelegationService
-
Indexes a single Indexable immediately to the primary collection.
- reindex(List<? extends Indexable<?>>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- reindex(List<? extends Indexable<?>>) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexDelegationService
-
Indexes multiple Indexables immediately to the primary collection.
- reindex(List<? extends Indexable<?>>) - Method in interface com.broadleafcommerce.search.index.core.service.ReindexService
-
Indexes or reindexes the provided
Indexable
objects. - reindexDelegationService(List<SearchIndexMasterProcessLauncher>, List<SearchIndexWorkerProcessLauncher>, ReindexService) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCoreServiceAutoConfiguration
- ReindexDelegationService - Interface in com.broadleafcommerce.search.index.core.service
-
Generic intermediary reindex implementation that delegates to implementation specific index functionality.
- reindexEndpoint(ReindexDelegationService) - Method in class com.broadleafcommerce.search.index.core.endpoint.autoconfigure.IndexerCoreEndpointAutoConfiguration
- ReindexEndpoint - Class in com.broadleafcommerce.search.index.core.endpoint
- ReindexEndpoint(ReindexDelegationService) - Constructor for class com.broadleafcommerce.search.index.core.endpoint.ReindexEndpoint
- ReindexErrorDetails - Class in com.broadleafcommerce.search.index.core.domain
- ReindexErrorDetails() - Constructor for class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
- ReindexErrorDetails(String, String, Instant) - Constructor for class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
- ReindexJob - Class in com.broadleafcommerce.search.index.core.domain
-
Contains details of an in progress or completed full reindex.
- ReindexJob() - Constructor for class com.broadleafcommerce.search.index.core.domain.ReindexJob
- ReindexJob(String, String, String, String, Instant, Instant, Instant, Instant, Instant, Long, Long, Integer, Integer, ReindexStatus, List<ReindexErrorDetails>) - Constructor for class com.broadleafcommerce.search.index.core.domain.ReindexJob
- ReindexJob.ReindexJobBuilder - Class in com.broadleafcommerce.search.index.core.domain
- reindexJobEndpoint(ReindexJobService<ReindexJob>) - Method in class com.broadleafcommerce.search.index.core.endpoint.autoconfigure.IndexerCoreEndpointAutoConfiguration
- ReindexJobRepository<D extends com.broadleafcommerce.data.tracking.core.Identifiable> - Interface in com.broadleafcommerce.search.index.core.repository
- reindexJobService() - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.IndexerCoreServiceAutoConfiguration
- ReindexJobService<P extends ReindexJob> - Interface in com.broadleafcommerce.search.index.core.service
-
Service API for
ReindexJob
- ReindexJobStatusEndpoint - Class in com.broadleafcommerce.search.index.core.endpoint
- ReindexJobStatusEndpoint(ReindexJobService<ReindexJob>) - Constructor for class com.broadleafcommerce.search.index.core.endpoint.ReindexJobStatusEndpoint
- ReindexQueue<T> - Interface in com.broadleafcommerce.search.index.core.queue
-
Interface to define a Queue.
- ReindexRequest - Class in com.broadleafcommerce.search.index.core.domain
-
Payload object representing a request to fully reindex an indexable type.
- ReindexRequest() - Constructor for class com.broadleafcommerce.search.index.core.domain.ReindexRequest
- ReindexRequest(String, IndexableType, boolean, Instant, Instant, boolean) - Constructor for class com.broadleafcommerce.search.index.core.domain.ReindexRequest
- ReindexService - Interface in com.broadleafcommerce.search.index.core.service
-
Implementation specific logic for reindexing documents in real time.
- ReindexStatus - Enum Class in com.broadleafcommerce.search.index.core.domain
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class com.broadleafcommerce.search.index.core.BlockingRejectedExecutionHandler
- remainingCapacity() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- remove() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- remove(Object) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- removeAdditionalProperty(String) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Allows callers to remove an arbitrary entry from a map.
- removeAll(Collection<?>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- replace(String, ReindexJob) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- replaceAll(List<Update<ReindexJob>>) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- replaceAllAllowingPartialSuccess(List<Update<ReindexJob>>) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- retainAll(Collection<?>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- run() - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
- run() - Method in class com.broadleafcommerce.search.index.core.worker.AbstractWorker
- run() - Method in class com.broadleafcommerce.search.index.core.worker.GenericSearchIndexWorkerProcessLauncher
S
- SearchIndexMasterProcessLauncher - Interface in com.broadleafcommerce.search.index.core.master
-
Interface for launching a reindex process.
- SearchIndexProcessEvent - Class in com.broadleafcommerce.search.index.core.event
-
Generic, abstract event for reindex processes.
- SearchIndexProcessEvent(IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.SearchIndexProcessEvent
- SearchIndexProcessEvent(Object, IndexableType) - Constructor for class com.broadleafcommerce.search.index.core.event.SearchIndexProcessEvent
- SearchIndexWorkerProcessLauncher - Interface in com.broadleafcommerce.search.index.core.worker
-
Component to kick off any background processes, either local or remote.
- SearchProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties
- searchReindexerBatchCompletedEventListener(ProcessStateService) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerLockService() - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerProcessCompletedEventListener(ProcessStateService) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerProcessCompleteEventListener(ProcessStateService) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerProcessFailedEventListener(ProcessStateService) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerProcessStateService() - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerQueueCreatedEventListener(ProcessStateService) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerQueueLoadedEventListener(QueueProvider, ProcessStateService) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerQueueProvider(IndexerProperties) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexerWorkerCompletedEventListener(ProcessStateService, SemaphoreProvider) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchReindexSemaphoreProvider() - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- searchWorkerStartedEventListener(ProcessStateService) - Method in class com.broadleafcommerce.search.index.autoconfigure.CoreIndexerAutoConfiguration
- SemaphoreProvider - Interface in com.broadleafcommerce.search.index.core
-
Simple interface to provide shared access to a Semaphore.
- ServiceProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- ServiceProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- setAdditionalProperty(String, Serializable) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Allows callers to set arbitrary state with key/value pairs for a particular process.
- setAllowedLocales(List<Locale>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- setApplicationContext(ApplicationContext) - Method in class com.broadleafcommerce.search.index.core.DefaultProcessStateService
- setAuthor(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The user that initiated this reindex process.
- setAuthorizationFailureHandler(OAuth2AuthorizationFailureHandler) - Method in class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.SynchronizedDelegatingOAuth2AuthorizedClientManager
- setAuthorizationSuccessHandler(OAuth2AuthorizationSuccessHandler) - Method in class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.SynchronizedDelegatingOAuth2AuthorizedClientManager
- setAuthorizedClientProvider(OAuth2AuthorizedClientProvider) - Method in class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.SynchronizedDelegatingOAuth2AuthorizedClientManager
- setBatchSize(int) - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
-
The size of each batch to read for queue loading.
- setChunkSize(int) - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
-
The size of each chunk to be put on the queue.
- setCompletionPauseTime(long) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
-
This is the time that the main control thread will pause on indexing process completion to allow other threads to finish what they are doing or catch up.
- setContextAttributesMapper(Function<OAuth2AuthorizeRequest, Map<String, Object>>) - Method in class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.SynchronizedDelegatingOAuth2AuthorizedClientManager
- setDefaultLocale(Locale) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- setDisabled(boolean) - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.SSLVerificationProperties
-
Dictates whether SSL verification should be disabled.
- setEnablePartialIndexWithFilters(boolean) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
Determines if the current reindex request has potential filters to limit the items indexed.
- setEndDate(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
A date used to filter the reindex of items.
- setEndpoint(String) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- setEndpoint(String) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- setEndTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The completion time of the process
- setErrorMessage(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
-
The message associated with this error, populated from
Throwable.getMessage()
- setErrors(List<ReindexErrorDetails>) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
A list of errors that may have occurred during the reindex process.
- setException(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
-
The fully qualified class name of this error.
- setExpectedCount(Long) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The expected number of items to be processed (May be an estimate, such as with Products)
- setExpectedIndexableItemsToProcess(long) - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder
-
Set the number of expected indexable items to process.
- setFieldsByIndexableType(Duration) - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- setFinishedLoadingQueueTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The time taken to load the queue for this job.
- setFinishedProcessingQueueTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The instant in time this queue was finished processing.
- setId(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- setIndexableType(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The IndexableType of this job (e.g.
- setLastUpdated(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The last update time of the process
- setLoadMaxTries(int) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Defines the number of times that we'll try to put something from a bounded BlockingQueue with the given wait time before giving up, for example when nothing is reading from the Queue.
- setLoadWaitTime(long) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Time in milliseconds to wait put something on a bounded BlockingQueue.
- setLocalesByTenantId(Duration) - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- setMaxQueueSize(int) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
The maximum allowed size of the queue.
- setName(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The display name which will identify this job to admin users.
- setName(String) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
The requested name to identify the requested reindex to administrators.
- setNodeCount(Integer) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The number of nodes involved in the reindex process.
- setPauseBetweenThreadsStart(long) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
-
Time in millis between 2 threads are started.
- setProcessedCount(Long) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The number of items processed during the full reindex.
- setQueue(IndexerProperties.QueueProperties) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- setReactiveDelegate(WebClientReactiveClientCredentialsTokenResponseClient) - Method in class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.OAuth2ClientCredentialsAccessTokenResponseClient
- setReadFieldsPath(String) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- setReadMaxTries(int) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Defines the number of times that we'll try to retrieve something from a queue with the given wait time before giving up.
- setReadTenantsPath(String) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- setReadWaitTime(long) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
-
Time in milliseconds to wait for something to arrive in the Queue.
- setSearch(IndexerProperties.SearchProperties) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- setService(IndexerProperties.SearchProperties.ServiceProperties) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties
- setService(IndexerProperties.TenantProperties.ServiceProperties) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties
- setServiceClient(String) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- setServiceClient(String) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- setServiceClient(String) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
-
The service client to use when calling inventory services.
- setServiceClient(String) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService
-
The service client to use when calling inventory services.
- setStartDate(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
A date used to filter the reindex of items.
- setStartTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The start time of the process
- setStatus(ReindexStatus) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The current status of the reindex process.
- setTenant(IndexerProperties.TenantProperties) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- setThreadCount(Integer) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
-
The total number of threads used across all nodes.
- setTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
-
The time (Approximate) that this error occurred.
- setType(IndexableType) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
The
IndexableType
for which the reindex is requested. - setTypeFactory(TypeFactory) - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerSearchService
- setUseAllTenants(boolean) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
-
A toggle used to filter the reindex of items.
- setWebClientBufferLimitInBytes(int) - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerWebClientProperties
-
When a Solr collection is indexed, we make use of a
WebClient
to make batched calls to gather the indexable objects. - setWorkerThreads(int) - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
-
The number of worker threads which should be started on a reindex process.
- shouldIndex(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilder
-
Check whether a document should be indexed for this indexable.
- shouldProcess(Indexable<?>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilderPreProcessor
-
Determine if this processor should be processed on the group containing this indexable.
- shouldProcess(List<? extends Indexable<?>>) - Method in class com.broadleafcommerce.search.index.core.document.AbstractDocumentBuilderPreProcessor
-
Determine if these indexables should be processed here based on information about a single indexable in the group.
- SINCE_DURATION_BEFORE_FLD - Static variable in class com.broadleafcommerce.search.index.core.messaging.AbstractReindexSinceDateJobListener
- size() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- SSLVerificationProperties - Class in com.broadleafcommerce.search.index.core.service.autoconfigure
-
Contains properties dictating SSL verification.
- SSLVerificationProperties() - Constructor for class com.broadleafcommerce.search.index.core.service.autoconfigure.SSLVerificationProperties
- START_DATE_KEY - Static variable in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Key for the start date of a reindex job.
- startFullReindex(IndexableType, Map<String, Serializable>) - Method in class com.broadleafcommerce.search.index.core.service.DefaultReindexDelegationService
- startProcessState(IndexableType, boolean) - Method in class com.broadleafcommerce.search.index.core.AbstractProcessStateService
- startProcessState(IndexableType, boolean) - Method in interface com.broadleafcommerce.search.index.core.ProcessStateService
-
Initiates an instance of ReindexStateHolder that will be used across multiple threads, typically for full reindexing.
- startTime(Instant) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The start time of the process
- status(ReindexStatus) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The current status of the reindex process.
- SUCCESS - Enum constant in enum class com.broadleafcommerce.search.index.core.domain.ReindexStatus
- SynchronizedDelegatingOAuth2AuthorizedClientManager - Class in com.broadleafcommerce.search.index.core.oauth2.client.endpoint
-
This component implements
OAuth2AuthorizedClientManager
and internally instantiates and delegates toAuthorizedClientServiceOAuth2AuthorizedClientManager
. - SynchronizedDelegatingOAuth2AuthorizedClientManager(ClientRegistrationRepository) - Constructor for class com.broadleafcommerce.search.index.core.oauth2.client.endpoint.SynchronizedDelegatingOAuth2AuthorizedClientManager
T
- take() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- Tenant() - Constructor for class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- TENANT_KEY - Static variable in interface com.broadleafcommerce.search.index.core.service.ReindexJobService
-
Key for the tenant of a reindex job.
- TenantPersistenceHandler - Class in com.broadleafcommerce.search.index.core.messaging.handler
-
Clear the locale cache in
IndexerTenantService
if a change has been made to a tenant. - TenantPersistenceHandler(IndexerTenantService, ObjectMapper) - Constructor for class com.broadleafcommerce.search.index.core.messaging.handler.TenantPersistenceHandler
- TenantProperties() - Constructor for class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties
- threadCount(Integer) - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
-
The total number of threads used across all nodes.
- toArray() - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- toArray(E[]) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractDelegatingQueue
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerProperties
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.CollectionIndexerWebClientProperties
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.QueueProperties
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties.ServiceProperties
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.SearchProperties
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties.ServiceProperties
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties.TenantProperties
- toString() - Method in class com.broadleafcommerce.search.index.autoconfigure.IndexerProperties
- toString() - Method in class com.broadleafcommerce.search.index.core.cache.IndexCacheProperties
- toString() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexErrorDetails
- toString() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob.ReindexJobBuilder
- toString() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexJob
- toString() - Method in class com.broadleafcommerce.search.index.core.domain.ReindexRequest
- toString() - Method in enum class com.broadleafcommerce.search.index.core.domain.ReindexStatus
- toString() - Method in class com.broadleafcommerce.search.index.core.ProcessStateHolder.ProcessFailure
- toString() - Method in class com.broadleafcommerce.search.index.core.service.autoconfigure.SSLVerificationProperties
- toString() - Method in class com.broadleafcommerce.search.index.core.service.DefaultIndexerTenantService.Tenant
- transform(List<FROM>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractQueueLoader
-
Provides an optional transformation step.
- transform(List<ID>) - Method in class com.broadleafcommerce.search.index.core.queue.AbstractBatchIdQueueLoader
-
Breaks the provided list of IDs into chunks of appropriate size.
U
- unlock(String, String) - Method in interface com.broadleafcommerce.search.index.core.LockService
-
Deprecated.
- update(String, ReindexJob) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- updateAll(List<Update<ReindexJob>>) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
- updateAllAllowingPartialSuccess(List<Update<ReindexJob>>) - Method in class com.broadleafcommerce.search.index.core.service.NullReindexJobService
V
- validateShouldReindex(DocumentContext) - Method in class com.broadleafcommerce.search.index.core.messaging.AbstractFullIndexMessageListener
-
Validate that the message state is valid to execute a re-index
- valueOf(String) - Static method in enum class com.broadleafcommerce.search.index.core.domain.ReindexStatus
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.broadleafcommerce.search.index.core.domain.ReindexStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
W
- WorkerCompletedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Provides an event to notify that a worker has completed its work.
- WorkerCompletedEvent(IndexableType, String) - Constructor for class com.broadleafcommerce.search.index.core.event.WorkerCompletedEvent
- WorkerCompletedEvent(Object, IndexableType, String) - Constructor for class com.broadleafcommerce.search.index.core.event.WorkerCompletedEvent
- WorkerCompletedEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
WorkerCompletedEvent
, and releases the semaphore for the worker on the master node. - WorkerCompletedEventListener(ProcessStateService, SemaphoreProvider) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.WorkerCompletedEventListener
- WorkerStartedEvent - Class in com.broadleafcommerce.search.index.core.event
-
Provides an event to notify that a worker has started its work.
- WorkerStartedEvent(IndexableType, String, int) - Constructor for class com.broadleafcommerce.search.index.core.event.WorkerStartedEvent
- WorkerStartedEvent(Object, IndexableType, String, int) - Constructor for class com.broadleafcommerce.search.index.core.event.WorkerStartedEvent
- WorkerStartedEventListener - Class in com.broadleafcommerce.search.index.core.event.listener
-
Listens for
WorkerStartedEvent
, and updates theProcessStateHolder
node count and total thread count for the new worker. - WorkerStartedEventListener(ProcessStateService) - Constructor for class com.broadleafcommerce.search.index.core.event.listener.WorkerStartedEventListener
- wrapUp(IndexableType, Lock) - Method in class com.broadleafcommerce.search.index.core.master.GenericSearchIndexMasterProcessLauncher
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
DefaultIndexerSearchService.getServiceClient()