A B C D E F G H I J K L M N O P Q R S T U V W X

A

above(Object) - Method in class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
above(Object) - Method in interface org.hibernate.search.query.dsl.RangeMatchingContext
The field value must be above above You can exclude the value above by calling .excludeLimit()
AbstractDocumentBuilder<T> - Class in org.hibernate.search.engine
Abstract base class for the document builders.
AbstractDocumentBuilder(XClass, ConfigContext, Similarity, ReflectionManager) - Constructor for class org.hibernate.search.engine.AbstractDocumentBuilder
Constructor used on contained entities not annotated with @Indexed themselves.
AbstractDocumentBuilder.PropertiesMetadata - Class in org.hibernate.search.engine
Wrapper class containing all the meta data extracted out of a single entity.
AbstractDocumentBuilder.PropertiesMetadata() - Constructor for class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
AbstractDocumentBuilder.PropertiesMetadata.Container - Enum in org.hibernate.search.engine
 
AbstractJMSHibernateSearchController - Class in org.hibernate.search.backend.impl.jms
Implement the Hibernate Search controller responsible for processing the work send through JMS by the slave nodes.
AbstractJMSHibernateSearchController() - Constructor for class org.hibernate.search.backend.impl.jms.AbstractJMSHibernateSearchController
 
AbstractLoader - Class in org.hibernate.search.engine
Abstract loader which will take care of taking object loading timings.
AbstractLoader() - Constructor for class org.hibernate.search.engine.AbstractLoader
 
add(Work, WorkQueue) - Method in class org.hibernate.search.backend.impl.BatchedQueueingProcessor
 
add(Work) - Method in class org.hibernate.search.backend.impl.PostTransactionWorkQueueSynchronization
 
add(Work, WorkQueue) - Method in interface org.hibernate.search.backend.QueueingProcessor
Add a work TODO move that somewhere else, it does not really fit here
add(Work) - Method in class org.hibernate.search.backend.WorkQueue
 
addAllWorkThatFailed(List<LuceneWork>) - Method in class org.hibernate.search.exception.impl.ErrorContextBuilder
 
addAnalyzerDef(AnalyzerDef, XAnnotatedElement) - Method in class org.hibernate.search.impl.ConfigContext
Add an analyzer definition which was defined as annotation.
addAsPayLoadsToQueue(LuceneWork, IndexShardingStrategy, PerDirectoryWorkProcessor) - Method in interface org.hibernate.search.backend.impl.lucene.DpSelectionDelegate
The LuceneWork must be applied to different indexes.
addCachedFilter(FilterKey, Filter) - Method in interface org.hibernate.search.filter.FilterCachingStrategy
Propose a candidate filter for caching
addCachedFilter(FilterKey, Filter) - Method in class org.hibernate.search.filter.MRUFilterCachingStrategy
 
addClass(Class<?>) - Method in class org.hibernate.search.spi.SearchFactoryBuilder
 
addClassBridgeDef(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
addClasses(Class<?>...) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
addClasses(Class<?>...) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
addClasses(Class<?>...) - Method in interface org.hibernate.search.spi.SearchFactoryIntegrator
Add the following classes to the SearchFactory
addClassToDirectoryProvider(Class<?>, DirectoryProvider<?>, boolean) - Method in interface org.hibernate.search.spi.WritableBuildContext
 
addField(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
addFieldToDocument(String, String, Document) - Method in interface org.hibernate.search.bridge.LuceneOptions
Add a new field with the name fieldName to the Lucene Document document using the value indexedString.
addFilter(Filter) - Method in class org.hibernate.search.filter.ChainedFilter
 
addFulltextFilterDef(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
addGlobalAnalyzerDef(AnalyzerDef) - Method in class org.hibernate.search.impl.ConfigContext
 
addIndexedClass(Class<?>) - Method in class org.hibernate.search.spi.internals.PolymorphicIndexHierarchy
 
addIndexingParameters(DirectoryProvider<?>, LuceneIndexingParameters) - Method in interface org.hibernate.search.spi.WritableBuildContext
 
AddLuceneWork - Class in org.hibernate.search.backend
 
AddLuceneWork(Serializable, String, Class, Document) - Constructor for class org.hibernate.search.backend.AddLuceneWork
 
AddLuceneWork(Serializable, String, Class, Document, boolean) - Constructor for class org.hibernate.search.backend.AddLuceneWork
 
AddLuceneWork(Serializable, String, Class, Document, Map<String, String>) - Constructor for class org.hibernate.search.backend.AddLuceneWork
 
AddLuceneWork(Serializable, String, Class, Document, Map<String, String>, boolean) - Constructor for class org.hibernate.search.backend.AddLuceneWork
 
addNumericField(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
addNumericFieldToDocument(String, Object, Document) - Method in interface org.hibernate.search.bridge.LuceneOptions
Add a new NumericField with the name fieldName to the Lucene Document document using the value numericValue.
addOptimizerStrategy(DirectoryProvider<?>, OptimizerStrategy) - Method in interface org.hibernate.search.spi.WritableBuildContext
 
addParameter(Object) - Method in class org.hibernate.search.filter.StandardFilterKey
 
address - Variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
addScopedAnalyzer(String, Analyzer) - Method in class org.hibernate.search.util.ScopedAnalyzer
 
addSetter(String, Method) - Method in class org.hibernate.search.engine.FilterDef
 
addSynchronization(EventSource, Synchronization) - Method in class org.hibernate.search.event.FullTextIndexEventListener
Adds a synchronization to be performed in the onFlush method; should only be used as workaround for the case a flush is happening out of transaction.
addToScopedAnalyzer(String, Analyzer, Index) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
addToTotalCount(long) - Method in interface org.hibernate.search.batchindexing.MassIndexerProgressMonitor
The total count of entities to be indexed is added here; It could be called more than once, the implementation should add them up.
addToTotalCount(long) - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
addToTotalCount(long) - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
addTransaction(long) - Method in class org.hibernate.search.store.optimization.IncrementalOptimizerStrategy
 
addTransaction(long) - Method in class org.hibernate.search.store.optimization.NoOpOptimizerStrategy
 
addTransaction(long) - Method in interface org.hibernate.search.store.optimization.OptimizerStrategy
has to be called in a thread safe way
addWork(Work<T>) - Method in class org.hibernate.search.engine.WorkPlan
Adds a work to be performed as part of the final plan.
addWorkToDpProcessor(DirectoryProvider<?>, LuceneWork) - Method in interface org.hibernate.search.backend.impl.lucene.PerDirectoryWorkProcessor
 
addWorkToQueue(Class<T>, T, Serializable, boolean, boolean, boolean, List<LuceneWork>) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
addWorkToQueue(Class<T>, T, Serializable, boolean, boolean, boolean, List<LuceneWork>) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
addWorkToQueue(Class<T>, T, Serializable, boolean, boolean, boolean, List<LuceneWork>) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
afterCompletion(int) - Method in class org.hibernate.search.backend.impl.PostTransactionWorkQueueSynchronization
 
afterLast() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
afterScrollOperation() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
afterTransactionCompletion(boolean, Transaction) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
all() - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryBuilder
 
all() - Method in interface org.hibernate.search.query.dsl.QueryBuilder
Query matching all documents Typically mixed with a boolean query.
AllContext - Interface in org.hibernate.search.query.dsl
 
allowFieldSelectionInProjection() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
allReaders - Variable in class org.hibernate.search.reader.SharingBufferReaderProvider
contains all Readers (most current per Directory and all unclosed old readers)
allWorkToBeDone(List<LuceneWork>) - Method in class org.hibernate.search.exception.impl.ErrorContextBuilder
 
Analyzer - Annotation Type in org.hibernate.search.annotations
Define an Analyzer for a given entity, method, field or Field The order of precedence is as such: - @Field - field / method - entity - default Either describe an explicit implementation through the impl parameter or use an external @AnalyzerDef definition through the def parameter
analyzer(Class<?>) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
analyzer(String) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
analyzer(Class<?>) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
analyzer(String) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
analyzer(Class<?>) - Method in class org.hibernate.search.cfg.FieldMapping
 
analyzer(String) - Method in class org.hibernate.search.cfg.FieldMapping
 
analyzer - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
ANALYZER_CLASS - Static variable in class org.hibernate.search.Environment
Default Lucene analyser
AnalyzerDef - Annotation Type in org.hibernate.search.annotations
Reusable analyzer definition.
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.AnalyzerDefMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.CalendarBridgeMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.ContainedInMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.DateBridgeMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.DocumentIdMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.EntityMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.FieldMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.FullTextFilterDefMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.IndexedMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.PropertyMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.ProvidedIdMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.SearchMapping
 
analyzerDef(String, Class<? extends TokenizerFactory>) - Method in class org.hibernate.search.cfg.TokenFilterDefMapping
 
AnalyzerDefMapping - Class in org.hibernate.search.cfg
 
AnalyzerDefs - Annotation Type in org.hibernate.search.annotations
Reusable analyzer definitions.
AnalyzerDiscriminator - Annotation Type in org.hibernate.search.annotations
Allows to dynamically select a named analyzer through a Discriminator implementation.
analyzerDiscriminator(Class<? extends Discriminator>) - Method in class org.hibernate.search.cfg.EntityMapping
 
analyzerDiscriminator(Class<? extends Discriminator>) - Method in class org.hibernate.search.cfg.IndexedMapping
 
analyzerDiscriminator(Class<? extends Discriminator>) - Method in class org.hibernate.search.cfg.PropertyMapping
 
analyzerInstanceFromClass(Class<?>, Version) - Static method in class org.hibernate.search.util.ClassLoaderHelper
 
AndDocIdSet - Class in org.hibernate.search.filter
A DocIdSet built as applying "AND" operation to a list of other DocIdSet(s).
AndDocIdSet(List<DocIdSet>, int) - Constructor for class org.hibernate.search.filter.AndDocIdSet
 
andField(String) - Method in class org.hibernate.search.query.dsl.impl.ConnectedPhraseMatchingContext
 
andField(String) - Method in class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
andField(String) - Method in class org.hibernate.search.query.dsl.impl.ConnectedTermMatchingContext
 
andField(String) - Method in interface org.hibernate.search.query.dsl.PhraseMatchingContext
field / property the term query is executed on
andField(String) - Method in interface org.hibernate.search.query.dsl.RangeMatchingContext
field / property the term query is executed on
andField(String) - Method in interface org.hibernate.search.query.dsl.TermMatchingContext
field / property the term query is executed on
appendContainedInWorkForInstance(Object, WorkPlan) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
If we have a work instance we have to check whether the instance to be indexed is contained in any other indexed entities.
appendFailureMessage(StringBuilder, LuceneWork) - Static method in class org.hibernate.search.exception.impl.LogErrorHandler
 
AppliedOnTypeAwareBridge - Interface in org.hibernate.search.bridge
For bridges implementing this interface, provide the type of the object the bridge is applied on: - the return type for a property - the class itself for a class-level bridge
applyNonFlushedChanges(NonFlushedChanges) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
applySetting(IndexWriter, int) - Method in enum org.hibernate.search.backend.configuration.IndexWriterSetting
 
applyToWriter(IndexWriter, boolean) - Method in class org.hibernate.search.backend.LuceneIndexingParameters
 
applyToWriter(IndexWriter) - Method in class org.hibernate.search.backend.LuceneIndexingParameters.ParameterSet
Applies the parameters represented by this to a writer.
areInSync(File, File) - Static method in class org.hibernate.search.util.FileHelper
 
AUTOREGISTER_LISTENERS - Static variable in class org.hibernate.search.Environment
Enable listeners auto registration in Hibernate Annotations and EntityManager.

B

BackendQueueProcessorFactory - Interface in org.hibernate.search.backend
Interface for different types of queue processor factories.
BATCH - Static variable in class org.hibernate.search.backend.LuceneIndexingParameters
 
BATCH_BACKEND - Static variable in class org.hibernate.search.Environment
batch backend implementation class (must have a no-arg constructor and implement BatchBackend) also prefix for configuration settings of the batch backend
BatchBackend - Interface in org.hibernate.search.backend.impl.batchlucene
Implementations of this interface are not drop-in replacements for the standard BackendQueueProcessorFactory, but are meant to be used only during batch processing.
BatchCoordinator - Class in org.hibernate.search.batchindexing
Makes sure that several different BatchIndexingWorkspace(s) can be started concurrently, sharing the same batch-backend and IndexWriters.
BatchCoordinator(Set<Class<?>>, SearchFactoryImplementor, SessionFactory, int, int, CacheMode, int, long, boolean, boolean, boolean, MassIndexerProgressMonitor) - Constructor for class org.hibernate.search.batchindexing.BatchCoordinator
 
BatchedQueueingProcessor - Class in org.hibernate.search.backend.impl
Batch work until BatchedQueueingProcessor.performWorks(org.hibernate.search.backend.WorkQueue) is called.
BatchedQueueingProcessor(WorkerBuildContext, Properties) - Constructor for class org.hibernate.search.backend.impl.BatchedQueueingProcessor
 
BatchIndexingWorkspace - Class in org.hibernate.search.batchindexing
This runnable will prepare a pipeline for batch indexing of entities, managing the lifecycle of several ThreadPools.
BatchIndexingWorkspace(SearchFactoryImplementor, SessionFactory, Class<?>, int, int, CacheMode, int, CountDownLatch, MassIndexerProgressMonitor, BatchBackend, long) - Constructor for class org.hibernate.search.batchindexing.BatchIndexingWorkspace
 
batchSizeToLoadObjects(int) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
batchSizeToLoadObjects(int) - Method in interface org.hibernate.search.MassIndexer
Sets the batch size used to load the root entities.
beforeCompletion() - Method in class org.hibernate.search.backend.impl.PostTransactionWorkQueueSynchronization
 
beforeFirst() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
beforeTransactionCompletion(Transaction) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
beginTransaction() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
beginTransaction() - Method in class org.hibernate.search.sandbox.standalone.InstanceTransactionContext
 
below(Object) - Method in class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
below(Object) - Method in interface org.hibernate.search.query.dsl.RangeMatchingContext
The field value must be below below You can exclude the value below by calling .excludeLimit()
bestGuessEntityName(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
BIG_DECIMAL - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
BIG_INTEGER - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
BigDecimalBridge - Class in org.hibernate.search.bridge.builtin
Map a BigDecimal element
BigDecimalBridge() - Constructor for class org.hibernate.search.bridge.builtin.BigDecimalBridge
 
BigIntegerBridge - Class in org.hibernate.search.bridge.builtin
Map a BigInteger element.
BigIntegerBridge() - Constructor for class org.hibernate.search.bridge.builtin.BigIntegerBridge
 
bits(IndexReader) - Method in class org.hibernate.search.filter.ChainedFilter
 
BlackHoleBackendQueueProcessorFactory - Class in org.hibernate.search.backend.impl.blackhole
This backend does not do anything: the Documents are not sent to any index but are discarded.
BlackHoleBackendQueueProcessorFactory() - Constructor for class org.hibernate.search.backend.impl.blackhole.BlackHoleBackendQueueProcessorFactory
 
block() - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsMasterMessageListener
 
bool() - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryBuilder
 
bool() - Method in interface org.hibernate.search.query.dsl.QueryBuilder
Boolean query
BOOLEAN - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
BooleanBridge - Class in org.hibernate.search.bridge.builtin
Map a boolean field
BooleanBridge() - Constructor for class org.hibernate.search.bridge.builtin.BooleanBridge
 
BooleanJunction<T extends BooleanJunction> - Interface in org.hibernate.search.query.dsl
Represents a boolean query that can contains one or more elements to join
Boost - Annotation Type in org.hibernate.search.annotations
Apply a boost factor on a field or a whole entity
boost(float) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
boost(float) - Method in class org.hibernate.search.cfg.EntityMapping
 
boost(float) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
boost(float) - Method in class org.hibernate.search.cfg.FieldMapping
 
boost(float) - Method in class org.hibernate.search.cfg.IndexedMapping
 
boost - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
BOOST - Static variable in interface org.hibernate.search.ProjectionConstants
Deprecated. always return 1
boostedTo(float) - Method in interface org.hibernate.search.query.dsl.FieldCustomization
Boost the field to a given value Most of the time positive float: - lower than 1 to diminish the weight - higher than 1 to increase the weight Could be negative but not unless you understand what is going on (advanced)
boostedTo(float) - Method in class org.hibernate.search.query.dsl.impl.ConnectedAllContext
 
boostedTo(float) - Method in class org.hibernate.search.query.dsl.impl.ConnectedPhraseMatchingContext
 
boostedTo(float) - Method in class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
boostedTo(float) - Method in class org.hibernate.search.query.dsl.impl.ConnectedTermMatchingContext
 
boostedTo(float) - Method in interface org.hibernate.search.query.dsl.QueryCustomization
Boost the query to a given value Most of the time positive float: - lower than 1 to diminish the weight - higher than 1 to increase the weight Could be negative but not unless you understand what is going on (advanced)
BoostStrategy - Interface in org.hibernate.search.engine
Interface to implement boost values as functions of the object value being boosted.
bridge(Class<?>) - Method in class org.hibernate.search.cfg.FieldMapping
 
bridge(Class<?>) - Method in class org.hibernate.search.cfg.ProvidedIdMapping
 
BridgeException - Exception in org.hibernate.search.bridge
 
BridgeException() - Constructor for exception org.hibernate.search.bridge.BridgeException
 
BridgeException(String) - Constructor for exception org.hibernate.search.bridge.BridgeException
 
BridgeException(String, Throwable) - Constructor for exception org.hibernate.search.bridge.BridgeException
 
BridgeException(Throwable) - Constructor for exception org.hibernate.search.bridge.BridgeException
 
BridgeFactory - Class in org.hibernate.search.bridge
This factory is responsible for creating and initializing build-in and custom FieldBridges.
buildBridgeException(Exception, String) - Method in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
BuildContext - Interface in org.hibernate.search.spi
Build context that can be used by some services at initialization
buildLazyAnalyzer(String) - Method in class org.hibernate.search.impl.ConfigContext
 
buildLoader() - Method in class org.hibernate.search.query.ObjectLoaderBuilder
 
buildLockRequest(LockOptions) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
buildMultiReader(int, IndexReader[]) - Static method in class org.hibernate.search.reader.ReaderProviderHelper
 
buildQueryBuilder() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
buildQueryBuilder() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
buildQueryBuilder() - Method in interface org.hibernate.search.SearchFactory
 
buildSearchFactory() - Method in class org.hibernate.search.spi.SearchFactoryBuilder
 

C

cache(FilterCacheModeType) - Method in class org.hibernate.search.cfg.FullTextFilterDefMapping
Add cache implementation for fulltextfilterdef mapping
CACHE_DOCIDRESULTS_SIZE - Static variable in class org.hibernate.search.Environment
number of docidresults cached in hard reference.
CacheableMultiReader - Class in org.hibernate.search.reader
MultiReader ensuring equals returns true if the underlying readers are the same (and in the same order) Especially useful when using CachingWrapperFilter
CacheableMultiReader(IndexReader[]) - Constructor for class org.hibernate.search.reader.CacheableMultiReader
 
cacheInstance(FilterCacheModeType) - Static method in class org.hibernate.search.util.FilterCacheModeTypeHelper
 
cacheMode(CacheMode) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
cacheMode(CacheMode) - Method in interface org.hibernate.search.MassIndexer
Sets the cache interaction mode for the data loading tasks.
cacheResults(FilterCacheModeType) - Static method in class org.hibernate.search.util.FilterCacheModeTypeHelper
 
CachingWrapperFilter - Class in org.hibernate.search.filter
A slightly different version of Lucene's original CachingWrapperFilter which uses SoftReferences instead of WeakReferences in order to cache the filter BitSet.
CachingWrapperFilter(Filter) - Constructor for class org.hibernate.search.filter.CachingWrapperFilter
 
CachingWrapperFilter(Filter, int) - Constructor for class org.hibernate.search.filter.CachingWrapperFilter
 
CALENDAR_DAY - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CALENDAR_DAY - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
CALENDAR_HOUR - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CALENDAR_HOUR - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
CALENDAR_MILLISECOND - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CALENDAR_MILLISECOND - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
CALENDAR_MINUTE - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CALENDAR_MINUTE - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
CALENDAR_MONTH - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CALENDAR_MONTH - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
CALENDAR_SECOND - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CALENDAR_SECOND - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
CALENDAR_YEAR - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CALENDAR_YEAR - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
CalendarBridge - Annotation Type in org.hibernate.search.annotations
Defines the temporal resolution of a given field Calendar are stored as String in GMT
CalendarBridge - Class in org.hibernate.search.bridge.builtin
 
CalendarBridge() - Constructor for class org.hibernate.search.bridge.builtin.CalendarBridge
 
CalendarBridge(Resolution) - Constructor for class org.hibernate.search.bridge.builtin.CalendarBridge
 
calendarBridge(Resolution) - Method in class org.hibernate.search.cfg.FieldMapping
 
calendarBridge(Resolution) - Method in class org.hibernate.search.cfg.PropertyMapping
 
CalendarBridgeMapping - Class in org.hibernate.search.cfg
 
CalendarBridgeMapping(SearchMapping, EntityDescriptor, PropertyDescriptor, Resolution) - Constructor for class org.hibernate.search.cfg.CalendarBridgeMapping
 
cancelQuery() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
cancelWorks(WorkQueue) - Method in class org.hibernate.search.backend.impl.BatchedQueueingProcessor
 
cancelWorks(WorkQueue) - Method in interface org.hibernate.search.backend.QueueingProcessor
Rollback works
ChainedFilter - Class in org.hibernate.search.filter
A Filter capable of chaining other filters, so that it's possible to apply several filters on a Query.
ChainedFilter() - Constructor for class org.hibernate.search.filter.ChainedFilter
 
channel - Variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
CHARACTER - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
CharacterBridge - Class in org.hibernate.search.bridge.builtin
Map a character element
CharacterBridge() - Constructor for class org.hibernate.search.bridge.builtin.CharacterBridge
 
CharFilterDef - Annotation Type in org.hibernate.search.annotations
Define a CharFilterFactory and its parameters
checkDocumentId(XProperty, AbstractDocumentBuilder.PropertiesMetadata, boolean, String, ConfigContext) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
CLASS_FIELDNAME - Static variable in interface org.hibernate.search.engine.DocumentBuilder
Lucene document field name containing the fully qualified classname of the indexed class.
classBoosts - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
classBoostStrategy - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
ClassBridge - Annotation Type in org.hibernate.search.annotations
This annotation allows a user to apply an implementation class to a Lucene document to manipulate it in any way the user sees fit.
ClassBridge - Class in org.hibernate.search.bridge.builtin
Convert a Class back and forth
ClassBridge() - Constructor for class org.hibernate.search.bridge.builtin.ClassBridge
 
classBridge(Class<?>) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
classBridge(Class<?>) - Method in class org.hibernate.search.cfg.EntityMapping
 
ClassBridgeMapping - Class in org.hibernate.search.cfg
 
ClassBridgeMapping(SearchMapping, EntityDescriptor, Class<?>, EntityMapping) - Constructor for class org.hibernate.search.cfg.ClassBridgeMapping
 
ClassBridges - Annotation Type in org.hibernate.search.annotations
 
classBridges - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
classIndexes - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
ClassLoaderHelper - Class in org.hibernate.search.util
Utility class to load instances of other classes by using a fully qualified name, or from a class type.
classNames - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
classStores - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
classTermVectors - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
CLAZZ - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
clazz - Variable in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
clazz - Variable in class org.hibernate.search.engine.EntityInfo
The entity class.
clean(SearchException, IndexReader...) - Static method in class org.hibernate.search.reader.ReaderProviderHelper
 
cleanSessionIfNeeded(Session) - Method in class org.hibernate.search.backend.impl.jms.AbstractJMSHibernateSearchController
Ensure to clean the resources after use.
cleanup() - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
clear() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
clear() - Method in class org.hibernate.search.backend.WorkQueue
 
clear() - Method in class org.hibernate.search.engine.WorkPlan
Removes all scheduled work
clear() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
clear() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
clear() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
clear() - Method in interface org.hibernate.search.stat.Statistics
Reset all statistics.
clear() - Method in class org.hibernate.search.stat.StatisticsImpl
 
clear() - Method in class org.hibernate.search.util.SoftLimitMRUCache
Clears the cache.
clear() - Method in class org.hibernate.search.util.WeakIdentityHashMap
Removes all mappings from this map.
clone() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
clone() - Method in class org.hibernate.search.util.ScopedAnalyzer
 
close() - Method in interface org.hibernate.search.backend.BackendQueueProcessorFactory
Used to shutdown and eventually release resources.
close() - Method in class org.hibernate.search.backend.impl.BatchedQueueingProcessor
 
close() - Method in interface org.hibernate.search.backend.impl.batchlucene.BatchBackend
Used to shutdown and release resources.
close() - Method in class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
 
close() - Method in class org.hibernate.search.backend.impl.blackhole.BlackHoleBackendQueueProcessorFactory
 
close() - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
close() - Method in class org.hibernate.search.backend.impl.jgroups.MasterJGroupsBackendQueueProcessorFactory
 
close() - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
close() - Method in class org.hibernate.search.backend.impl.lucene.LuceneBackendQueueProcessorFactory
 
close() - Method in class org.hibernate.search.backend.impl.TransactionalWorker
 
close() - Method in interface org.hibernate.search.backend.QueueingProcessor
clean resources This method should log errors rather than raise an exception
close() - Method in interface org.hibernate.search.backend.Worker
clean resources This method can return exceptions
close() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
close() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
close() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
close() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
close() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
close() - Method in class org.hibernate.search.reader.SharingBufferReaderProvider.ReaderUsagePair
Closes the IndexReader if no other resource is using it in which case the reference to this container will also be removed.
close() - Method in interface org.hibernate.search.spi.SearchFactoryIntegrator
 
CloseIndexRunnable - Class in org.hibernate.search.backend.impl.lucene
Runnable to close the IndexWriter of a Workspace, if open.
CloseIndexRunnable(Workspace) - Constructor for class org.hibernate.search.backend.impl.lucene.CloseIndexRunnable
 
closeIndexWriter() - Method in class org.hibernate.search.backend.Workspace
Closes a previously opened IndexWriter.
closeReader(IndexReader) - Method in class org.hibernate.search.reader.NotSharedReaderProvider
 
closeReader(IndexReader) - Method in interface org.hibernate.search.reader.ReaderProvider
Close a reader previously opened by ReaderProvider.openReader(org.hibernate.search.store.DirectoryProvider...).
closeReader(IndexReader) - Method in class org.hibernate.search.reader.SharedReaderProvider
Deprecated.  
closeReader(IndexReader) - Method in class org.hibernate.search.reader.SharingBufferReaderProvider
 
clusterName - Variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
commit() - Method in class org.hibernate.search.sandbox.standalone.InstanceTransactionContext
 
commitIndexWriter(ErrorContextBuilder) - Method in class org.hibernate.search.backend.Workspace
Commits changes to a previously opened IndexWriter.
commitIndexWriter() - Method in class org.hibernate.search.backend.Workspace
 
ConcatStringBridge - Class in org.hibernate.search.cfg
 
ConcatStringBridge() - Constructor for class org.hibernate.search.cfg.ConcatStringBridge
 
CONCURRENT_WRITERS - Static variable in class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
 
ConcurrentMergeScheduler - Class in org.hibernate.search.backend.impl.lucene.overrides
We customize Lucene's ConcurrentMergeScheduler to route eventual exceptions to our configurable errorhandler.
ConcurrentMergeScheduler(ErrorHandler) - Constructor for class org.hibernate.search.backend.impl.lucene.overrides.ConcurrentMergeScheduler
 
ConfigContext - Class in org.hibernate.search.impl
Provides access to some default configuration settings (eg default Analyzer or default Similarity) and checks whether certain optional libraries are available.
ConfigContext(SearchConfiguration) - Constructor for class org.hibernate.search.impl.ConfigContext
 
configuration(SearchConfiguration) - Method in class org.hibernate.search.spi.SearchFactoryBuilder
 
CONFIGURATION_FILE - Static variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
CONFIGURATION_STRING - Static variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
CONFIGURATION_XML - Static variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
ConfigurationParseHelper - Class in org.hibernate.search.backend.configuration
Helper class to avoid managing NumberFormatException and similar code and ensure consistent error messages across Configuration parsing problems.
ConfigurationParseHelper() - Constructor for class org.hibernate.search.backend.configuration.ConfigurationParseHelper
 
ConnectedAllContext - Class in org.hibernate.search.query.dsl.impl
 
ConnectedAllContext() - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedAllContext
 
ConnectedMultiFieldsPhraseQueryBuilder - Class in org.hibernate.search.query.dsl.impl
 
ConnectedMultiFieldsPhraseQueryBuilder(PhraseQueryContext, QueryCustomizer, List<FieldContext>, QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsPhraseQueryBuilder
 
ConnectedMultiFieldsRangeQueryBuilder - Class in org.hibernate.search.query.dsl.impl
 
ConnectedMultiFieldsRangeQueryBuilder(RangeQueryContext, QueryCustomizer, List<FieldContext>, QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsRangeQueryBuilder
 
ConnectedMultiFieldsTermQueryBuilder - Class in org.hibernate.search.query.dsl.impl
 
ConnectedMultiFieldsTermQueryBuilder(TermQueryContext, Object, List<FieldContext>, QueryCustomizer, QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsTermQueryBuilder
 
ConnectedPhraseMatchingContext - Class in org.hibernate.search.query.dsl.impl
 
ConnectedPhraseMatchingContext(String, PhraseQueryContext, QueryCustomizer, QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedPhraseMatchingContext
 
ConnectedQueryBuilder - Class in org.hibernate.search.query.dsl.impl
Assuming connection with the search factory
ConnectedQueryBuilder(QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedQueryBuilder
 
ConnectedQueryContextBuilder - Class in org.hibernate.search.query.dsl.impl
Assuming connection with the search factory
ConnectedQueryContextBuilder(SearchFactoryImplementor) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedQueryContextBuilder
 
ConnectedQueryContextBuilder.HSearchEntityContext - Class in org.hibernate.search.query.dsl.impl
 
ConnectedQueryContextBuilder.HSearchEntityContext(Class<?>, SearchFactoryImplementor) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedQueryContextBuilder.HSearchEntityContext
 
ConnectedRangeMatchingContext - Class in org.hibernate.search.query.dsl.impl
 
ConnectedRangeMatchingContext(String, QueryCustomizer, QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
ConnectedTermMatchingContext - Class in org.hibernate.search.query.dsl.impl
 
ConnectedTermMatchingContext(TermQueryContext, String, QueryCustomizer, QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedTermMatchingContext
 
ConnectedTermMatchingContext(TermQueryContext, String[], QueryCustomizer, QueryBuildingContext) - Constructor for class org.hibernate.search.query.dsl.impl.ConnectedTermMatchingContext
 
connection() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
ContainedIn - Annotation Type in org.hibernate.search.annotations
Describe the owning entity as being part of the target entity's index (to be more accurate, being part of the indexed object graph).
containedIn() - Method in class org.hibernate.search.cfg.PropertyMapping
 
containedInGetters - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
ContainedInMapping - Class in org.hibernate.search.cfg
 
ContainedInMapping(SearchMapping, PropertyDescriptor, EntityDescriptor) - Constructor for class org.hibernate.search.cfg.ContainedInMapping
 
contains(Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
contains(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
contains(Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
containsKey(Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
containsKey(Object) - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns true if this map contains a mapping for the specified key.
containsValue(Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
containsValue(Object) - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns true if this map maps one or more keys to the specified value.
ContextHelper - Class in org.hibernate.search.util
Deprecated. Use FullTextSession.getSearchFactory() instead.
ContextHelper() - Constructor for class org.hibernate.search.util.ContextHelper
Deprecated.  
ContextualException2WayBridge - Class in org.hibernate.search.bridge.util
Wrap the exception with an exception provide contextual feedback
ContextualException2WayBridge() - Constructor for class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
ContextualExceptionBridge - Class in org.hibernate.search.bridge.util
Wrap the exception with an exception provide contextual feedback
ContextualExceptionBridge() - Constructor for class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
copyStateFromOldFactory(SearchFactoryState) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
createAddWork(Class<T>, T, Serializable, String, boolean) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
createCoordinator() - Method in class org.hibernate.search.impl.MassIndexerImpl
 
createCriteria(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createCriteria(String, String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createCriteria(Class) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createCriteria(Class, String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createDirectoryProviders(XClass, SearchConfiguration, WritableBuildContext, ReflectionManager) - Method in class org.hibernate.search.store.DirectoryProviderFactory
 
createErrorContext() - Method in class org.hibernate.search.exception.impl.ErrorContextBuilder
 
createExactMatchQuery(String, Object) - Static method in class org.hibernate.search.bridge.util.NumericFieldUtils
 
createFilter(Object, String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createFSIndex(File, Properties) - Static method in class org.hibernate.search.store.DirectoryProviderHelper
Creates an FSDirectory in provided directory and initializes an index if not already existing.
createFullTextEntityManager(EntityManager) - Static method in class org.hibernate.search.jpa.Search
Deprecated. As of release 3.1.0, replaced by Search.getFullTextEntityManager(javax.persistence.EntityManager)
createFullTextQuery(Query, Class<?>...) - Method in interface org.hibernate.search.FullTextSession
Create a fulltext query on top of a native Lucene query returning the matching objects of type entities and their respective subclasses.
createFullTextQuery(Query, Class...) - Method in class org.hibernate.search.impl.FullTextSessionImpl
Execute a Lucene query and retrieve managed objects of type entities (or their indexed subclasses) If entities is empty, include all indexed entities
createFullTextQuery(Query, Class<?>...) - Method in interface org.hibernate.search.jpa.FullTextEntityManager
Create a fulltext query on top of a native Lucene query returning the matching objects of type entities and their respective subclasses.
createFullTextQuery(Query, Class<?>...) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createFullTextQuery(Query, Class<?>...) - Method in interface org.hibernate.search.sandbox.standalone.FullTextManager
Create a fulltext query on top of a native Lucene query returning the matching objects of type entities and their respective subclasses.
createFullTextQuery(Query, Class<?>...) - Method in class org.hibernate.search.sandbox.standalone.LuceneFullTextManager
 
createFullTextSession(Session) - Static method in class org.hibernate.search.Search
Deprecated. As of release 3.1.0, replaced by Search.getFullTextSession(Session)
createIndexer(Class<?>...) - Method in interface org.hibernate.search.FullTextSession
Creates a MassIndexer to rebuild the indexes of some or all indexed entity types.
createIndexer(Class<?>...) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createIndexer(Class<?>...) - Method in interface org.hibernate.search.jpa.FullTextEntityManager
Creates a MassIndexer to rebuild the indexes of some or all indexed entity types.
createIndexer(Class<?>...) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createLockFactory(File, Properties) - Static method in class org.hibernate.search.store.DirectoryProviderHelper
Creates a LockFactory as selected in the configuration for the DirectoryProvider.
createLockFactory(File, Properties) - Method in interface org.hibernate.search.store.LockFactoryFactory
Creates a LockFactory implementation.
createNamedQuery(String) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createNamedQuery(String, Class<T>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createNativeQuery(String) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createNativeQuery(String, Class) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createNativeQuery(String, String) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createNumericRangeQuery(String, Object, Object, boolean, boolean) - Static method in class org.hibernate.search.bridge.util.NumericFieldUtils
 
createQuery(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createQuery(String) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createQuery(CriteriaQuery<T>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createQuery(String, Class<T>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
createQuery() - Method in class org.hibernate.search.query.dsl.impl.ConnectedAllContext
 
createQuery() - Method in class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsPhraseQueryBuilder
 
createQuery(FieldContext) - Method in class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsPhraseQueryBuilder
 
createQuery() - Method in class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsRangeQueryBuilder
 
createQuery(FieldContext) - Method in class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsRangeQueryBuilder
 
createQuery() - Method in class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsTermQueryBuilder
 
createQuery(FieldContext) - Method in class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsTermQueryBuilder
 
createQuery() - Method in interface org.hibernate.search.query.dsl.Termination
Return the lucene query representing the operation
createReaderProvider(SearchConfiguration, BuildContext) - Static method in class org.hibernate.search.reader.ReaderProviderFactory
 
createSQLQuery(String, String, Class) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createSQLQuery(String, String[], Class[]) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createSQLQuery(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
createWorker(SearchConfiguration, WorkerBuildContext) - Static method in class org.hibernate.search.backend.WorkerFactory
 
criteria(Criteria) - Method in class org.hibernate.search.query.ObjectLoaderBuilder
 
current - Variable in class org.hibernate.search.reader.SharingBufferReaderProvider.PerDirectoryLatestReader
Reference to the most current IndexReader for a DirectoryProvider; guarded by lockOnReplaceCurrent;
currentFactory(SearchFactoryIntegrator) - Method in class org.hibernate.search.spi.SearchFactoryBuilder
 
currentReaders - Variable in class org.hibernate.search.reader.SharingBufferReaderProvider
contains last updated Reader; protected by lockOnOpenLatest (in the values)

D

DATE_DAY - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DATE_DAY - Static variable in class org.hibernate.search.bridge.builtin.DateBridge
 
DATE_HOUR - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DATE_HOUR - Static variable in class org.hibernate.search.bridge.builtin.DateBridge
 
DATE_MILLISECOND - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DATE_MILLISECOND - Static variable in class org.hibernate.search.bridge.builtin.DateBridge
 
DATE_MINUTE - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DATE_MINUTE - Static variable in class org.hibernate.search.bridge.builtin.DateBridge
 
DATE_MONTH - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DATE_MONTH - Static variable in class org.hibernate.search.bridge.builtin.DateBridge
 
DATE_SECOND - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DATE_SECOND - Static variable in class org.hibernate.search.bridge.builtin.DateBridge
 
DATE_YEAR - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DATE_YEAR - Static variable in class org.hibernate.search.bridge.builtin.DateBridge
 
DateBridge - Annotation Type in org.hibernate.search.annotations
Defines the temporal resolution of a given field Date are stored as String in GMT
DateBridge - Class in org.hibernate.search.bridge.builtin
Bridge a java.util.Date to a String, truncated to the resolution Date are stored GMT based

ie Resolution.YEAR: yyyy Resolution.MONTH: yyyyMM Resolution.DAY: yyyyMMdd Resolution.HOUR: yyyyMMddHH Resolution.MINUTE: yyyyMMddHHmm Resolution.SECOND: yyyyMMddHHmmss Resolution.MILLISECOND: yyyyMMddHHmmssSSS

DateBridge() - Constructor for class org.hibernate.search.bridge.builtin.DateBridge
 
DateBridge(Resolution) - Constructor for class org.hibernate.search.bridge.builtin.DateBridge
 
dateBridge(Resolution) - Method in class org.hibernate.search.cfg.FieldMapping
 
dateBridge(Resolution) - Method in class org.hibernate.search.cfg.PropertyMapping
 
DateBridgeMapping - Class in org.hibernate.search.cfg
 
DateBridgeMapping(SearchMapping, EntityDescriptor, PropertyDescriptor, Resolution) - Constructor for class org.hibernate.search.cfg.DateBridgeMapping
 
DateResolutionUtil - Class in org.hibernate.search.bridge.builtin
 
DEFAULT_COPY_BUFFER_SIZE - Static variable in class org.hibernate.search.util.FileHelper
 
DEFAULT_NULL_TOKEN - Static variable in annotation type org.hibernate.search.annotations.Field
Value for Field.indexNullAs() parameter indicating that null values should not indexed using the
DEFAULT_NULL_TOKEN - Static variable in class org.hibernate.search.Environment
Parameter name used to configure the default null token
DEFAULT_SIZE - Static variable in class org.hibernate.search.filter.CachingWrapperFilter
 
DEFAULT_SOFT_REF_COUNT - Static variable in class org.hibernate.search.util.SoftLimitMRUCache
The default soft reference count.
DEFAULT_STRONG_REF_COUNT - Static variable in class org.hibernate.search.util.SoftLimitMRUCache
The default strong reference count.
DefaultBoostStrategy - Class in org.hibernate.search.engine
 
DefaultBoostStrategy() - Constructor for class org.hibernate.search.engine.DefaultBoostStrategy
 
defineBoost(Object) - Method in interface org.hibernate.search.engine.BoostStrategy
 
defineBoost(Object) - Method in class org.hibernate.search.engine.DefaultBoostStrategy
 
DelegateNamedAnalyzer - Class in org.hibernate.search.util
Delegate to a named analyzer.
DelegateNamedAnalyzer(String) - Constructor for class org.hibernate.search.util.DelegateNamedAnalyzer
 
delete(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
delete(String, Object, Type) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
delete(String, Object[], Type[]) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
delete(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
delete(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
delete(File) - Static method in class org.hibernate.search.util.FileHelper
 
DeleteExtWorkDelegate - Class in org.hibernate.search.backend.impl.lucene.works
Stateless extension of DeleteLuceneWork, performing the same LuceneWork in an optimal way in case the index is NOT shared across different entities (which is the default).
DeleteLuceneWork - Class in org.hibernate.search.backend
 
DeleteLuceneWork(Serializable, String, Class) - Constructor for class org.hibernate.search.backend.DeleteLuceneWork
 
depth(int) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
destroy() - Method in class org.hibernate.search.reader.NotSharedReaderProvider
 
destroy() - Method in interface org.hibernate.search.reader.ReaderProvider
Called when a SearchFactory is destroyed.
destroy() - Method in class org.hibernate.search.reader.SharedReaderProvider
Deprecated.  
destroy() - Method in class org.hibernate.search.reader.SharingBufferReaderProvider
 
detach(Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
DirectoryProvider<TDirectory extends Directory> - Interface in org.hibernate.search.store
Set up and provide a Lucene Directory equals() and hashCode() must guaranty equality between two providers pointing to the same underlying Lucene Store.
DirectoryProviderData - Class in org.hibernate.search.spi.internals
 
DirectoryProviderData() - Constructor for class org.hibernate.search.spi.internals.DirectoryProviderData
 
DirectoryProviderFactory - Class in org.hibernate.search.store
Create a Lucene directory provider which can be configured through the following properties: hibernate.search.default.* hibernate.search.<indexname>.*, where <indexname> properties have precedence over default ones.
DirectoryProviderFactory() - Constructor for class org.hibernate.search.store.DirectoryProviderFactory
 
DirectoryProviderFactory.DirectoryProviders - Class in org.hibernate.search.store
 
DirectoryProviderFactory.DirectoryProviders(IndexShardingStrategy, DirectoryProvider[], Similarity) - Constructor for class org.hibernate.search.store.DirectoryProviderFactory.DirectoryProviders
 
DirectoryProviderHelper - Class in org.hibernate.search.store
 
disableFetchProfile(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
disableFilter(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
disableFullTextFilter(String) - Method in interface org.hibernate.search.FullTextQuery
Disable a given filter by its name
disableFullTextFilter(String) - Method in interface org.hibernate.search.jpa.FullTextQuery
Disable a given filter by its name
disableFullTextFilter(String) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
disableFullTextFilter(String) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
disconnect() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
Discriminator - Interface in org.hibernate.search.analyzer
Returns the expected discriminator name to use on the element evaluated
discriminator - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
discriminatorGetter - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
DO_NOT_INDEX_NULL - Static variable in annotation type org.hibernate.search.annotations.Field
Default value for Field.indexNullAs() parameter.
doc(int) - Method in class org.hibernate.search.query.QueryHits
 
doc(int, FieldSelector) - Method in class org.hibernate.search.query.QueryHits
 
docId(int) - Method in class org.hibernate.search.query.QueryHits
 
DOCUMENT - Static variable in interface org.hibernate.search.ProjectionConstants
The Lucene document returned by a search.
DOCUMENT_ID - Static variable in interface org.hibernate.search.ProjectionConstants
Lucene Document id.
DocumentBuilder - Interface in org.hibernate.search.engine
Interface created to keep backwards compatibility.
DocumentBuilderContainedEntity<T> - Class in org.hibernate.search.engine
Set up and provide a manager for classes which are indexed via @IndexedEmbedded, but themselves do not contain the @Indexed annotation.
DocumentBuilderContainedEntity(XClass, ConfigContext, ReflectionManager) - Constructor for class org.hibernate.search.engine.DocumentBuilderContainedEntity
Constructor used on contained entities not annotated with @Indexed themselves.
DocumentBuilderHelper - Class in org.hibernate.search.engine
 
DocumentBuilderIndexedEntity<T> - Class in org.hibernate.search.engine
Set up and provide a manager for classes which are directly annotated with @Indexed.
DocumentBuilderIndexedEntity(XClass, ConfigContext, DirectoryProviderFactory.DirectoryProviders, ReflectionManager) - Constructor for class org.hibernate.search.engine.DocumentBuilderIndexedEntity
Creates a document builder for entities annotated with @Indexed.
DocumentExtractor - Class in org.hibernate.search.engine
Helper class to extract EntityInfos out of the QueryHits.
DocumentExtractor(QueryHits, SearchFactoryImplementor, String[], Set<String>, boolean) - Constructor for class org.hibernate.search.engine.DocumentExtractor
 
DocumentId - Annotation Type in org.hibernate.search.annotations
Declare a field as the document id.
documentId() - Method in class org.hibernate.search.cfg.PropertyMapping
 
DocumentIdMapping - Class in org.hibernate.search.cfg
 
DocumentIdMapping(PropertyDescriptor, EntityDescriptor, SearchMapping) - Constructor for class org.hibernate.search.cfg.DocumentIdMapping
 
documentsAdded(long) - Method in interface org.hibernate.search.batchindexing.MassIndexerProgressMonitor
The number of documents sent to the backend; This is called several times during the indexing process.
documentsAdded(long) - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
documentsAdded(long) - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
documentsBuilt(int) - Method in interface org.hibernate.search.batchindexing.MassIndexerProgressMonitor
The number of Documents built; This is called several times and concurrently during the indexing process.
documentsBuilt(int) - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
documentsBuilt(int) - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
DOUBLE - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DOUBLE_NUMERIC - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
DoubleBridge - Class in org.hibernate.search.bridge.builtin
Map a double element
DoubleBridge() - Constructor for class org.hibernate.search.bridge.builtin.DoubleBridge
 
DoubleNumericFieldBridge - Class in org.hibernate.search.bridge.builtin
Double numeric field bridge, capable of decoding double values from Field
DoubleNumericFieldBridge() - Constructor for class org.hibernate.search.bridge.builtin.DoubleNumericFieldBridge
 
doWork(Work) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
doWorkInSync(LuceneWork) - Method in interface org.hibernate.search.backend.impl.batchlucene.BatchBackend
Does one work in sync
doWorkInSync(LuceneWork) - Method in class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
 
DpSelectionDelegate - Interface in org.hibernate.search.backend.impl.lucene
 
DpSelectionVisitor - Class in org.hibernate.search.backend.impl.lucene
This is the main client for IndexShardingStrategies.
DpSelectionVisitor() - Constructor for class org.hibernate.search.backend.impl.lucene.DpSelectionVisitor
 
DynamicBoost - Annotation Type in org.hibernate.search.annotations
Apply a dynamic boost factor on a field or a whole entity.
dynamicBoost(Class<? extends BoostStrategy>) - Method in class org.hibernate.search.cfg.EntityMapping
 
dynamicBoost(Class<? extends BoostStrategy>) - Method in class org.hibernate.search.cfg.PropertyMapping
 
dynamicFieldBoosts - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 

E

elementFromString(String) - Static method in class org.hibernate.search.util.XMLHelper
Converts a String representing an XML snippet into an Element.
elements() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
embeddedContainers - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
embeddedGetters - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
embeddedPropertiesMetadata - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
enableFetchProfile(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
enableFilter(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
enableFullTextFilter(String) - Method in interface org.hibernate.search.FullTextQuery
Enable a given filter by its name.
enableFullTextFilter(String) - Method in interface org.hibernate.search.jpa.FullTextQuery
Enable a given filter by its name.
enableFullTextFilter(String) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
enableFullTextFilter(String) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
enableHibernateSearch(EventListeners, Properties) - Static method in class org.hibernate.search.event.EventListenerRegister
Add the FullTextIndexEventListener to all listeners, if enabled in configuration and if not already registered.
enqueueAsyncWork(LuceneWork) - Method in interface org.hibernate.search.backend.impl.batchlucene.BatchBackend
Enqueues one work to be processed asynchronously
enqueueAsyncWork(LuceneWork) - Method in class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
 
entitiesLoaded(int) - Method in interface org.hibernate.search.batchindexing.MassIndexerProgressMonitor
The number of entities loaded from database; This is called several times and concurrently during the indexing process.
entitiesLoaded(int) - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
entitiesLoaded(int) - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.AnalyzerDefMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.CalendarBridgeMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.ContainedInMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.DateBridgeMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.DocumentIdMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.EntityMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.FieldMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.FullTextFilterDefMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.IndexedMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.PropertyMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.ProvidedIdMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.SearchMapping
 
entity(Class<?>) - Method in class org.hibernate.search.cfg.TokenFilterDefMapping
 
EntityConsumerLuceneworkProducer - Class in org.hibernate.search.batchindexing
Component of batch-indexing pipeline, using chained producer-consumers.
EntityConsumerLuceneworkProducer(ProducerConsumerQueue<List<?>>, MassIndexerProgressMonitor, SessionFactory, CountDownLatch, SearchFactoryImplementor, CacheMode, BatchBackend) - Constructor for class org.hibernate.search.batchindexing.EntityConsumerLuceneworkProducer
 
EntityContext - Interface in org.hibernate.search.query.dsl
 
EntityDescriptor - Class in org.hibernate.search.cfg
 
EntityDescriptor(Class<?>) - Constructor for class org.hibernate.search.cfg.EntityDescriptor
 
EntityInfo - Class in org.hibernate.search.engine
Wrapper class for the loading of a single entity.
EntityInfo(Class, String, Serializable, Object[]) - Constructor for class org.hibernate.search.engine.EntityInfo
 
EntityMapping - Class in org.hibernate.search.cfg
 
EntityMapping(Class<?>, SearchMapping) - Constructor for class org.hibernate.search.cfg.EntityMapping
 
EntityState - Enum in org.hibernate.search.engine
Entity state with regard to indexing possibilities
entrySet() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
entrySet() - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns a collection view of the mappings contained in this map.
EnumBridge - Class in org.hibernate.search.bridge.builtin
Map an Enum field
EnumBridge() - Constructor for class org.hibernate.search.bridge.builtin.EnumBridge
 
Environment - Class in org.hibernate.search
 
equals(Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
equals(Object) - Method in class org.hibernate.search.backend.LuceneIndexingParameters.ParameterSet
 
equals(Object) - Method in class org.hibernate.search.filter.CachingWrapperFilter
 
equals(Object) - Method in class org.hibernate.search.filter.FilterKey
 
equals(Object) - Method in class org.hibernate.search.filter.StandardFilterKey
 
equals(Object) - Method in class org.hibernate.search.reader.CacheableMultiReader
only available since 2.3
equals(Object) - Method in class org.hibernate.search.store.FSDirectoryProvider
 
equals(Object) - Method in class org.hibernate.search.store.FSMasterDirectoryProvider
 
equals(Object) - Method in class org.hibernate.search.store.FSSlaveDirectoryProvider
 
equals(Object) - Method in class org.hibernate.search.store.RAMDirectoryProvider
 
ERROR_HANDLER - Static variable in class org.hibernate.search.Environment
Set to a fully qualified classname of a type implementing org.hibernate.search.exception.ErrorHandler to override the error strategy used during processing of the Lucene updates.
ErrorContext - Interface in org.hibernate.search.exception
 
ErrorContextBuilder - Class in org.hibernate.search.exception.impl
 
ErrorContextBuilder() - Constructor for class org.hibernate.search.exception.impl.ErrorContextBuilder
 
ErrorHandler - Interface in org.hibernate.search.exception
 
errorThatOccurred(Throwable) - Method in class org.hibernate.search.exception.impl.ErrorContextBuilder
 
EventListenerRegister - Class in org.hibernate.search.event
Helper methods initializing Hibernate Search event listeners.
EventListenerRegister() - Constructor for class org.hibernate.search.event.EventListenerRegister
 
EventSourceTransactionContext - Class in org.hibernate.search.backend.impl
Implementation of the transactional context on top of an EventSource (Session)
EventSourceTransactionContext(EventSource) - Constructor for class org.hibernate.search.backend.impl.EventSourceTransactionContext
 
evict(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
except(Query...) - Method in interface org.hibernate.search.query.dsl.AllContext
Exclude the documents matching these queries
except(Query...) - Method in class org.hibernate.search.query.dsl.impl.ConnectedAllContext
 
excludeLimit() - Method in class org.hibernate.search.query.dsl.impl.ConnectedMultiFieldsRangeQueryBuilder
 
excludeLimit() - Method in interface org.hibernate.search.query.dsl.RangeMatchingContext.FromRangeContext
 
excludeLimit() - Method in interface org.hibernate.search.query.dsl.RangeTerminationExcludable
 
EXCLUSIVE_INDEX_USE - Static variable in class org.hibernate.search.Environment
When set to true a lock on the index will not be released until the SearchFactory (or SessionFactory) is closed.
executeLoad(EntityInfo) - Method in class org.hibernate.search.engine.AbstractLoader
 
executeLoad(EntityInfo...) - Method in class org.hibernate.search.engine.AbstractLoader
 
executeLoad(EntityInfo) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
executeLoad(EntityInfo...) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
executeLoad(EntityInfo) - Method in class org.hibernate.search.engine.QueryLoader
 
executeLoad(EntityInfo...) - Method in class org.hibernate.search.engine.QueryLoader
 
executeNativeUpdate(NativeSQLQuerySpecification, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
executeUpdate(String, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
executeUpdate() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
executeUpdate() - Method in class org.hibernate.search.query.FullTextQueryImpl
 
Executors - Class in org.hibernate.search.batchindexing
Helper class to create threads; these threads are grouped and named to be identified in a profiler.
Executors() - Constructor for class org.hibernate.search.batchindexing.Executors
 
Executors.BlockPolicy - Class in org.hibernate.search.batchindexing
A handler for rejected tasks that will have the caller block until space is available.
Executors.BlockPolicy() - Constructor for class org.hibernate.search.batchindexing.Executors.BlockPolicy
Creates a BlockPolicy.
explain(int) - Method in interface org.hibernate.search.FullTextQuery
Return the Lucene Explanation object describing the score computation for the matching object/document in the current query
explain(int) - Method in interface org.hibernate.search.jpa.FullTextQuery
Return the Lucene Explanation object describing the score computation for the matching object/document in the current query
explain(int) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
explain(int) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
explain(int) - Method in class org.hibernate.search.query.QueryHits
 
EXPLANATION - Static variable in interface org.hibernate.search.ProjectionConstants
Lucene Explanation object describing the score computation for the matching object/document This feature is relatively expensive, do not use unless you return a limited amount of objects (using pagination) To retrieve explanation of a single result, consider retrieving ProjectionConstants.DOCUMENT_ID and using fullTextQuery.explain(int)
EXPLICIT_DEFAULT_VALUE - Static variable in class org.hibernate.search.backend.LuceneIndexingParameters
 
extract(int) - Method in class org.hibernate.search.engine.DocumentExtractor
 
extractTwoWayType(FieldBridge, XClass, ReflectionManager) - Static method in class org.hibernate.search.bridge.BridgeFactory
Takes in a fieldBridge and will return you a TwoWayFieldBridge instance.
extractType(ClassBridge, XClass) - Static method in class org.hibernate.search.bridge.BridgeFactory
This extracts and instantiates the implementation class from a ClassBridge annotation.
extractType(FieldBridge, XClass, ReflectionManager) - Static method in class org.hibernate.search.bridge.BridgeFactory
This extracts and instantiates the implementation class from a ClassBridge annotation.

F

Factory - Annotation Type in org.hibernate.search.annotations
Marks a method as a factory method for a given type.
Field - Annotation Type in org.hibernate.search.annotations
Annotation used for marking a property as indexable.
field() - Method in class org.hibernate.search.cfg.CalendarBridgeMapping
 
field() - Method in class org.hibernate.search.cfg.ContainedInMapping
 
field() - Method in class org.hibernate.search.cfg.DateBridgeMapping
 
field() - Method in class org.hibernate.search.cfg.DocumentIdMapping
 
field() - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
field() - Method in class org.hibernate.search.cfg.FieldMapping
 
field() - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
field() - Method in class org.hibernate.search.cfg.PropertyMapping
 
fieldBoosts - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
FieldBridge - Annotation Type in org.hibernate.search.annotations
specifies a given field bridge implementation
FieldBridge - Interface in org.hibernate.search.bridge
Link between a java property and a Lucene Document Usually a Java property will be linked to a Document Field.
FieldBridgeMapping - Class in org.hibernate.search.cfg
 
FieldBridgeMapping(Class<?>, Map<String, Object>, FieldMapping, PropertyDescriptor, EntityDescriptor, SearchMapping) - Constructor for class org.hibernate.search.cfg.FieldBridgeMapping
 
fieldBridges - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
FieldContext - Class in org.hibernate.search.query.dsl.impl
 
FieldContext(String) - Constructor for class org.hibernate.search.query.dsl.impl.FieldContext
 
FieldCustomization<T> - Interface in org.hibernate.search.query.dsl
 
fieldGetters - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
fieldIndex - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
FieldMapping - Class in org.hibernate.search.cfg
 
FieldMapping(PropertyDescriptor, EntityDescriptor, SearchMapping) - Constructor for class org.hibernate.search.cfg.FieldMapping
 
fieldName - Variable in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
fieldNames - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
fieldNullTokens - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
Fields - Annotation Type in org.hibernate.search.annotations
Mark a property as indexable into different fields Useful if the field is used for sorting and searching
fieldStore - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
fieldTermVectors - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
FileHelper - Class in org.hibernate.search.util
Utility class for synchronizing files/directories.
FileHelper() - Constructor for class org.hibernate.search.util.FileHelper
 
filter(Class<? extends TokenFilterFactory>) - Method in class org.hibernate.search.cfg.AnalyzerDefMapping
 
filter(Class<? extends TokenFilterFactory>) - Method in class org.hibernate.search.cfg.TokenFilterDefMapping
 
filter(Object, String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
filter(Object, String, Object, Type) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
filter(Object, String, Object[], Type[]) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
filter - Variable in class org.hibernate.search.query.QueryHits
 
FILTER_CACHING_STRATEGY - Static variable in class org.hibernate.search.Environment
filter caching strategy class (must have a no-arg constructor and implement FilterCachingStrategy)
FilterCacheModeType - Enum in org.hibernate.search.annotations
Cache mode strategy for FullTextFilterDefs.
FilterCacheModeTypeHelper - Class in org.hibernate.search.util
 
FilterCachingStrategy - Interface in org.hibernate.search.filter
Defines the caching filter strategy implementations of getCachedFilter and addCachedFilter must be thread-safe
FilterDef - Class in org.hibernate.search.engine
A wrapper class which encapsulates all required information to create a defined filter.
FilterDef(FullTextFilterDef) - Constructor for class org.hibernate.search.engine.FilterDef
 
filteredBy(Filter) - Method in class org.hibernate.search.query.dsl.impl.ConnectedAllContext
 
filteredBy(Filter) - Method in interface org.hibernate.search.query.dsl.QueryCustomization
Filter the query results with the Filter instance
FilterKey - Class in org.hibernate.search.filter
The key object must implement equals / hashcode so that 2 keys are equals if and only if the given Filter types are the same and the set of parameters are the same.
FilterKey() - Constructor for class org.hibernate.search.filter.FilterKey
 
FilterOptimizationHelper - Class in org.hibernate.search.filter
Helper class to apply some common optimizations when several Filters are applied.
FilterOptimizationHelper() - Constructor for class org.hibernate.search.filter.FilterOptimizationHelper
 
find(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
find(String, Object, Type) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
find(String, Object[], Type[]) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
find(Class<T>, Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
find(Class<T>, Object, Map<String, Object>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
find(Class<T>, Object, LockModeType) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
find(Class<T>, Object, LockModeType, Map<String, Object>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
first() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
FLOAT - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
FLOAT_NUMERIC - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
FloatBridge - Class in org.hibernate.search.bridge.builtin
Map a float element
FloatBridge() - Constructor for class org.hibernate.search.bridge.builtin.FloatBridge
 
FloatNumericFieldBridge - Class in org.hibernate.search.bridge.builtin
Float numeric field bridge, capable of decoding float values from Field
FloatNumericFieldBridge() - Constructor for class org.hibernate.search.bridge.builtin.FloatNumericFieldBridge
 
flush() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
flush() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
flushToIndexes() - Method in interface org.hibernate.search.FullTextSession
Flush all index changes forcing Hibernate Search to apply all changes to the index not waiting for the batch limit.
flushToIndexes() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
flushToIndexes() - Method in interface org.hibernate.search.jpa.FullTextEntityManager
Flush all index changes forcing Hibernate Search to apply all changes to the index not waiting for the batch limit.
flushToIndexes() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
flushToIndexes() - Method in interface org.hibernate.search.sandbox.standalone.FullTextManager
Flush all index changes forcing Hibernate Search to apply all changes to the index not waiting for the batch limit.
flushToIndexes() - Method in class org.hibernate.search.sandbox.standalone.LuceneFullTextManager
 
flushWorks() - Method in class org.hibernate.search.backend.impl.PostTransactionWorkQueueSynchronization
 
flushWorks(TransactionContext) - Method in class org.hibernate.search.backend.impl.TransactionalWorker
 
flushWorks(TransactionContext) - Method in interface org.hibernate.search.backend.Worker
Flush any work queue.
forceLockRelease() - Method in class org.hibernate.search.backend.Workspace
Forces release of Directory lock.
forceTimedOut() - Method in class org.hibernate.search.query.TimeoutManager
 
forEntity(Class<?>) - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryContextBuilder
 
forEntity(Class<?>) - Method in interface org.hibernate.search.query.dsl.QueryContextBuilder
 
from(T) - Method in class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
from(T) - Method in interface org.hibernate.search.query.dsl.RangeMatchingContext
 
FSDirectoryProvider - Class in org.hibernate.search.store
Use a Lucene FSDirectory.
FSDirectoryProvider() - Constructor for class org.hibernate.search.store.FSDirectoryProvider
 
FSMasterDirectoryProvider - Class in org.hibernate.search.store
File based DirectoryProvider that takes care of index copy The base directory is represented by hibernate.search..indexBase The index is created in / The source (aka copy) directory is built from / A copy is triggered every refresh seconds
FSMasterDirectoryProvider() - Constructor for class org.hibernate.search.store.FSMasterDirectoryProvider
 
FSSlaveDirectoryProvider - Class in org.hibernate.search.store
File based directory provider that takes care of getting a version of the index from a given source.
FSSlaveDirectoryProvider() - Constructor for class org.hibernate.search.store.FSSlaveDirectoryProvider
 
FullTextEntityManager - Interface in org.hibernate.search.jpa
Extends an EntityManager with Full-Text operations
FullTextEntityManagerImpl - Class in org.hibernate.search.jpa.impl
 
FullTextEntityManagerImpl(EntityManager) - Constructor for class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
FullTextFilter - Interface in org.hibernate.search
represents a FullTextFilter that is about to be applied Used to inject parameters
FullTextFilterDef - Annotation Type in org.hibernate.search.annotations
Defines a FullTextFilter that can be optionally applied to every FullText Queries While not related to a specific indexed entity, the annotation has to be set on one of them
fullTextFilterDef(String, Class<?>) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
fullTextFilterDef(String, Class<?>) - Method in class org.hibernate.search.cfg.EntityMapping
 
fullTextFilterDef(String, Class<?>) - Method in class org.hibernate.search.cfg.FullTextFilterDefMapping
 
fullTextFilterDef(String, Class<?>) - Method in class org.hibernate.search.cfg.IndexedMapping
 
fullTextFilterDef(String, Class<?>) - Method in class org.hibernate.search.cfg.ProvidedIdMapping
 
fullTextFilterDef(String, Class<?>) - Method in class org.hibernate.search.cfg.SearchMapping
 
fullTextFilterDef(String, Class<?>) - Method in class org.hibernate.search.cfg.TokenFilterDefMapping
 
FullTextFilterDefMapping - Class in org.hibernate.search.cfg
Mapping class responsible for collecting data for constructing FullTextFilterDef annotation.
FullTextFilterDefMapping(SearchMapping, String, Class<?>) - Constructor for class org.hibernate.search.cfg.FullTextFilterDefMapping
 
FullTextFilterDefs - Annotation Type in org.hibernate.search.annotations
A list of FullTextFilterDef
FullTextFilterImpl - Class in org.hibernate.search.query
 
FullTextFilterImpl() - Constructor for class org.hibernate.search.query.FullTextFilterImpl
 
FullTextFilterImplementor - Interface in org.hibernate.search.filter
 
FullTextIndexEventListener - Class in org.hibernate.search.event
This listener supports setting a parent directory for all generated index files.
FullTextIndexEventListener() - Constructor for class org.hibernate.search.event.FullTextIndexEventListener
Deprecated. As of Hibernate Search 3.3. This method was used for instantiating the event listener when configured in a configuration file. Since Hibernate Core 3.6 Hibernate Search will always be automatically enabled if available on the classpath.
FullTextIndexEventListener(FullTextIndexEventListener.Installation) - Constructor for class org.hibernate.search.event.FullTextIndexEventListener
 
FullTextIndexEventListener.Installation - Enum in org.hibernate.search.event
 
FullTextManager - Interface in org.hibernate.search.sandbox.standalone
 
FullTextQuery - Interface in org.hibernate.search
The base interface for Lucene powered searches.
FullTextQuery - Interface in org.hibernate.search.jpa
The base interface for lucene powered searches.
FullTextQuery - Interface in org.hibernate.search.sandbox.standalone
 
FullTextQueryImpl - Class in org.hibernate.search.jpa.impl
Implements JPA 2 query interface and delegate the call to a Hibernate Core FullTextQuery.
FullTextQueryImpl(FullTextQuery, Session) - Constructor for class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
FullTextQueryImpl - Class in org.hibernate.search.query
Implementation of FullTextQuery.
FullTextQueryImpl(Query, Class<?>[], SessionImplementor, ParameterMetadata) - Constructor for class org.hibernate.search.query.FullTextQueryImpl
Constructs a FullTextQueryImpl instance.
FullTextSession - Interface in org.hibernate.search
Extends the Hibernate Session with fulltext search and indexing capabilities.
FullTextSessionImpl - Class in org.hibernate.search.impl
Lucene full text search aware session.
FullTextSessionImpl(Session) - Constructor for class org.hibernate.search.impl.FullTextSessionImpl
 
fuzzy() - Method in interface org.hibernate.search.query.dsl.TermContext
Use a fuzzy search approximation (aka edit distance)
FuzzyContext - Interface in org.hibernate.search.query.dsl
 

G

GENERATE_STATS - Static variable in class org.hibernate.search.Environment
If set to true the search statistic will be gathered.
get(Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
get(String, Document) - Method in class org.hibernate.search.bridge.builtin.DoubleNumericFieldBridge
 
get(String, Document) - Method in class org.hibernate.search.bridge.builtin.FloatNumericFieldBridge
 
get(String, Document) - Method in class org.hibernate.search.bridge.builtin.IntegerNumericFieldBridge
 
get(String, Document) - Method in class org.hibernate.search.bridge.builtin.LongNumericFieldBridge
 
get(String, Document) - Method in class org.hibernate.search.bridge.NullEncodingTwoWayFieldBridge
 
get(String, Document) - Method in interface org.hibernate.search.bridge.TwoWayFieldBridge
Build the element object from the Document
get(String, Document) - Method in class org.hibernate.search.bridge.TwoWayString2FieldBridgeAdaptor
 
get(String, Document) - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
get(Class, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
get(Class, Serializable, LockMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
get(Class, Serializable, LockOptions) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
get(String, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
get(String, Serializable, LockMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
get(String, Serializable, LockOptions) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
get() - Method in interface org.hibernate.search.query.dsl.EntityContext
return the query builder
get() - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryContextBuilder.HSearchEntityContext
 
get() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
get(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
get(Class<T>, Serializable) - Method in interface org.hibernate.search.sandbox.standalone.FullTextManager
Returns the entity instance of a given type and id value
get(Class<T>, Serializable) - Method in class org.hibernate.search.sandbox.standalone.LuceneFullTextManager
 
get(Object) - Method in class org.hibernate.search.util.SoftLimitMRUCache
Gets an object from the cache.
get(Object) - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns the value to which the specified key is mapped in this weak hash map, or null if the map contains no mapping for this key.
getAddress() - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
Cluster's node address
getAnalyzer(String) - Method in class org.hibernate.search.backend.Workspace
 
getAnalyzer() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getAnalyzer(XAnnotatedElement, ConfigContext) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getAnalyzer(String) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getAnalyzer(Class<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getAnalyzer(String) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getAnalyzer(Class<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getAnalyzer(String) - Method in interface org.hibernate.search.SearchFactory
Retrieve an analyzer instance by its definition name
getAnalyzer(Class<?>) - Method in interface org.hibernate.search.SearchFactory
Retrieves the scoped analyzer for a given class.
getAnalyzerDefinitionName(Object, Object, String) - Method in interface org.hibernate.search.analyzer.Discriminator
Allows to specify the analyzer to be used for the given field based on the specified entity state.
getAnalyzerDefs() - Method in class org.hibernate.search.cfg.SearchMapping
 
getAnalyzerDiscriminator() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getAnalyzerDiscriminator() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getAnalyzers() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getAnalyzers() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getAnalyzers() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getAnalyzers() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getAnnotationReader(AnnotatedElement) - Method in class org.hibernate.search.impl.MappingModelMetadataProvider
 
getAttributeName(XMember, String) - Static method in class org.hibernate.search.util.ReflectionHelper
Get attribute name out of member unless overriden by name.
getBackendQueueProcessorFactory() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getBackendQueueProcessorFactory() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getBackendQueueProcessorFactory() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getBackendQueueProcessorFactory() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getBackendQueueProcessorFactory() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getBatcher() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getBatchIndexParameters() - Method in class org.hibernate.search.backend.LuceneIndexingParameters
 
getBatchSize() - Method in class org.hibernate.search.jmx.IndexControl
 
getBatchSize() - Method in interface org.hibernate.search.jmx.IndexControlMBean
 
getBeanClass() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getBeanXClass() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getBigDecimal(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getBigInteger(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getBinary(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getBlob(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getBoolean(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getBoost() - Method in interface org.hibernate.search.bridge.LuceneOptions
Prefer the use of LuceneOptions.addFieldToDocument(String, String, org.apache.lucene.document.Document) over manually building your Field objects and adding them to the Document.
getBoost() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getBoost(XProperty, Field) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getBridge(String) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getByte(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getCacheBitResultsSize() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getCacheBitResultsSize() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getCacheBitResultsSize() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getCacheBitResultsSize() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getCachedFilter(FilterKey) - Method in interface org.hibernate.search.filter.FilterCachingStrategy
Retrieve the cached filter for a given key or null if not cached
getCachedFilter(FilterKey) - Method in class org.hibernate.search.filter.MRUFilterCachingStrategy
 
getCacheMode() - Method in class org.hibernate.search.engine.FilterDef
 
getCacheMode() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getCalendar(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getCalendarBridge() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getCalendarField(Resolution) - Static method in class org.hibernate.search.bridge.BridgeFactory
 
getChannel() - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
getCharacter(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getClass(T) - Static method in class org.hibernate.search.util.HibernateHelper
Get the real class type.
getClassBoost(Object) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
getClassBridgeDefs() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getClasses() - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
getClassesInDirectoryProvider(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getClassesInDirectoryProvider(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getClassesInDirectoryProvider(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getClassesInDirectoryProvider(DirectoryProvider<?>) - Method in interface org.hibernate.search.spi.WorkerBuildContext
 
getClassFromWork(Work<T>) - Static method in class org.hibernate.search.util.HibernateHelper
 
getClassLuceneOptions(int) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
getClassMapping(String) - Method in interface org.hibernate.search.cfg.SearchConfiguration
Returns a Class from a String parameter.
getClassMapping(String) - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
getClassMapping(String) - Method in class org.hibernate.search.impl.IncrementalSearchConfiguration
 
getClassMappings() - Method in interface org.hibernate.search.cfg.SearchConfiguration
Returns an iterator over the list of indexed classes
getClassMappings() - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
getClassMappings() - Method in class org.hibernate.search.impl.IncrementalSearchConfiguration
 
getClob(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getClusterName() - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
getConfigurationProperties() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getConfigurationProperties() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getConfigurationProperties() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getConfigurationProperties() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getContainedIn() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getContextEntityIdentifier(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getCopyBufferSize(String, Properties) - Static method in class org.hibernate.search.store.DirectoryProviderHelper
Users may configure the number of MB to use as "chunk size" for large file copy operations performed by DirectoryProviders.
getCriteriaBuilder() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getCurrentLockMode(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getCurrentValueFor(IndexWriterSetting) - Method in class org.hibernate.search.backend.LuceneIndexingParameters.ParameterSet
 
getDate(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getDateBridge() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getDateField(Resolution) - Static method in class org.hibernate.search.bridge.BridgeFactory
 
getDefaultAnalyzer() - Method in class org.hibernate.search.impl.ConfigContext
 
getDefaultNullToken() - Method in class org.hibernate.search.impl.ConfigContext
 
getDefaults() - Method in class org.hibernate.search.impl.MappingModelMetadataProvider
 
getDefaultSimilarity() - Method in class org.hibernate.search.impl.ConfigContext
 
getDelegate(AddLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.DpSelectionVisitor
 
getDelegate(DeleteLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.DpSelectionVisitor
 
getDelegate(OptimizeLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.DpSelectionVisitor
 
getDelegate(PurgeAllLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.DpSelectionVisitor
 
getDelegate(AddLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.works.LuceneWorkVisitor
 
getDelegate(DeleteLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.works.LuceneWorkVisitor
 
getDelegate(OptimizeLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.works.LuceneWorkVisitor
 
getDelegate(PurgeAllLuceneWork) - Method in class org.hibernate.search.backend.impl.lucene.works.LuceneWorkVisitor
 
getDelegate(AddLuceneWork) - Method in interface org.hibernate.search.backend.WorkVisitor
 
getDelegate(DeleteLuceneWork) - Method in interface org.hibernate.search.backend.WorkVisitor
 
getDelegate(OptimizeLuceneWork) - Method in interface org.hibernate.search.backend.WorkVisitor
 
getDelegate(PurgeAllLuceneWork) - Method in interface org.hibernate.search.backend.WorkVisitor
 
getDelegate() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getDirectory() - Method in interface org.hibernate.search.store.DirectoryProvider
Returns an initialized Lucene Directory.
getDirectory() - Method in class org.hibernate.search.store.FSDirectoryProvider
 
getDirectory() - Method in class org.hibernate.search.store.FSMasterDirectoryProvider
 
getDirectory() - Method in class org.hibernate.search.store.FSSlaveDirectoryProvider
 
getDirectory() - Method in class org.hibernate.search.store.RAMDirectoryProvider
 
getDirectoryProviderData() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDirectoryProviderData() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDirectoryProviderData() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getDirectoryProviderData() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getDirectoryProviderForAddition(Class<?>, Serializable, String, Document) - Method in class org.hibernate.search.store.IdHashShardingStrategy
 
getDirectoryProviderForAddition(Class<?>, Serializable, String, Document) - Method in interface org.hibernate.search.store.IndexShardingStrategy
return the DirectoryProvider where the given entity will be indexed
getDirectoryProviderForAddition(Class<?>, Serializable, String, Document) - Method in class org.hibernate.search.store.NotShardedStrategy
 
getDirectoryProviderIndexingParams() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDirectoryProviderIndexingParams() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDirectoryProviderIndexingParams() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getDirectoryProviderIndexingParams() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getDirectoryProviderLock(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDirectoryProviderLock(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDirectoryProviderLock(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDirectoryProviderLock(DirectoryProvider<?>) - Method in interface org.hibernate.search.spi.BuildContext
This method cannot be used in initialize methods.
getDirectoryProviders() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getDirectoryProviders() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDirectoryProviders() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDirectoryProviders(Class<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDirectoryProviders() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDirectoryProviders(Class<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDirectoryProviders(Class<?>) - Method in interface org.hibernate.search.SearchFactory
Provide access to the DirectoryProviders for a given entity.
getDirectoryProviders() - Method in interface org.hibernate.search.spi.BuildContext
 
getDirectoryProviderSelectionStrategy() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getDirectoryProvidersForAllShards() - Method in class org.hibernate.search.store.IdHashShardingStrategy
 
getDirectoryProvidersForAllShards() - Method in interface org.hibernate.search.store.IndexShardingStrategy
Ask for all shards (eg to query or optimize)
getDirectoryProvidersForAllShards() - Method in class org.hibernate.search.store.NotShardedStrategy
 
getDirectoryProvidersForDeletion(Class<?>, Serializable, String) - Method in class org.hibernate.search.store.IdHashShardingStrategy
 
getDirectoryProvidersForDeletion(Class<?>, Serializable, String) - Method in interface org.hibernate.search.store.IndexShardingStrategy
return the DirectoryProvider(s) where the given entity is stored and where the deletion operation needs to be applied id and idInString can be null.
getDirectoryProvidersForDeletion(Class<?>, Serializable, String) - Method in class org.hibernate.search.store.NotShardedStrategy
 
getDirectoryProvidersForQuery(FullTextFilterImplementor[]) - Method in class org.hibernate.search.store.IdHashShardingStrategy
 
getDirectoryProvidersForQuery(FullTextFilterImplementor[]) - Method in interface org.hibernate.search.store.IndexShardingStrategy
return the set of DirectoryProvider(s) where the entities matching the filters are stored this optional optimization allows queries to hit a subset of all shards, which may be useful for some datasets if this optimization is not needed, return getDirectoryProvidersForAllShards() fullTextFilters can be empty if no filter is applied
getDirectoryProvidersForQuery(FullTextFilterImplementor[]) - Method in class org.hibernate.search.store.NotShardedStrategy
 
getDirLock() - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
getDocIdSet(IndexReader) - Method in class org.hibernate.search.filter.CachingWrapperFilter
 
getDocIdSet(IndexReader) - Method in class org.hibernate.search.filter.ChainedFilter
 
getDocument() - Method in class org.hibernate.search.backend.LuceneWork
 
getDocument(T, Serializable, Map<String, String>) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
Builds the Lucene Document for a given entity instance and its id.
getDocumentBuilder(Class<T>) - Method in class org.hibernate.search.backend.Workspace
 
getDocumentBuilderContainedEntity(Class<T>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDocumentBuilderContainedEntity(Class<T>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDocumentBuilderContainedEntity(Class<T>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDocumentBuilderIndexedEntity(Class<T>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDocumentBuilderIndexedEntity(Class<T>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDocumentBuilderIndexedEntity(Class<T>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDocumentBuilderIndexedEntity(Class<T>) - Method in interface org.hibernate.search.spi.WorkerBuildContext
 
getDocumentBuildersContainedEntities() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDocumentBuildersContainedEntities() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDocumentBuildersContainedEntities() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getDocumentBuildersContainedEntities() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getDocumentBuildersIndexedEntities() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDocumentBuildersIndexedEntities() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getDocumentBuildersIndexedEntities() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getDocumentBuildersIndexedEntities() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getDocumentBuildersIndexedEntities() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getDocumentClass(Document) - Static method in class org.hibernate.search.engine.DocumentBuilderHelper
 
getDocumentFields(SearchFactoryImplementor, Class<?>, Document, String[]) - Static method in class org.hibernate.search.engine.DocumentBuilderHelper
 
getDocumentId() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getDocumentId(SearchFactoryImplementor, Class<?>, Document) - Static method in class org.hibernate.search.engine.DocumentBuilderHelper
 
getDocumentIdName(SearchFactoryImplementor, Class<?>) - Static method in class org.hibernate.search.engine.DocumentBuilderHelper
 
getDocumentsAddedCount() - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
getDocumentsAddedCount() - Method in interface org.hibernate.search.jmx.IndexingProgressMonitorMBean
 
getDontFlushFromFind() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getDouble(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getDynamicBoost() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getDynamicBoost() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getDynamicBoost(XProperty) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getEnabledFilter(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getEnabledFilters() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getEntitiesInDirectory() - Method in class org.hibernate.search.backend.Workspace
 
getEntity() - Method in class org.hibernate.search.backend.Work
 
getEntityClass() - Method in class org.hibernate.search.backend.LuceneWork
 
getEntityClass() - Method in class org.hibernate.search.backend.Work
 
getEntityDescriptor(Class<?>) - Method in class org.hibernate.search.cfg.SearchMapping
 
getEntityManagerFactory() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getEntityMode() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getEntityName(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getEntityPersister(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getEntityState() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getEntityType() - Method in class org.hibernate.search.query.dsl.impl.QueryBuildingContext
 
getEntityUsingInterceptor(EntityKey) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getErrorHandler() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getErrorHandler() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getErrorHandler() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getErrorHandler() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getErrorHandler() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getErrorHandler() - Method in interface org.hibernate.search.spi.WorkerBuildContext
 
getFactory() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getFactory() - Method in class org.hibernate.search.query.dsl.impl.QueryBuildingContext
 
getFactoryMethod() - Method in class org.hibernate.search.engine.FilterDef
 
getFailingOperations() - Method in interface org.hibernate.search.exception.ErrorContext
 
getFailingOperations() - Method in class org.hibernate.search.exception.impl.SingleErrorContext
 
getFetchProfile() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getField() - Method in class org.hibernate.search.query.dsl.impl.FieldContext
 
getFieldCustomizer() - Method in class org.hibernate.search.query.dsl.impl.FieldContext
 
getFieldLuceneOptions(int, Object) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
getFieldPosition(String[], String) - Static method in class org.hibernate.search.engine.DocumentBuilderHelper
 
getFields() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getFieldToAnalyzerMap() - Method in class org.hibernate.search.backend.AddLuceneWork
 
getFilterCacheBitResultsSize() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getFilterCacheBitResultsSize() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getFilterCacheBitResultsSize() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getFilterCachingStrategy() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getFilterCachingStrategy() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getFilterCachingStrategy() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getFilterCachingStrategy() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getFilterCachingStrategy() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getFilterDefinition(String) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getFilterDefinition(String) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getFilterDefinition(String) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getFilterDefinitions() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getFilterDefinitions() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getFilterDefinitions() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getFilterDefinitions() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getFilterParameterType(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getFilterParameterValue(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getFirstResult() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getFloat(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getFlushMode() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getFlushMode() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getFlushMode() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getFrom() - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
getFullTextEntityManager(EntityManager) - Static method in class org.hibernate.search.jpa.Search
Build a full text capable EntityManager The underlying EM implementation has to be Hibernate EntityManager
getFullTextFilerDefs() - Method in class org.hibernate.search.cfg.SearchMapping
 
getFullTextFilterDefs() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getFullTextSession(Session) - Static method in class org.hibernate.search.Search
 
getHints() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getId() - Method in class org.hibernate.search.backend.LuceneWork
 
getId() - Method in class org.hibernate.search.backend.Work
 
getId(Object) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
In case of an indexed entity, return the value of it's identifier: what is marked as @Id or @DocumentId; in case the entity uses @ProvidedId, it's illegal to call this method.
getId(Object) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getId(Object) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
Return the id used for indexing if possible An IllegalStateException otherwise

If the id is provided, we can't extract it from the entity

getIdBridge() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getIdentifier(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getIdentifierName() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getIdGetter() - Method in class org.hibernate.search.backend.Work
 
getIdGetter() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getIdInString() - Method in class org.hibernate.search.backend.LuceneWork
 
getIdKeywordName() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getImpl() - Method in class org.hibernate.search.engine.FilterDef
 
getImpl() - Method in class org.hibernate.search.filter.FilterKey
Represent the @FullTextFilterDef.impl class
getIndex() - Method in interface org.hibernate.search.bridge.LuceneOptions
Prefer the use of LuceneOptions.addFieldToDocument(String, String, org.apache.lucene.document.Document) over manually building your Field objects and adding them to the Document.
getIndex(Index) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getIndexed() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getIndexedClasses(Class<?>[]) - Method in class org.hibernate.search.spi.internals.PolymorphicIndexHierarchy
 
getIndexedClassNames() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getIndexedClassNames() - Method in interface org.hibernate.search.stat.Statistics
Returns a list of all indexed classes.
getIndexedClassNames() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getIndexedTypesPolymorphic(Class<?>[]) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getIndexedTypesPolymorphic(Class<?>[]) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getIndexedTypesPolymorphic(Class<?>[]) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getIndexEmbedded() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getIndexHierarchy() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getIndexHierarchy() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getIndexHierarchy() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getIndexHierarchy() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getIndexingParameters(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getIndexingParameters(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getIndexingParameters(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getIndexingParameters(DirectoryProvider<?>) - Method in interface org.hibernate.search.spi.WorkerBuildContext
 
getIndexingStrategy() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getIndexingStrategy() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getIndexingStrategy() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getIndexingStrategy() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getIndexingStrategy() - Method in interface org.hibernate.search.spi.BuildContext
 
getIndexingStrategy() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getIndexReaders(Searchable) - Static method in class org.hibernate.search.reader.ReaderProviderHelper
Find the underlying IndexReaders for the given searchable
getIndexReaders(IndexReader) - Static method in class org.hibernate.search.reader.ReaderProviderHelper
Find the underlying IndexReaders for the given reader
getIndexWriter(boolean, ErrorContextBuilder) - Method in class org.hibernate.search.backend.Workspace
Gets the IndexWriter, opening one if needed.
getIndexWriter(boolean) - Method in class org.hibernate.search.backend.Workspace
 
getInitialContext(Properties, String) - Static method in class org.hibernate.search.util.JNDIHelper
Creates an initial context
getInteger(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getInterceptor() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getIntValue(Properties, String, int) - Static method in class org.hibernate.search.backend.configuration.ConfigurationParseHelper
Looks for a numeric value in the Properties, returning defValue if not found or if an empty string is found.
getJDBCContext() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getJMSFactory() - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
getJmsQueue() - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
getJmsQueueName() - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
getJndiProperties(Properties, String) - Static method in class org.hibernate.search.util.JNDIHelper
 
getKey() - Method in enum org.hibernate.search.backend.configuration.IndexWriterSetting
 
getKeyMethod() - Method in class org.hibernate.search.engine.FilterDef
 
getLazyAnalyzers() - Method in class org.hibernate.search.impl.ConfigContext
 
getLines(String) - Method in class org.hibernate.search.util.HibernateSearchResourceLoader
 
getListeners() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getLoadedEntitiesCount() - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
getLoadedEntitiesCount() - Method in interface org.hibernate.search.jmx.IndexingProgressMonitorMBean
 
getLoadQueryInfluencers() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getLobHelper() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getLocale(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getLockMode(Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getLockMode() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getLockModes() - Method in class org.hibernate.search.query.FullTextQueryImpl
 
getLockOptions() - Method in class org.hibernate.search.query.FullTextQueryImpl
 
getLong(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getLuceneMatchVersion() - Method in class org.hibernate.search.impl.ConfigContext
 
getLuceneResolution(Resolution) - Static method in class org.hibernate.search.bridge.builtin.DateResolutionUtil
 
getMappedSubclasses() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getMasterListener() - Method in class org.hibernate.search.backend.impl.jgroups.MasterJGroupsBackendQueueProcessorFactory
 
getMaxResults() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getMemberValue(Object, XMember) - Static method in class org.hibernate.search.util.ReflectionHelper
 
getMetadata() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getMetamodel() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getName() - Method in class org.hibernate.search.engine.FilterDef
 
getName() - Method in interface org.hibernate.search.filter.FullTextFilterImplementor
 
getName() - Method in class org.hibernate.search.query.FullTextFilterImpl
 
getName() - Method in class org.hibernate.search.util.DelegateNamedAnalyzer
 
getNamedQuery(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getNamedSQLQuery(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getNonFlushedChanges() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getNumberOfEntitiesToIndex() - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
getNumberOfEntitiesToIndex() - Method in interface org.hibernate.search.jmx.IndexingProgressMonitorMBean
 
getNumberOfFetchingThreads() - Method in class org.hibernate.search.jmx.IndexControl
 
getNumberOfFetchingThreads() - Method in interface org.hibernate.search.jmx.IndexControlMBean
 
getNumberOfIndexedEntities(String) - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getNumberOfIndexedEntities(String) - Method in interface org.hibernate.search.stat.Statistics
Returns the number of documents for the given entity.
getNumberOfIndexedEntities(String) - Method in class org.hibernate.search.stat.StatisticsImpl
 
getNumberOfObjectLoadingThreads() - Method in class org.hibernate.search.jmx.IndexControl
 
getNumberOfObjectLoadingThreads() - Method in interface org.hibernate.search.jmx.IndexControlMBean
 
getNumericFields() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getObjectLoadingExecutionAvgTime() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getObjectLoadingExecutionAvgTime() - Method in interface org.hibernate.search.stat.Statistics
Get the average object loading time in nanoseconds.
getObjectLoadingExecutionAvgTime() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getObjectLoadingExecutionMaxTime() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getObjectLoadingExecutionMaxTime() - Method in interface org.hibernate.search.stat.Statistics
Get the time in nanoseconds for the slowest object load.
getObjectLoadingExecutionMaxTime() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getObjectLoadingTotalTime() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getObjectLoadingTotalTime() - Method in interface org.hibernate.search.stat.Statistics
Get the total object loading in nanoseconds.
getObjectLoadingTotalTime() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getObjectsLoadedCount() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getObjectsLoadedCount() - Method in interface org.hibernate.search.stat.Statistics
Gets the total number of objects loaded
getObjectsLoadedCount() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getOperationAtFault() - Method in interface org.hibernate.search.exception.ErrorContext
 
getOperationAtFault() - Method in class org.hibernate.search.exception.impl.SingleErrorContext
 
getOptimizerStrategy(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getOptimizerStrategy(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getOptimizerStrategy(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getOptimizerStrategy() - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
getOptimizerStrategy(DirectoryProvider<?>) - Method in interface org.hibernate.search.spi.WorkerBuildContext
 
getParameter(String) - Method in interface org.hibernate.search.FullTextFilter
 
getParameter(String) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getParameter(int) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getParameter(String, Class<T>) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getParameter(int, Class<T>) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getParameter(String) - Method in class org.hibernate.search.query.FullTextFilterImpl
 
getParameters() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getParameters() - Method in class org.hibernate.search.query.FullTextFilterImpl
 
getParameterValue(Parameter<T>) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getParameterValue(String) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getParameterValue(int) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getPersistenceContext() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getPlannedLuceneWork() - Method in class org.hibernate.search.engine.WorkPlan
Converts the current plan into a list of LuceneWork, something that the backends can actually perform to execute the plan.
getPositionIncrementGap(String) - Method in class org.hibernate.search.util.DelegateNamedAnalyzer
 
getPositionIncrementGap(String) - Method in class org.hibernate.search.util.ScopedAnalyzer
 
getPrecisionStep(NumericField) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getProcessor(List<LuceneWork>) - Method in interface org.hibernate.search.backend.BackendQueueProcessorFactory
Return a runnable implementation responsible for processing the queue to a given backend.
getProcessor(List<LuceneWork>) - Method in class org.hibernate.search.backend.impl.blackhole.BlackHoleBackendQueueProcessorFactory
 
getProcessor(List<LuceneWork>) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
getProcessor(List<LuceneWork>) - Method in class org.hibernate.search.backend.impl.jgroups.MasterJGroupsBackendQueueProcessorFactory
 
getProcessor(List<LuceneWork>) - Method in class org.hibernate.search.backend.impl.jgroups.SlaveJGroupsBackendQueueProcessorFactory
 
getProcessor(List<LuceneWork>) - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
getProcessor(List<LuceneWork>) - Method in class org.hibernate.search.backend.impl.lucene.LuceneBackendQueueProcessorFactory
 
getProgrammaticMapping() - Method in interface org.hibernate.search.cfg.SearchConfiguration
 
getProgrammaticMapping() - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
getProgrammaticMapping() - Method in class org.hibernate.search.impl.IncrementalSearchConfiguration
 
getProperties() - Method in interface org.hibernate.search.cfg.SearchConfiguration
Gets properties as a java.util.Properties object.
getProperties() - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
getProperties() - Method in class org.hibernate.search.impl.IncrementalSearchConfiguration
 
getProperties() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getProperty(String) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
getProperty(String, String) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
getProperty(String) - Method in interface org.hibernate.search.cfg.SearchConfiguration
Gets a configuration property from its name or null if not present
getProperty(String) - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
getProperty(String) - Method in class org.hibernate.search.impl.IncrementalSearchConfiguration
 
getPropertyDescriptor(String, ElementType) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getProvidedId() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getProvidedServices() - Method in interface org.hibernate.search.cfg.SearchConfiguration
Provide service instances.
getProvidedServices() - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
getProvidedServices() - Method in class org.hibernate.search.impl.IncrementalSearchConfiguration
 
getProviders() - Method in class org.hibernate.search.store.DirectoryProviderFactory.DirectoryProviders
 
getQueryAnalyzer() - Method in class org.hibernate.search.query.dsl.impl.QueryBuildingContext
 
getReaderProvider() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getReaderProvider() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getReaderProvider() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getReaderProvider() - Method in interface org.hibernate.search.SearchFactory
 
getReaderProvider() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getReference(Class<T>, Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getReflectionManager() - Method in interface org.hibernate.search.cfg.SearchConfiguration
Returns a reflection manager if already available in the environment null otherwise
getReflectionManager() - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
getReflectionManager() - Method in class org.hibernate.search.impl.IncrementalSearchConfiguration
 
getResources(String, Class<?>) - Static method in class org.hibernate.search.util.ClassLoaderHelper
 
getResultList() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getResultSize() - Method in interface org.hibernate.search.FullTextQuery
Returns the number of hits for this search

Caution: The number of results might be slightly different from list().size() because list() if the index is not in sync with the database at the time of query.

getResultSize() - Method in interface org.hibernate.search.jpa.FullTextQuery
Returns the number of hits for this search Caution: The number of results might be slightly different from getResultList().size() because getResultList() may be not in sync with the database at the time of query.
getResultSize() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getResultSize() - Method in class org.hibernate.search.query.FullTextQueryImpl
 
getRowNumber() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
getSealedQueue() - Method in class org.hibernate.search.backend.WorkQueue
 
getSearchFactory() - Method in interface org.hibernate.search.FullTextSession
 
getSearchFactory() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getSearchFactory() - Method in interface org.hibernate.search.jpa.FullTextEntityManager
 
getSearchFactory() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getSearchFactory() - Method in interface org.hibernate.search.sandbox.standalone.FullTextManager
 
getSearchFactory() - Method in class org.hibernate.search.sandbox.standalone.LuceneFullTextManager
 
getSearchFactory(Session) - Static method in class org.hibernate.search.util.ContextHelper
Deprecated.  
getSearchFactoryBySFI(SessionImplementor) - Static method in class org.hibernate.search.util.ContextHelper
Deprecated.  
getSearchFactoryImplementor() - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
getSearchMapping(SearchConfiguration) - Static method in class org.hibernate.search.impl.SearchMappingBuilder
This factory method takes a SearchConfiguration object and returns a SearchMapping object which defines the programmatic model for indexing entities and fields.
getSearchQueryExecutionAvgTime() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getSearchQueryExecutionAvgTime() - Method in interface org.hibernate.search.stat.Statistics
Get the average search time in nanoseconds.
getSearchQueryExecutionAvgTime() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getSearchQueryExecutionCount() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getSearchQueryExecutionCount() - Method in interface org.hibernate.search.stat.Statistics
Get global number of executed search queries
getSearchQueryExecutionCount() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getSearchQueryExecutionMaxTime() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getSearchQueryExecutionMaxTime() - Method in interface org.hibernate.search.stat.Statistics
Get the time in nanoseconds of the slowest search.
getSearchQueryExecutionMaxTime() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getSearchQueryExecutionMaxTimeQueryString() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getSearchQueryExecutionMaxTimeQueryString() - Method in interface org.hibernate.search.stat.Statistics
Get the query string for the slowest query.
getSearchQueryExecutionMaxTimeQueryString() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getSearchQueryTotalTime() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getSearchQueryTotalTime() - Method in interface org.hibernate.search.stat.Statistics
Get the total search time in nanoseconds.
getSearchQueryTotalTime() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getSearchVersion() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
getSearchVersion() - Method in interface org.hibernate.search.stat.Statistics
Returns the Hibernate Search version.
getSearchVersion() - Method in class org.hibernate.search.stat.StatisticsImpl
 
getSelectionStrategy() - Method in class org.hibernate.search.store.DirectoryProviderFactory.DirectoryProviders
 
getSentence() - Method in class org.hibernate.search.query.dsl.impl.PhraseQueryContext
 
getService() - Method in interface org.hibernate.search.spi.ServiceProvider
 
getServiceManager() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getServiceManager() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getServiceManager() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getServiceManager() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getSession() - Method in class org.hibernate.search.backend.impl.jms.AbstractJMSHibernateSearchController
Return the current or give a new session This session is not used per se, but is the link to access the Search configuration.
getSession(EntityMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getSessionFactory() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getShort(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getSimilarity() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getSimilarity() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getSimilarity(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getSimilarity(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getSimilarity(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getSimilarity() - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
getSimilarity(DirectoryProvider<?>) - Method in interface org.hibernate.search.spi.WorkerBuildContext
 
getSimilarity() - Method in class org.hibernate.search.store.DirectoryProviderFactory.DirectoryProviders
 
getSingleResult() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
getSlop() - Method in class org.hibernate.search.query.dsl.impl.PhraseQueryContext
 
getSourceDirectory(String, Properties, boolean) - Static method in class org.hibernate.search.store.DirectoryProviderHelper
Build a directory name out of a root and relative path, guessing the significant part and checking for the file availability
getState() - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsMasterMessageListener
 
getStatistics() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getStatistics() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getStatistics() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getStatistics() - Method in interface org.hibernate.search.SearchFactory
Retrieve the statistics instance for this factory.
getStatisticsImplementor() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
Retrieve the statistics implementor instance for this factory.
getStatisticsImplementor() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getStatisticsImplementor() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getStatusMessagePeriod() - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
getStore() - Method in interface org.hibernate.search.bridge.LuceneOptions
Prefer the use of LuceneOptions.addFieldToDocument(String, String, org.apache.lucene.document.Document) over manually building your Field objects and adding them to the Document.
getString(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getSubReadersFromMultiReader(MultiReader) - Static method in class org.hibernate.search.reader.ReaderProviderHelper
 
getTerm(Serializable) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getTermVector() - Method in interface org.hibernate.search.bridge.LuceneOptions
Prefer the use of LuceneOptions.addFieldToDocument(String, String, org.apache.lucene.document.Document) over manually building your Field objects and adding them to the Document.
getTermVector(TermVector) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
getText(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getThrowable() - Method in interface org.hibernate.search.exception.ErrorContext
 
getThrowable() - Method in class org.hibernate.search.exception.impl.SingleErrorContext
 
getTimeoutLeftInMilliseconds() - Method in class org.hibernate.search.query.TimeoutManager
 
getTimeoutLeftInSeconds() - Method in class org.hibernate.search.query.TimeoutManager
 
getTimestamp() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getTimeZone(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getTo() - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
getTransaction() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getTransaction() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
getTransactionIdentifier() - Method in class org.hibernate.search.backend.impl.EventSourceTransactionContext
 
getTransactionIdentifier() - Method in interface org.hibernate.search.backend.TransactionContext
 
getTransactionIdentifier() - Method in class org.hibernate.search.sandbox.standalone.InstanceTransactionContext
 
getTransactionIndexParameters() - Method in class org.hibernate.search.backend.LuceneIndexingParameters
 
getType() - Method in class org.hibernate.search.backend.Work
 
getType(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getType() - Method in class org.hibernate.search.query.TimeoutManager
 
getTypeHelper() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getUninitializedSearchFactory() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getUninitializedSearchFactory() - Method in interface org.hibernate.search.spi.BuildContext
Returns the SessionFactoryImplementor instance.
getVerifiedIndexDir(String, Properties, boolean) - Static method in class org.hibernate.search.store.DirectoryProviderHelper
Verify the index directory exists and is writable, or creates it if not existing.
getVersionString() - Static method in class org.hibernate.search.Version
 
getWorkDelegate(WorkVisitor<T>) - Method in class org.hibernate.search.backend.AddLuceneWork
 
getWorkDelegate(WorkVisitor<T>) - Method in class org.hibernate.search.backend.DeleteLuceneWork
 
getWorkDelegate(WorkVisitor<T>) - Method in class org.hibernate.search.backend.LuceneWork
 
getWorkDelegate(WorkVisitor<T>) - Method in class org.hibernate.search.backend.OptimizeLuceneWork
 
getWorkDelegate(WorkVisitor<T>) - Method in class org.hibernate.search.backend.PurgeAllLuceneWork
 
getWorker() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
getWorker() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
getWorker() - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
getWorker() - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
getWorker() - Method in interface org.hibernate.search.spi.SearchFactoryIntegrator
 
guessEntityName(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
guessType(Field, NumericField, XMember, ReflectionManager) - Static method in class org.hibernate.search.bridge.BridgeFactory
 

H

handle(ErrorContext) - Method in interface org.hibernate.search.exception.ErrorHandler
 
handle(ErrorContext) - Method in class org.hibernate.search.exception.impl.LogErrorHandler
 
handleMergeException(Throwable) - Method in class org.hibernate.search.backend.impl.lucene.overrides.ConcurrentMergeScheduler
 
hasErrors() - Method in interface org.hibernate.search.exception.ErrorContext
 
hasErrors() - Method in class org.hibernate.search.exception.impl.SingleErrorContext
 
hashCode() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
hashCode() - Method in class org.hibernate.search.backend.LuceneIndexingParameters.ParameterSet
 
hashCode() - Method in class org.hibernate.search.filter.CachingWrapperFilter
 
hashCode() - Method in class org.hibernate.search.filter.FilterKey
 
hashCode() - Method in class org.hibernate.search.filter.StandardFilterKey
 
hashCode() - Method in class org.hibernate.search.reader.CacheableMultiReader
 
hashCode() - Method in class org.hibernate.search.store.FSDirectoryProvider
 
hashCode() - Method in class org.hibernate.search.store.FSMasterDirectoryProvider
 
hashCode() - Method in class org.hibernate.search.store.FSSlaveDirectoryProvider
 
hashCode() - Method in class org.hibernate.search.store.RAMDirectoryProvider
 
hasNext() - Method in class org.hibernate.search.query.IteratorImpl
 
hasPartialResults() - Method in interface org.hibernate.search.FullTextQuery
*Experimental* API, subject to change or removal When using FullTextQuery.limitExecutionTimeTo(long, java.util.concurrent.TimeUnit) }, returns true if partial results are returned (ie if the time limit has been reached and the result fetching process has been terminated.
hasPartialResults() - Method in interface org.hibernate.search.jpa.FullTextQuery
*Experimental* API, subject to change or removal When using FullTextQuery.limitExecutionTimeTo(long, java.util.concurrent.TimeUnit) }, returns true if partial results are returned (ie if the time limit has been reached and the result fetching process has been terminated.
hasPartialResults() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
hasPartialResults() - Method in class org.hibernate.search.query.FullTextQueryImpl
 
hasPartialResults() - Method in class org.hibernate.search.query.TimeoutManager
 
HibernateHelper - Class in org.hibernate.search.util
 
HibernateSearchResourceLoader - Class in org.hibernate.search.util
 
HibernateSearchResourceLoader() - Constructor for class org.hibernate.search.util.HibernateSearchResourceLoader
 
HibernateSearchResourceLoader(String) - Constructor for class org.hibernate.search.util.HibernateSearchResourceLoader
 

I

id - Variable in class org.hibernate.search.engine.EntityInfo
The document id.
ID - Static variable in interface org.hibernate.search.ProjectionConstants
Object id property
IdentifierConsumerEntityProducer - Class in org.hibernate.search.batchindexing
This Runnable is consuming entity identifiers and producing loaded detached entities for the next queue.
IdentifierConsumerEntityProducer(ProducerConsumerQueue<List<Serializable>>, ProducerConsumerQueue<List<?>>, MassIndexerProgressMonitor, SessionFactory, CacheMode, Class<?>) - Constructor for class org.hibernate.search.batchindexing.IdentifierConsumerEntityProducer
 
IdentifierProducer - Class in org.hibernate.search.batchindexing
This Runnable is going to feed the indexing queue with the identifiers of all the entities going to be indexed.
IdentifierProducer(ProducerConsumerQueue<List<Serializable>>, SessionFactory, int, Class<?>, MassIndexerProgressMonitor, long) - Constructor for class org.hibernate.search.batchindexing.IdentifierProducer
 
IdHashShardingStrategy - Class in org.hibernate.search.store
This implementation use idInString as the hashKey.
IdHashShardingStrategy() - Constructor for class org.hibernate.search.store.IdHashShardingStrategy
 
idName - Variable in class org.hibernate.search.engine.EntityInfo
The name of the document id property.
ignoreAnalyzer() - Method in interface org.hibernate.search.query.dsl.FieldCustomization
Advanced Do not execute the analyzer on the text.
ignoreAnalyzer() - Method in class org.hibernate.search.query.dsl.impl.ConnectedPhraseMatchingContext
 
ignoreAnalyzer() - Method in class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
ignoreAnalyzer() - Method in class org.hibernate.search.query.dsl.impl.ConnectedTermMatchingContext
 
ignoreFieldBridge() - Method in interface org.hibernate.search.query.dsl.FieldCustomization
Do not try and find the field bridge nor apply the object / string conversion matching objects should be of type String in this case.
ignoreFieldBridge() - Method in class org.hibernate.search.query.dsl.impl.ConnectedPhraseMatchingContext
 
ignoreFieldBridge() - Method in class org.hibernate.search.query.dsl.impl.ConnectedRangeMatchingContext
 
ignoreFieldBridge() - Method in class org.hibernate.search.query.dsl.impl.ConnectedTermMatchingContext
 
immediateLoad(String, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
ImmutableSearchFactory - Class in org.hibernate.search.impl
This implementation is never directly exposed to the user, it is always wrapped into a MutableSearchFactory
ImmutableSearchFactory(SearchFactoryState) - Constructor for class org.hibernate.search.impl.ImmutableSearchFactory
 
IncrementalOptimizerStrategy - Class in org.hibernate.search.store.optimization
Optimization strategy triggered after a certain amount of operations
IncrementalOptimizerStrategy() - Constructor for class org.hibernate.search.store.optimization.IncrementalOptimizerStrategy
 
IncrementalSearchConfiguration - Class in org.hibernate.search.impl
 
IncrementalSearchConfiguration(List<Class<?>>, Properties) - Constructor for class org.hibernate.search.impl.IncrementalSearchConfiguration
 
incrementModificationCounter(int) - Method in class org.hibernate.search.backend.Workspace
Increment the counter of modification operations done on the index.
Index - Enum in org.hibernate.search.annotations
Defines how an Field should be indexed
index(Index) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
index(Index) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
index(Index) - Method in class org.hibernate.search.cfg.FieldMapping
 
index(T) - Method in interface org.hibernate.search.FullTextSession
Force the (re)indexing of a given managed object.
index(T) - Method in class org.hibernate.search.impl.FullTextSessionImpl
(Re-)index an entity.
index(String) - Method in class org.hibernate.search.jmx.IndexControl
 
index(String) - Method in interface org.hibernate.search.jmx.IndexControlMBean
Index the specified entity using the mass indexer.
index(T) - Method in interface org.hibernate.search.jpa.FullTextEntityManager
Force the (re)indexing of a given managed object.
index(T) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
index(T) - Method in interface org.hibernate.search.sandbox.standalone.FullTextManager
Force the (re)indexing of a given managed object.
index(T) - Method in class org.hibernate.search.sandbox.standalone.LuceneFullTextManager
(Re-)index an entity.
INDEX_CTRL_MBEAN_OBJECT_NAME - Static variable in interface org.hibernate.search.jmx.IndexControlMBean
 
IndexControl - Class in org.hibernate.search.jmx
Implementation of the IndexControlMBean JMX attributes and operations.
IndexControl(Properties) - Constructor for class org.hibernate.search.jmx.IndexControl
 
IndexControlMBean - Interface in org.hibernate.search.jmx
Defines the Hibernate Search exposed JMX attributes and operations for index creation and purging.
Indexed - Annotation Type in org.hibernate.search.annotations
 
indexed() - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
indexed() - Method in class org.hibernate.search.cfg.EntityMapping
 
IndexedEmbedded - Annotation Type in org.hibernate.search.annotations
 
indexedEntitiesCount() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
indexedEntitiesCount() - Method in interface org.hibernate.search.stat.Statistics
Returns a map of all indexed entities and their document count in the index.
indexedEntitiesCount() - Method in class org.hibernate.search.stat.StatisticsImpl
 
IndexedMapping - Class in org.hibernate.search.cfg
 
IndexedMapping(SearchMapping, EntityDescriptor, EntityMapping) - Constructor for class org.hibernate.search.cfg.IndexedMapping
 
indexedTargetedEntities(Set<Class<?>>) - Method in class org.hibernate.search.query.ObjectLoaderBuilder
 
indexEmbedded() - Method in class org.hibernate.search.cfg.PropertyMapping
 
IndexEmbeddedMapping - Class in org.hibernate.search.cfg
 
IndexEmbeddedMapping(SearchMapping, PropertyDescriptor, EntityDescriptor) - Constructor for class org.hibernate.search.cfg.IndexEmbeddedMapping
 
indexesOfThis - Variable in class org.hibernate.search.engine.EntityInfo
 
INDEXING_PROGRESS_MONITOR_MBEAN_OBJECT_NAME - Static variable in interface org.hibernate.search.jmx.IndexingProgressMonitorMBean
 
INDEXING_STRATEGY - Static variable in class org.hibernate.search.Environment
Defines the indexing strategy, default event Other options manual
indexingCompleted() - Method in interface org.hibernate.search.batchindexing.MassIndexerProgressMonitor
Called when the indexing is completed.
indexingCompleted() - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
indexingCompleted() - Method in class org.hibernate.search.jmx.IndexingProgressMonitor
 
IndexingProgressMonitor - Class in org.hibernate.search.jmx
A JMX based mass indexer progress monitor.
IndexingProgressMonitor() - Constructor for class org.hibernate.search.jmx.IndexingProgressMonitor
 
IndexingProgressMonitorMBean - Interface in org.hibernate.search.jmx
A MBean for following the progress of mass indexing.
indexName(String) - Method in class org.hibernate.search.cfg.IndexedMapping
 
indexNullAs() - Method in interface org.hibernate.search.bridge.LuceneOptions
 
indexNullAs(String) - Method in class org.hibernate.search.cfg.FieldMapping
 
IndexShardingStrategy - Interface in org.hibernate.search.store
Defines how a given virtual index shards data into different DirectoryProviders
IndexWriterSetting - Enum in org.hibernate.search.backend.configuration
Represents possible options to be applied to an org.apache.lucene.index.IndexWriter
init(Session, SearchFactoryImplementor) - Method in class org.hibernate.search.engine.AbstractLoader
 
init(Session, SearchFactoryImplementor, TimeoutManager) - Method in interface org.hibernate.search.engine.Loader
 
init(Session, SearchFactoryImplementor, TimeoutManager) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
init(Session, SearchFactoryImplementor, TimeoutManager) - Method in class org.hibernate.search.engine.ProjectionLoader
 
init(Session, SearchFactoryImplementor, ResultTransformer, ObjectLoaderBuilder, String[], TimeoutManager) - Method in class org.hibernate.search.engine.ProjectionLoader
 
init(Session, SearchFactoryImplementor, TimeoutManager) - Method in class org.hibernate.search.engine.QueryLoader
 
initialize(Properties, WorkerBuildContext) - Method in interface org.hibernate.search.backend.BackendQueueProcessorFactory
Used at startup, called once as first method.
initialize(Properties, MassIndexerProgressMonitor, WorkerBuildContext) - Method in interface org.hibernate.search.backend.impl.batchlucene.BatchBackend
Used at startup, called once as first method.
initialize(Properties, MassIndexerProgressMonitor, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
 
initialize(Properties, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.blackhole.BlackHoleBackendQueueProcessorFactory
 
initialize(Properties, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
initialize(Properties, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.jgroups.MasterJGroupsBackendQueueProcessorFactory
 
initialize() - Method in class org.hibernate.search.backend.impl.jms.AbstractJMSHibernateSearchController
 
initialize(Properties, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
initialize(Properties, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.lucene.LuceneBackendQueueProcessorFactory
 
initialize(Properties, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.TransactionalWorker
 
initialize(Properties, WorkerBuildContext) - Method in interface org.hibernate.search.backend.Worker
 
initialize(Configuration) - Method in class org.hibernate.search.event.FullTextIndexEventListener
Initialize method called by Hibernate Core when the SessionFactory starts
initialize(Properties) - Method in interface org.hibernate.search.filter.FilterCachingStrategy
initialize the strategy from the properties The Properties must not be changed
initialize(Properties) - Method in class org.hibernate.search.filter.MRUFilterCachingStrategy
 
initialize(Properties, BuildContext) - Method in class org.hibernate.search.reader.NotSharedReaderProvider
 
initialize(Properties, BuildContext) - Method in interface org.hibernate.search.reader.ReaderProvider
Inialize the reader provider before its use.
initialize(Properties, BuildContext) - Method in class org.hibernate.search.reader.SharedReaderProvider
Deprecated.  
initialize(Properties, BuildContext) - Method in class org.hibernate.search.reader.SharingBufferReaderProvider
 
initialize(String, Properties, BuildContext) - Method in interface org.hibernate.search.store.DirectoryProvider
get the information to initialize the directory and build its hashCode/equals method
initialize(String, Properties, BuildContext) - Method in class org.hibernate.search.store.FSDirectoryProvider
 
initialize(String, Properties, BuildContext) - Method in class org.hibernate.search.store.FSMasterDirectoryProvider
 
initialize(String, Properties, BuildContext) - Method in class org.hibernate.search.store.FSSlaveDirectoryProvider
 
initialize(Properties, DirectoryProvider<?>[]) - Method in class org.hibernate.search.store.IdHashShardingStrategy
 
initialize(Properties, DirectoryProvider<?>[]) - Method in interface org.hibernate.search.store.IndexShardingStrategy
provides access to sharding properties (under the suffix sharding_strategy) and provide access to all the DirectoryProviders for a given index
initialize(Properties, DirectoryProvider<?>[]) - Method in class org.hibernate.search.store.NotShardedStrategy
 
initialize(DirectoryProvider, Properties, BuildContext) - Method in class org.hibernate.search.store.optimization.IncrementalOptimizerStrategy
 
initialize(DirectoryProvider, Properties, BuildContext) - Method in class org.hibernate.search.store.optimization.NoOpOptimizerStrategy
 
initialize(DirectoryProvider, Properties, BuildContext) - Method in interface org.hibernate.search.store.optimization.OptimizerStrategy
 
initialize(String, Properties, BuildContext) - Method in class org.hibernate.search.store.RAMDirectoryProvider
 
initialize(Object) - Static method in class org.hibernate.search.util.HibernateHelper
 
initializeCollection(PersistentCollection, boolean) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
initializeIndexIfNeeded(Directory) - Static method in class org.hibernate.search.store.DirectoryProviderHelper
Initialize the Lucene Directory if it isn't already.
initializeObjects(EntityInfo[], Criteria, Class<?>, SearchFactoryImplementor, TimeoutManager) - Static method in class org.hibernate.search.engine.ObjectLoaderHelper
 
initLazyAnalyzers() - Method in class org.hibernate.search.impl.ConfigContext
 
initSubClass(XClass, ConfigContext) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
initSubClass(XClass, ConfigContext) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
initSubClass(XClass, ConfigContext) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
instanceFromClass(Class<T>, Class<?>, String) - Static method in class org.hibernate.search.util.ClassLoaderHelper
Creates an instance of target class
instanceFromName(Class<T>, String, Class<?>, String) - Static method in class org.hibernate.search.util.ClassLoaderHelper
Creates an instance of a target class designed by fully qualified name
InstanceTransactionContext - Class in org.hibernate.search.sandbox.standalone
Transaction context that contains transaction boundaries methods.
InstanceTransactionContext() - Constructor for class org.hibernate.search.sandbox.standalone.InstanceTransactionContext
 
instantiate(String, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
INT_NUMERIC - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
INTEGER - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
IntegerBridge - Class in org.hibernate.search.bridge.builtin
Map an integer element
IntegerBridge() - Constructor for class org.hibernate.search.bridge.builtin.IntegerBridge
 
IntegerNumericFieldBridge - Class in org.hibernate.search.bridge.builtin
Integer numeric field bridge, capable of decoding integer values from Field
IntegerNumericFieldBridge() - Constructor for class org.hibernate.search.bridge.builtin.IntegerNumericFieldBridge
 
internalLoad(String, Serializable, boolean, boolean) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
invoke(String, Object, Object) - Method in class org.hibernate.search.engine.FilterDef
 
isBatch() - Method in class org.hibernate.search.backend.LuceneWork
 
isBound(Parameter<?>) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
isCacheable() - Method in class org.hibernate.search.filter.AndDocIdSet
 
isClosed() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isCompressed() - Method in interface org.hibernate.search.bridge.LuceneOptions
Prefer the use of LuceneOptions.addFieldToDocument(String, String, org.apache.lucene.document.Document) over manually building your Field objects and adding them to the Document.
isConfiguredAsSync(Properties) - Static method in class org.hibernate.search.backend.impl.BatchedQueueingProcessor
 
isConnected() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isConsumed() - Method in class org.hibernate.search.backend.impl.PostTransactionWorkQueueSynchronization
 
isDefaultReadOnly() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isDirty() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isEmpty() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
isEmpty() - Method in class org.hibernate.search.filter.ChainedFilter
 
isEmpty() - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns true if this map contains no key-value mappings.
isEventSource() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isExcludeFrom() - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
isExcludeTo() - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
isExclusiveIndexUsage() - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
isExclusiveIndexUsageEnabled(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
isExclusiveIndexUsageEnabled(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
isExclusiveIndexUsageEnabled(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
isExclusiveIndexUsageEnabled(DirectoryProvider<?>) - Method in interface org.hibernate.search.spi.WorkerBuildContext
 
isFetchProfileEnabled(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isFirst() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
isIgnoreAnalyzer() - Method in class org.hibernate.search.query.dsl.impl.FieldContext
 
isIgnoreFieldBridge() - Method in class org.hibernate.search.query.dsl.impl.FieldContext
 
isInitialized(Object) - Static method in class org.hibernate.search.util.HibernateHelper
 
isJMXEnabled() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
isJMXEnabled() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
isJMXEnabled() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
isJpaPresent() - Method in class org.hibernate.search.impl.ConfigContext
 
isLast() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
isNameRegistered(String) - Static method in class org.hibernate.search.jmx.JMXRegistrar
Checks whether a bean is registered under the given name.
isObjectNotFoundException(RuntimeException) - Static method in class org.hibernate.search.engine.LoaderHelper
 
isOpen() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isOpen() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
isReadOnly(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isRoot() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
isSealedAndUnchanged() - Method in class org.hibernate.search.backend.WorkQueue
 
isStatisticsEnabled() - Method in class org.hibernate.search.jmx.StatisticsInfo
 
isStatisticsEnabled() - Method in interface org.hibernate.search.stat.Statistics
Are statistics logged
isStatisticsEnabled() - Method in class org.hibernate.search.stat.StatisticsImpl
 
isTimedOut() - Method in class org.hibernate.search.query.TimeoutManager
 
isTransactionInProgress() - Method in class org.hibernate.search.backend.impl.EventSourceTransactionContext
 
isTransactionInProgress() - Method in interface org.hibernate.search.backend.TransactionContext
 
isTransactionInProgress() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
isTransactionInProgress() - Method in class org.hibernate.search.sandbox.standalone.InstanceTransactionContext
 
iterate(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
iterate(String, Object, Type) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
iterate(String, Object[], Type[]) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
iterate(String, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
iterate() - Method in class org.hibernate.search.query.FullTextQueryImpl
Return an iterator on the results.
iterateFilter(Object, String, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
iterator() - Method in class org.hibernate.search.filter.AndDocIdSet
 
IteratorImpl - Class in org.hibernate.search.query
 
IteratorImpl(List<EntityInfo>, Loader) - Constructor for class org.hibernate.search.query.IteratorImpl
 

J

JG_CLUSTER_NAME - Static variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
JGROUPS_PREFIX - Static variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
JGroupsBackendQueueProcessor - Class in org.hibernate.search.backend.impl.jgroups
Responsible for sending Lucene works from slave nodes to master node
JGroupsBackendQueueProcessor(List<LuceneWork>, JGroupsBackendQueueProcessorFactory) - Constructor for class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessor
 
JGroupsBackendQueueProcessorFactory - Class in org.hibernate.search.backend.impl.jgroups
Common base class for Master and Slave BackendQueueProcessorFactories
JGroupsBackendQueueProcessorFactory() - Constructor for class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
JGroupsMasterMessageListener - Class in org.hibernate.search.backend.impl.jgroups
Listen for messages from slave nodes and apply them into LuceneBackendQueueProcessor
JGroupsMasterMessageListener(SearchFactoryImplementor) - Constructor for class org.hibernate.search.backend.impl.jgroups.JGroupsMasterMessageListener
 
JMS_CONNECTION_FACTORY - Static variable in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
JMS_QUEUE - Static variable in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
JMSBackendQueueProcessor - Class in org.hibernate.search.backend.impl.jms
 
JMSBackendQueueProcessor(List<LuceneWork>, JMSBackendQueueProcessorFactory) - Constructor for class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessor
 
JMSBackendQueueProcessorFactory - Class in org.hibernate.search.backend.impl.jms
 
JMSBackendQueueProcessorFactory() - Constructor for class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
JMX_ENABLED - Static variable in class org.hibernate.search.Environment
If set to true JMX beans get enabled.
JMXRegistrar - Class in org.hibernate.search.jmx
Helper class to register JMX beans.
JNDIHelper - Class in org.hibernate.search.util
Helper class for creating an JNDI InitialContext.
joinTransaction() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 

K

Key - Annotation Type in org.hibernate.search.annotations
Marks a method as a key constructor for a given type.
keys() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
keySet() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
keySet() - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns a set view of the keys contained in this map.
keyword() - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryBuilder
 
keyword() - Method in interface org.hibernate.search.query.dsl.QueryBuilder
build a term query

L

last() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
limitExecutionTimeTo(long, TimeUnit) - Method in interface org.hibernate.search.FullTextQuery
*Experimental* API, subject to change or removal Limit the time used by Hibernate Search to execute the query.
limitExecutionTimeTo(long, TimeUnit) - Method in interface org.hibernate.search.jpa.FullTextQuery
*Experimental* API, subject to change or removal Limit the time used by Hibernate Search to execute the query.
limitExecutionTimeTo(long, TimeUnit) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
limitExecutionTimeTo(long, TimeUnit) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
limitFetchingOnTimeout() - Method in class org.hibernate.search.query.TimeoutManager
 
limitIndexedObjectsTo(long) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
limitIndexedObjectsTo(long) - Method in interface org.hibernate.search.MassIndexer
EXPERIMENTAL method: will probably change Will stop indexing after having indexed a set amount of objects.
list(PrintStream) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
list(PrintWriter) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
list(String, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
list(CriteriaImpl) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
list(NativeSQLQuerySpecification, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
list() - Method in class org.hibernate.search.query.FullTextQueryImpl
 
list() - Method in interface org.hibernate.search.sandbox.standalone.FullTextQuery
 
listCustomQuery(CustomQuery, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
listFilter(Object, String, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
load(InputStream) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
load(EntityInfo) - Method in class org.hibernate.search.engine.AbstractLoader
 
load(EntityInfo...) - Method in class org.hibernate.search.engine.AbstractLoader
 
load(EntityInfo) - Method in interface org.hibernate.search.engine.Loader
 
load(EntityInfo...) - Method in interface org.hibernate.search.engine.Loader
 
load(EntityInfo, Session) - Static method in class org.hibernate.search.engine.ObjectLoaderHelper
 
load(EntityInfo) - Method in class org.hibernate.search.engine.ProjectionLoader
 
load(EntityInfo...) - Method in class org.hibernate.search.engine.ProjectionLoader
 
load(String, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
load(String, Serializable, LockMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
load(String, Serializable, LockOptions) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
load(Object, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
load(Class, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
load(Class, Serializable, LockMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
load(Class, Serializable, LockOptions) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
Loader - Interface in org.hibernate.search.engine
Interface defining a set of operations in order to load entities which matched a query.
LoaderHelper - Class in org.hibernate.search.engine
 
loadFromXML(InputStream) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
loadWithoutTiming(EntityInfo) - Method in class org.hibernate.search.engine.AbstractLoader
 
loadWithoutTiming(EntityInfo) - Method in interface org.hibernate.search.engine.Loader
 
loadWithoutTiming(EntityInfo) - Method in class org.hibernate.search.engine.ProjectionLoader
 
lock(String, Object, LockMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
lock(Object, LockMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
lock(Object, LockModeType) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
lock(Object, LockModeType, Map<String, Object>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
LockFactoryFactory - Interface in org.hibernate.search.store
To use a custom implementation of org.apache.lucene.store.LockFactory you need to implement this interface and define the fully qualified classname of the factory implementation as a DirectoryProvider parameter for the locking_strategy key.
logError(String, Throwable) - Method in class org.hibernate.search.exception.impl.LogErrorHandler
 
LogErrorHandler - Class in org.hibernate.search.exception.impl
 
LogErrorHandler() - Constructor for class org.hibernate.search.exception.impl.LogErrorHandler
 
LoggerFactory - Class in org.hibernate.search.util
A factory class for class loggers.
LoggerFactory() - Constructor for class org.hibernate.search.util.LoggerFactory
 
logWorkDone(LuceneWork, MassIndexerProgressMonitor) - Method in interface org.hibernate.search.backend.impl.lucene.works.LuceneWorkDelegate
Used for stats and performance counters, use the monitor to keep track of activity done on the index.
LONG - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
LONG_NUMERIC - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
LongBridge - Class in org.hibernate.search.bridge.builtin
Map a long element
LongBridge() - Constructor for class org.hibernate.search.bridge.builtin.LongBridge
 
LongNumericFieldBridge - Class in org.hibernate.search.bridge.builtin
Long numeric field bridge, capable of decoding long values from Field
LongNumericFieldBridge() - Constructor for class org.hibernate.search.bridge.builtin.LongNumericFieldBridge
 
LUCENE_MATCH_VERSION - Static variable in class org.hibernate.search.Environment
The Lucene match version parameter.
LuceneBackendQueueProcessorFactory - Class in org.hibernate.search.backend.impl.lucene
This will actually contain the Workspace and LuceneWork visitor implementation, reused per-DirectoryProvider.
LuceneBackendQueueProcessorFactory() - Constructor for class org.hibernate.search.backend.impl.lucene.LuceneBackendQueueProcessorFactory
 
LuceneBatchBackend - Class in org.hibernate.search.backend.impl.batchlucene
This is not meant to be used as a regular backend, only to apply batch changes to the index.
LuceneBatchBackend() - Constructor for class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
 
LuceneFullTextManager - Class in org.hibernate.search.sandbox.standalone
Implements a standalone full text service.
LuceneIndexingParameters - Class in org.hibernate.search.backend
Wrapper class around the Lucene indexing parameters defined in IndexWriterSetting.
LuceneIndexingParameters(Properties) - Constructor for class org.hibernate.search.backend.LuceneIndexingParameters
 
LuceneIndexingParameters.ParameterSet - Class in org.hibernate.search.backend
 
LuceneIndexingParameters.ParameterSet(Properties, String) - Constructor for class org.hibernate.search.backend.LuceneIndexingParameters.ParameterSet
 
LuceneOptions - Interface in org.hibernate.search.bridge
A helper class for building Field objects and associating them to Documents.
LuceneWork - Class in org.hibernate.search.backend
Represent a Serializable Lucene unit work WARNING: This class aims to be serializable and passed in an asynchronous way across VMs any non backward compatible serialization change should be done with great care and publically announced.
LuceneWork(Serializable, String, Class) - Constructor for class org.hibernate.search.backend.LuceneWork
 
LuceneWork(Serializable, String, Class, Document) - Constructor for class org.hibernate.search.backend.LuceneWork
 
LuceneWork(Serializable, String, Class, Document, boolean) - Constructor for class org.hibernate.search.backend.LuceneWork
 
LuceneWorkDelegate - Interface in org.hibernate.search.backend.impl.lucene.works
 
LuceneWorkVisitor - Class in org.hibernate.search.backend.impl.lucene.works
 
LuceneWorkVisitor(Workspace, WorkerBuildContext) - Constructor for class org.hibernate.search.backend.impl.lucene.works.LuceneWorkVisitor
 

M

make() - Static method in class org.hibernate.search.util.LoggerFactory
 
makeBatchBackend(MassIndexerProgressMonitor) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
makeBatchBackend(MassIndexerProgressMonitor) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
makeBatchBackend(MassIndexerProgressMonitor) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
MappingModelMetadataProvider - Class in org.hibernate.search.impl
 
MappingModelMetadataProvider(MetadataProvider, SearchMapping) - Constructor for class org.hibernate.search.impl.MappingModelMetadataProvider
 
MaskedProperty - Class in org.hibernate.search.backend.configuration
A wrapper to Properties, to restrict the availability of values to only those which have a key beginning with some masking String.
MaskedProperty(Properties, String) - Constructor for class org.hibernate.search.backend.configuration.MaskedProperty
Provides a view to the provided Properties hiding all keys not starting with some [mask.].
MaskedProperty(Properties, String, Properties) - Constructor for class org.hibernate.search.backend.configuration.MaskedProperty
Provides a view to the provided Properties hiding all keys not starting with some [mask.].
MassIndexer - Interface in org.hibernate.search
A MassIndexer is useful to rebuild the indexes from the data contained in the database.
MassIndexerImpl - Class in org.hibernate.search.impl
Prepares and configures a BatchIndexingWorkspace to start rebuilding the indexes for all entity instances in the database.
MassIndexerImpl(SearchFactoryImplementor, SessionFactory, Class<?>...) - Constructor for class org.hibernate.search.impl.MassIndexerImpl
 
MassIndexerProgressMonitor - Interface in org.hibernate.search.batchindexing
As a MassIndexer can take some time to finish it's job, a MassIndexerProgressMonitor can be defined in the configuration property hibernate.search.worker.indexing.monitor implementing this interface to track indexing performance.
MasterJGroupsBackendQueueProcessorFactory - Class in org.hibernate.search.backend.impl.jgroups
Backend factory used in JGroups clustering mode in master node.
MasterJGroupsBackendQueueProcessorFactory() - Constructor for class org.hibernate.search.backend.impl.jgroups.MasterJGroupsBackendQueueProcessorFactory
 
matching(Object) - Method in class org.hibernate.search.query.dsl.impl.ConnectedTermMatchingContext
 
matching(Object) - Method in interface org.hibernate.search.query.dsl.TermMatchingContext
Value searched in the field or fields.
merge(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
merge(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
merge(T) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
mergeByBitAnds(List<DocIdSet>) - Static method in class org.hibernate.search.filter.FilterOptimizationHelper
Returns a new list of DocIdSet, applying binary AND on all DocIdSet implemented by using BitSet or OpenBitSet.
MODEL_MAPPING - Static variable in class org.hibernate.search.Environment
 
MRUFilterCachingStrategy - Class in org.hibernate.search.filter
Keep the most recently used Filters in the cache The cache is at least as big as hibernate.search.filter.cache_strategy.size Above this limit, Filters are kept as soft references
MRUFilterCachingStrategy() - Constructor for class org.hibernate.search.filter.MRUFilterCachingStrategy
 
MultiClassesQueryLoader - Class in org.hibernate.search.engine
A loader which loads objects of multiple types.
MultiClassesQueryLoader() - Constructor for class org.hibernate.search.engine.MultiClassesQueryLoader
 
must(Query) - Method in interface org.hibernate.search.query.dsl.BooleanJunction
The boolean query results must (or must not) match the subquery Call the .not() method to ensure results of the boolean query do NOT match the subquery.
MustJunction - Interface in org.hibernate.search.query.dsl
Represents the context in which a must clause is described.
MutableSearchFactory - Class in org.hibernate.search.impl
Factory delegating to a concrete implementation of another factory, Useful to swap one factory for another.
MutableSearchFactory() - Constructor for class org.hibernate.search.impl.MutableSearchFactory
 
MutableSearchFactoryState - Class in org.hibernate.search.impl
Shared factory state
MutableSearchFactoryState() - Constructor for class org.hibernate.search.impl.MutableSearchFactoryState
 

N

name(String) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
name(String) - Method in class org.hibernate.search.cfg.DocumentIdMapping
 
name(String) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
name(String) - Method in class org.hibernate.search.cfg.FieldMapping
 
name(String) - Method in class org.hibernate.search.cfg.ProvidedIdMapping
 
needOptimization() - Method in class org.hibernate.search.store.optimization.IncrementalOptimizerStrategy
 
needOptimization() - Method in class org.hibernate.search.store.optimization.NoOpOptimizerStrategy
 
needOptimization() - Method in interface org.hibernate.search.store.optimization.OptimizerStrategy
has to be called in a thread safe way
newFixedThreadPool(int, String) - Static method in class org.hibernate.search.batchindexing.Executors
Creates a new fixed size ThreadPoolExecutor.
newFixedThreadPool(int, String, int) - Static method in class org.hibernate.search.batchindexing.Executors
Creates a new fixed size ThreadPoolExecutor
newInstance(String, String...) - Method in class org.hibernate.search.util.HibernateSearchResourceLoader
 
next() - Method in class org.hibernate.search.query.IteratorImpl
 
next() - Method in class org.hibernate.search.query.ScrollableResultsImpl
NoOpOptimizerStrategy - Class in org.hibernate.search.store.optimization
 
NoOpOptimizerStrategy() - Constructor for class org.hibernate.search.store.optimization.NoOpOptimizerStrategy
 
not() - Method in interface org.hibernate.search.query.dsl.MustJunction
Negate the must clause.
NotShardedStrategy - Class in org.hibernate.search.store
 
NotShardedStrategy() - Constructor for class org.hibernate.search.store.NotShardedStrategy
 
NotSharedReaderProvider - Class in org.hibernate.search.reader
Open a reader each time
NotSharedReaderProvider() - Constructor for class org.hibernate.search.reader.NotSharedReaderProvider
 
NullEncodingTwoWayFieldBridge - Class in org.hibernate.search.bridge
 
NullEncodingTwoWayFieldBridge(TwoWayFieldBridge, String) - Constructor for class org.hibernate.search.bridge.NullEncodingTwoWayFieldBridge
 
NumberBridge - Class in org.hibernate.search.bridge.builtin
Base class for numbers - integer, double, etc.
NumberBridge() - Constructor for class org.hibernate.search.bridge.builtin.NumberBridge
 
NumericField - Annotation Type in org.hibernate.search.annotations
Extension annotation for @Field supporting Lucene's numeric field feature.
numericField() - Method in class org.hibernate.search.cfg.ContainedInMapping
 
numericField() - Method in class org.hibernate.search.cfg.FieldMapping
 
NumericFieldBridge - Class in org.hibernate.search.bridge.builtin
Bridge to index numeric values using a Trie structure (multiple terms representing different precisions)
NumericFieldBridge() - Constructor for class org.hibernate.search.bridge.builtin.NumericFieldBridge
 
NumericFieldMapping - Class in org.hibernate.search.cfg
 
NumericFieldMapping(PropertyDescriptor, EntityDescriptor, SearchMapping) - Constructor for class org.hibernate.search.cfg.NumericFieldMapping
 
NumericFields - Annotation Type in org.hibernate.search.annotations
Numeric extension for Fields annotation
NumericFieldUtils - Class in org.hibernate.search.bridge.util
Utility class to handle Numeric Fields
NumericFieldUtils() - Constructor for class org.hibernate.search.bridge.util.NumericFieldUtils
 

O

OBJECT_CLASS - Static variable in interface org.hibernate.search.ProjectionConstants
Represents the Hibernate entity class returned in a search.
ObjectLoaderBuilder - Class in org.hibernate.search.query
 
ObjectLoaderBuilder() - Constructor for class org.hibernate.search.query.ObjectLoaderBuilder
 
ObjectLoaderHelper - Class in org.hibernate.search.engine
 
ObjectLoaderHelper() - Constructor for class org.hibernate.search.engine.ObjectLoaderHelper
 
objectLoadExecuted(long, long) - Method in class org.hibernate.search.stat.StatisticsImpl
 
objectLoadExecuted(long, long) - Method in interface org.hibernate.search.stat.StatisticsImplementor
Callback for number of object loaded from the db.
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.BooleanBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.CalendarBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.CharacterBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.ClassBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.DateBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.EnumBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.NumberBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.NumericFieldBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.StringBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.UriBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.builtin.UrlBridge
 
objectToString(Object) - Method in class org.hibernate.search.bridge.NullEncodingTwoWayFieldBridge
 
objectToString(Object) - Method in interface org.hibernate.search.bridge.StringBridge
Converts the object representation to a string.
objectToString(Object) - Method in interface org.hibernate.search.bridge.TwoWayFieldBridge
Convert the object representation to a string.
objectToString(Object) - Method in class org.hibernate.search.bridge.TwoWayString2FieldBridgeAdaptor
 
objectToString(Object) - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
objectToString(Object) - Method in class org.hibernate.search.cfg.ConcatStringBridge
 
objectToString(String, Object) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
onField(String) - Method in interface org.hibernate.search.query.dsl.FuzzyContext
field / property the term query is executed on
onField(String) - Method in interface org.hibernate.search.query.dsl.PhraseContext
field / property the term query is executed on
onField(String) - Method in interface org.hibernate.search.query.dsl.RangeContext
field / property the term query is executed on
onField(String) - Method in interface org.hibernate.search.query.dsl.TermContext
field / property the term query is executed on
onField(String) - Method in interface org.hibernate.search.query.dsl.WildcardContext
field / property the term query is executed on
onFields(String...) - Method in interface org.hibernate.search.query.dsl.TermContext
 
onFlush(FlushEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
Make sure the indexes are updated right after the hibernate flush, avoiding object loading during a flush.
onMessage(Message) - Method in class org.hibernate.search.backend.impl.jms.AbstractJMSHibernateSearchController
Process the Hibernate Search work queues received
onPostDelete(PostDeleteEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
onPostInsert(PostInsertEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
onPostRecreateCollection(PostCollectionRecreateEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
onPostRemoveCollection(PostCollectionRemoveEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
onPostUpdate(PostUpdateEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
onPostUpdateCollection(PostCollectionUpdateEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
openReader(DirectoryProvider...) - Method in class org.hibernate.search.reader.NotSharedReaderProvider
 
openReader(DirectoryProvider...) - Method in interface org.hibernate.search.reader.ReaderProvider
Open a read-only reader on all the listed directory providers.
openReader(DirectoryProvider...) - Method in class org.hibernate.search.reader.SharedReaderProvider
Deprecated.  
openReader(DirectoryProvider...) - Method in class org.hibernate.search.reader.SharingBufferReaderProvider
 
openResource(String) - Method in class org.hibernate.search.util.HibernateSearchResourceLoader
 
optimizationForced() - Method in class org.hibernate.search.store.optimization.IncrementalOptimizerStrategy
 
optimizationForced() - Method in class org.hibernate.search.store.optimization.NoOpOptimizerStrategy
 
optimizationForced() - Method in interface org.hibernate.search.store.optimization.OptimizerStrategy
has to be called in a thread safe way
optimize() - Method in class org.hibernate.search.backend.Workspace
Used by OptimizeLuceneWork after index optimization to flag that optimization has been forced.
optimize() - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
optimize(Class) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
optimize() - Method in class org.hibernate.search.impl.MutableSearchFactory
 
optimize(Class) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
optimize(String) - Method in class org.hibernate.search.jmx.IndexControl
 
optimize(String) - Method in interface org.hibernate.search.jmx.IndexControlMBean
Optimizes the index for the specified entity.
optimize() - Method in interface org.hibernate.search.SearchFactory
Optimize all indexes
optimize(Class) - Method in interface org.hibernate.search.SearchFactory
Optimize the index holding entityType
optimize(Workspace) - Method in class org.hibernate.search.store.optimization.IncrementalOptimizerStrategy
 
optimize(Workspace) - Method in class org.hibernate.search.store.optimization.NoOpOptimizerStrategy
 
optimize(Workspace) - Method in interface org.hibernate.search.store.optimization.OptimizerStrategy
has to be called in a thread safe way
optimizeAfterPurge(boolean) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
optimizeAfterPurge(boolean) - Method in interface org.hibernate.search.MassIndexer
If index optimization should be run before starting, after the purgeAll.
OptimizeLuceneWork - Class in org.hibernate.search.backend
A unit of work triggering an optimize operation.
OptimizeLuceneWork(Class) - Constructor for class org.hibernate.search.backend.OptimizeLuceneWork
 
optimizeOnFinish(boolean) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
optimizeOnFinish(boolean) - Method in interface org.hibernate.search.MassIndexer
If index optimization has to be started at the end of the indexing process.
optimizerPhase() - Method in class org.hibernate.search.backend.Workspace
If optimization has not been forced give a chance to configured OptimizerStrategy to optimize the index.
OptimizerStrategy - Interface in org.hibernate.search.store.optimization
 
OptionallyWrapInJTATransaction - Class in org.hibernate.search.batchindexing
Wrap the subsequent Runnable in a JTA Transaction if necessary: - if the existing Hibernate Core transaction strategy requires a TransactionManager - if no JTA transaction is already started Unfortunately at this time we need to have access to SessionFactoryImplementor
OptionallyWrapInJTATransaction(SessionFactory, SessionAwareRunnable) - Constructor for class org.hibernate.search.batchindexing.OptionallyWrapInJTATransaction
 
OptionallyWrapInJTATransaction(SessionFactory, StatelessSessionAwareRunnable) - Constructor for class org.hibernate.search.batchindexing.OptionallyWrapInJTATransaction
 
org.hibernate.search - package org.hibernate.search
 
org.hibernate.search.analyzer - package org.hibernate.search.analyzer
 
org.hibernate.search.annotations - package org.hibernate.search.annotations
 
org.hibernate.search.backend - package org.hibernate.search.backend
 
org.hibernate.search.backend.configuration - package org.hibernate.search.backend.configuration
 
org.hibernate.search.backend.impl - package org.hibernate.search.backend.impl
 
org.hibernate.search.backend.impl.batchlucene - package org.hibernate.search.backend.impl.batchlucene
 
org.hibernate.search.backend.impl.blackhole - package org.hibernate.search.backend.impl.blackhole
 
org.hibernate.search.backend.impl.jgroups - package org.hibernate.search.backend.impl.jgroups
 
org.hibernate.search.backend.impl.jms - package org.hibernate.search.backend.impl.jms
 
org.hibernate.search.backend.impl.lucene - package org.hibernate.search.backend.impl.lucene
 
org.hibernate.search.backend.impl.lucene.overrides - package org.hibernate.search.backend.impl.lucene.overrides
 
org.hibernate.search.backend.impl.lucene.works - package org.hibernate.search.backend.impl.lucene.works
 
org.hibernate.search.batchindexing - package org.hibernate.search.batchindexing
 
org.hibernate.search.bridge - package org.hibernate.search.bridge
 
org.hibernate.search.bridge.builtin - package org.hibernate.search.bridge.builtin
 
org.hibernate.search.bridge.util - package org.hibernate.search.bridge.util
 
org.hibernate.search.cfg - package org.hibernate.search.cfg
 
org.hibernate.search.engine - package org.hibernate.search.engine
 
org.hibernate.search.event - package org.hibernate.search.event
 
org.hibernate.search.exception - package org.hibernate.search.exception
 
org.hibernate.search.exception.impl - package org.hibernate.search.exception.impl
 
org.hibernate.search.filter - package org.hibernate.search.filter
 
org.hibernate.search.impl - package org.hibernate.search.impl
 
org.hibernate.search.jmx - package org.hibernate.search.jmx
 
org.hibernate.search.jpa - package org.hibernate.search.jpa
 
org.hibernate.search.jpa.impl - package org.hibernate.search.jpa.impl
 
org.hibernate.search.query - package org.hibernate.search.query
 
org.hibernate.search.query.dsl - package org.hibernate.search.query.dsl
Provide a domain specific language to write Lucene queries.
org.hibernate.search.query.dsl.impl - package org.hibernate.search.query.dsl.impl
 
org.hibernate.search.reader - package org.hibernate.search.reader
 
org.hibernate.search.sandbox - package org.hibernate.search.sandbox
This package contains various experimentations.
org.hibernate.search.sandbox.standalone - package org.hibernate.search.sandbox.standalone
This package contains various experimentations.
org.hibernate.search.spi - package org.hibernate.search.spi
 
org.hibernate.search.spi.internals - package org.hibernate.search.spi.internals
 
org.hibernate.search.stat - package org.hibernate.search.stat
 
org.hibernate.search.store - package org.hibernate.search.store
 
org.hibernate.search.store.optimization - package org.hibernate.search.store.optimization
 
org.hibernate.search.util - package org.hibernate.search.util
 
overridesForField(String, String) - Method in interface org.hibernate.search.query.dsl.EntityContext
 
overridesForField(String, String) - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryContextBuilder.HSearchEntityContext
 

P

param(String, String) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
param(String, String) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
param(String, String) - Method in class org.hibernate.search.cfg.TokenFilterDefMapping
 
Parameter - Annotation Type in org.hibernate.search.annotations
Parameter (basically key/value pattern)
ParameterizedBridge - Interface in org.hibernate.search.bridge
Allow parameter injection to a given bridge.
parseBoolean(String, String) - Static method in class org.hibernate.search.backend.configuration.ConfigurationParseHelper
Parses a string to recognize exactly either "true" or "false".
parseInt(String, String) - Static method in class org.hibernate.search.backend.configuration.ConfigurationParseHelper
Parses a String to get an int value.
parseInt(String, int, String) - Static method in class org.hibernate.search.backend.configuration.ConfigurationParseHelper
In case value is null or an empty string the defValue is returned
parseVal(String) - Method in enum org.hibernate.search.backend.configuration.IndexWriterSetting
Specific parameters may override to provide additional keywords support.
PassThroughAnalyzer - Class in org.hibernate.search.util
Analyzer that applies no operation whatsoever to the flux This is useful for queries operating on non tokenized fields.
PassThroughAnalyzer() - Constructor for class org.hibernate.search.util.PassThroughAnalyzer
 
path - Variable in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
PerDirectoryWorkProcessor - Interface in org.hibernate.search.backend.impl.lucene
Interface to implement visitor pattern in combination with DpSelectionVisitor and DpSelectionDelegate to send LuceneWork to the appropriate queues, as defined by an IndexShardingStrategy.
performWork(LuceneWork, IndexWriter) - Method in class org.hibernate.search.backend.impl.lucene.works.DeleteExtWorkDelegate
 
performWork(LuceneWork, IndexWriter) - Method in interface org.hibernate.search.backend.impl.lucene.works.LuceneWorkDelegate
Will perform work on an IndexWriter.
performWork(Work<?>, TransactionContext) - Method in class org.hibernate.search.backend.impl.TransactionalWorker
 
performWork(Work<?>, TransactionContext) - Method in interface org.hibernate.search.backend.Worker
Declare a work to be done within a given transaction context
performWorks(WorkQueue) - Method in class org.hibernate.search.backend.impl.BatchedQueueingProcessor
 
performWorks(WorkQueue) - Method in interface org.hibernate.search.backend.QueueingProcessor
Execute works
persist(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
persist(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
persist(Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
phrase() - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryBuilder
 
phrase() - Method in interface org.hibernate.search.query.dsl.QueryBuilder
find an sentence (words can be inversed according to the slop factor
PhraseContext - Interface in org.hibernate.search.query.dsl
 
PhraseMatchingContext - Interface in org.hibernate.search.query.dsl
 
PhraseQueryContext - Class in org.hibernate.search.query.dsl.impl
 
PhraseQueryContext() - Constructor for class org.hibernate.search.query.dsl.impl.PhraseQueryContext
 
PhraseTermination - Interface in org.hibernate.search.query.dsl
 
PolymorphicIndexHierarchy - Class in org.hibernate.search.spi.internals
Helper class which keeps track of all super classes and interfaces of the indexed entities.
PolymorphicIndexHierarchy() - Constructor for class org.hibernate.search.spi.internals.PolymorphicIndexHierarchy
 
popMethod() - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
popMethod() - Method in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
populateResult(String, FieldBridge, Store, String[], Object[], Document, ContextualException2WayBridge) - Static method in class org.hibernate.search.engine.DocumentBuilderHelper
 
postInitialize(Set<Class<?>>) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
PostTransactionWorkQueueSynchronization - Class in org.hibernate.search.backend.impl
Execute some work inside a transaction synchronization
PostTransactionWorkQueueSynchronization(QueueingProcessor, WeakIdentityHashMap, SearchFactoryImplementor) - Constructor for class org.hibernate.search.backend.impl.PostTransactionWorkQueueSynchronization
in transaction work
PRECISION_STEP_DEFAULT - Static variable in annotation type org.hibernate.search.annotations.NumericField
Default precision step, mimicking Lucene's default precision step value.
precisionStep(int) - Method in class org.hibernate.search.cfg.NumericFieldMapping
 
precisionSteps - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata
 
prefix(String) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
preparedQuery - Variable in class org.hibernate.search.query.QueryHits
 
prepareJMSTools() - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
prepareWorkPlan() - Method in class org.hibernate.search.backend.WorkQueue
Compiles the work collected so far in an optimal execution plan, storing the list of lucene operations to be performed in the sealedQueue.
prepareWorks(WorkQueue) - Method in class org.hibernate.search.backend.impl.BatchedQueueingProcessor
 
prepareWorks(WorkQueue) - Method in interface org.hibernate.search.backend.QueueingProcessor
prepare resources for a later performWorks call
previous() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
printStatusMessage(long, long, long) - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
processCollectionEvent(AbstractCollectionEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
processContainedInAndPrepareExecution() - Method in class org.hibernate.search.engine.WorkPlan
Makes sure that all additional work needed because of containedIn is added to the work plan.
processFieldsForProjection(AbstractDocumentBuilder.PropertiesMetadata, String[], Object[], Document, ContextualException2WayBridge) - Static method in class org.hibernate.search.engine.DocumentBuilderHelper
 
processWork(T, Serializable, WorkType, AbstractEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
ProducerConsumerQueue<T> - Class in org.hibernate.search.batchindexing
Implements a blocking queue capable of storing a "poison" token to signal consumer threads that the task is finished.
ProducerConsumerQueue(int) - Constructor for class org.hibernate.search.batchindexing.ProducerConsumerQueue
 
ProducerConsumerQueue(int, int) - Constructor for class org.hibernate.search.batchindexing.ProducerConsumerQueue
 
producerStopping() - Method in class org.hibernate.search.batchindexing.ProducerConsumerQueue
Each producer thread should call producerStopping() when it has finished.
projection - Variable in class org.hibernate.search.engine.EntityInfo
Array of projected values.
ProjectionConstants - Interface in org.hibernate.search
Defined projection constants.
ProjectionLoader - Class in org.hibernate.search.engine
Implementation of the Loader interface used for loading entities which are projected via ProjectionConstants.THIS.
ProjectionLoader() - Constructor for class org.hibernate.search.engine.ProjectionLoader
 
PROP_GROUP - Static variable in class org.hibernate.search.backend.LuceneIndexingParameters
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.CalendarBridgeMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.ContainedInMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.DateBridgeMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.DocumentIdMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.EntityMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.FieldMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.IndexedMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.PropertyMapping
 
property(String, ElementType) - Method in class org.hibernate.search.cfg.ProvidedIdMapping
 
PropertyDescriptor - Class in org.hibernate.search.cfg
 
PropertyDescriptor(String, ElementType) - Constructor for class org.hibernate.search.cfg.PropertyDescriptor
 
PropertyMapping - Class in org.hibernate.search.cfg
 
PropertyMapping(String, ElementType, EntityDescriptor, SearchMapping) - Constructor for class org.hibernate.search.cfg.PropertyMapping
 
propertyNames() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
ProvidedId - Annotation Type in org.hibernate.search.annotations
Objects whose identifier is provided externally and not part of the object state should be marked with this annotation

This annotation should not be used in conjunction with DocumentId

providedId() - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
providedId() - Method in class org.hibernate.search.cfg.IndexedMapping
 
ProvidedIdMapping - Class in org.hibernate.search.cfg
 
ProvidedIdMapping(SearchMapping, EntityDescriptor) - Constructor for class org.hibernate.search.cfg.ProvidedIdMapping
 
purge(Class<T>, Serializable) - Method in interface org.hibernate.search.FullTextSession
Remove the entity with the type entityType and the identifier id from the index.
purge(Class<T>, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
Remove the entity with the type entityType and the identifier id from the index.
purge(String) - Method in class org.hibernate.search.jmx.IndexControl
 
purge(String) - Method in interface org.hibernate.search.jmx.IndexControlMBean
Purge the index of the specified entity.
purge(Class<T>, Serializable) - Method in interface org.hibernate.search.jpa.FullTextEntityManager
Remove the entity with the type entityType and the identifier id from the index.
purge(Class<T>, Serializable) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
purge(Class<T>, Serializable) - Method in interface org.hibernate.search.sandbox.standalone.FullTextManager
Remove the entity with the type entityType and the identifier id from the index.
purge(Class<T>, Serializable) - Method in class org.hibernate.search.sandbox.standalone.LuceneFullTextManager
 
purgeAll(Class<T>) - Method in interface org.hibernate.search.FullTextSession
Remove all entities from of particular class and all its subclasses from the index.
purgeAll(Class<T>) - Method in class org.hibernate.search.impl.FullTextSessionImpl
Remove all entities from of particular class and all its subclasses from the index.
purgeAll(Class<T>) - Method in interface org.hibernate.search.jpa.FullTextEntityManager
Remove all entities from of particular class and all its subclasses from the index.
purgeAll(Class<T>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
purgeAll(Class<T>) - Method in interface org.hibernate.search.sandbox.standalone.FullTextManager
Remove all entities from of particular class and all its subclasses from the index.
purgeAll(Class<T>) - Method in class org.hibernate.search.sandbox.standalone.LuceneFullTextManager
 
PurgeAllLuceneWork - Class in org.hibernate.search.backend
A unit of work used to purge an entire index.
PurgeAllLuceneWork(Class) - Constructor for class org.hibernate.search.backend.PurgeAllLuceneWork
 
purgeAllOnStart(boolean) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
purgeAllOnStart(boolean) - Method in interface org.hibernate.search.MassIndexer
If all entities should be removed from the index before starting using purgeAll.
pushMethod(String) - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
pushMethod(String) - Method in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
put(Object, Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
put(T) - Method in class org.hibernate.search.batchindexing.ProducerConsumerQueue
Adds a new object to the queue, blocking if no space is available.
put(Object, Object) - Method in class org.hibernate.search.util.SoftLimitMRUCache
Puts a value in the cache.
put(K, V) - Method in class org.hibernate.search.util.WeakIdentityHashMap
Associates the specified value with the specified key in this map.
putAll(Map<? extends Object, ? extends Object>) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
putAll(Map<? extends K, ? extends V>) - Method in class org.hibernate.search.util.WeakIdentityHashMap
Copies all of the mappings from the specified map to this map These mappings will replace any mappings that this map had for any of the keys currently in the specified map.

Q

QueryBuilder - Interface in org.hibernate.search.query.dsl
 
QueryBuildingContext - Class in org.hibernate.search.query.dsl.impl
Keep the query builder contextual information
QueryBuildingContext(SearchFactoryImplementor, Analyzer, Class<?>) - Constructor for class org.hibernate.search.query.dsl.impl.QueryBuildingContext
 
QueryContextBuilder - Interface in org.hibernate.search.query.dsl
Query builder that needs contextualization: A query builder should know which entity or analyzer it relies on.
QueryCustomization<T> - Interface in org.hibernate.search.query.dsl
Operations common to all types of queries
QueryHits - Class in org.hibernate.search.query
A helper class which gives access to the current query and its hits.
QueryHits(IndexSearcherWithPayload, Query, Filter, Sort, TimeoutManager) - Constructor for class org.hibernate.search.query.QueryHits
 
QueryHits(IndexSearcherWithPayload, Query, Filter, Sort, Integer, TimeoutManager) - Constructor for class org.hibernate.search.query.QueryHits
 
QueryLoader - Class in org.hibernate.search.engine
 
QueryLoader() - Constructor for class org.hibernate.search.engine.QueryLoader
 
QueueingProcessor - Interface in org.hibernate.search.backend
Pile work operations No thread safety has to be implemented, the queue being scoped already The implementation must be "stateless" wrt the queue through (ie not store the queue state) FIXME this Interface does not make much sense, since the impl will not be changed

R

raiseExceptionOnTimeout() - Method in class org.hibernate.search.query.TimeoutManager
 
RAMDirectoryProvider - Class in org.hibernate.search.store
Use a Lucene RAMDirectory
RAMDirectoryProvider() - Constructor for class org.hibernate.search.store.RAMDirectoryProvider
 
range() - Method in class org.hibernate.search.query.dsl.impl.ConnectedQueryBuilder
 
range() - Method in interface org.hibernate.search.query.dsl.QueryBuilder
find matching elements within a range
RangeContext - Interface in org.hibernate.search.query.dsl
 
RangeMatchingContext - Interface in org.hibernate.search.query.dsl
 
RangeMatchingContext.FromRangeContext<T> - Interface in org.hibernate.search.query.dsl
 
RangeQueryContext - Class in org.hibernate.search.query.dsl.impl
 
RangeQueryContext() - Constructor for class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
RangeTerminationExcludable - Interface in org.hibernate.search.query.dsl
 
reactOnQueryTimeoutExceptionWhileExtracting(QueryTimeoutException) - Method in class org.hibernate.search.query.TimeoutManager
 
reader - Variable in class org.hibernate.search.reader.SharingBufferReaderProvider.ReaderUsagePair
 
READER_PREFIX - Static variable in class org.hibernate.search.Environment
define the reader prefix
READER_STRATEGY - Static variable in class org.hibernate.search.Environment
define the reader strategy used
readerFactory(Directory) - Method in class org.hibernate.search.reader.SharingBufferReaderProvider
 
ReaderProvider - Interface in org.hibernate.search.reader
Responsible for providing and managing the lifecycle of a read only reader.
ReaderProviderFactory - Class in org.hibernate.search.reader
 
ReaderProviderFactory() - Constructor for class org.hibernate.search.reader.ReaderProviderFactory
 
ReaderProviderHelper - Class in org.hibernate.search.reader
 
ReaderProviderHelper() - Constructor for class org.hibernate.search.reader.ReaderProviderHelper
 
receive(Message) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsMasterMessageListener
 
reconnect() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
reconnect(Connection) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
ReflectionHelper - Class in org.hibernate.search.util
 
reflectionManager - Variable in class org.hibernate.search.engine.AbstractDocumentBuilder
 
refresh(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
refresh(Object, LockMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
refresh(Object, LockOptions) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
refresh(Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
refresh(Object, Map<String, Object>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
refresh(Object, LockModeType) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
refresh(Object, LockModeType, Map<String, Object>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
refreshAndGet() - Method in class org.hibernate.search.reader.SharingBufferReaderProvider.PerDirectoryLatestReader
Gets an updated IndexReader for the current Directory; the index status will be checked.
registerMBean(Object, String) - Static method in class org.hibernate.search.jmx.JMXRegistrar
Registers the specified object with the given name to the MBean server.
registerSynchronization(Synchronization) - Method in class org.hibernate.search.backend.impl.EventSourceTransactionContext
 
registerSynchronization(Synchronization) - Method in interface org.hibernate.search.backend.TransactionContext
Register the given synchronization.
registerSynchronization(Synchronization) - Method in class org.hibernate.search.sandbox.standalone.InstanceTransactionContext
 
rehash() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.hibernate.search.batchindexing.Executors.BlockPolicy
Puts the Runnable to the blocking queue, effectively blocking the delegating thread until space is available.
releaseService(Class<? extends ServiceProvider<?>>) - Method in class org.hibernate.search.engine.ServiceManager
 
releaseService(Class<? extends ServiceProvider<?>>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
releaseService(Class<? extends ServiceProvider<?>>) - Method in interface org.hibernate.search.spi.BuildContext
Release a service from duty.
remove(Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
remove(Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
remove() - Method in class org.hibernate.search.query.IteratorImpl
 
remove(Object) - Method in class org.hibernate.search.util.WeakIdentityHashMap
Removes the mapping for this key from this map if present.
removeValue(Object) - Method in class org.hibernate.search.util.WeakIdentityHashMap
Remove elements having the according value.
replicate(String, Object, ReplicationMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
replicate(Object, ReplicationMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
requestService(Class<? extends ServiceProvider<T>>) - Method in class org.hibernate.search.engine.ServiceManager
 
requestService(Class<? extends ServiceProvider<T>>) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
requestService(Class<? extends ServiceProvider<T>>) - Method in interface org.hibernate.search.spi.BuildContext
Declare the use of a service.
requiresProvidedId() - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
requiresProvidedId() - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
Resolution - Enum in org.hibernate.search.annotations
Date indexing resolution.
RESOLUTION_PARAMETER - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
RESOURCE_CHARSET - Static variable in class org.hibernate.search.Environment
Tokenizer or filter parameter describing the charset used to load associated resources if needed.
RETRY_MARKER_LOOKUP - Static variable in class org.hibernate.search.Environment
Number of times we retry the logic looking for marker files in master's directory before giving up and raising an exception.
returnAlreadyLoadedObjectsInCorrectOrder(EntityInfo[], Session) - Static method in class org.hibernate.search.engine.ObjectLoaderHelper
 
reusableTokenStream(String, Reader) - Method in class org.hibernate.search.util.DelegateNamedAnalyzer
 
rollback() - Method in class org.hibernate.search.sandbox.standalone.InstanceTransactionContext
 
rootEntities - Variable in class org.hibernate.search.impl.MassIndexerImpl
 
run() - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessor
 
run() - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessor
 
run() - Method in class org.hibernate.search.backend.impl.lucene.CloseIndexRunnable
 
run() - Method in class org.hibernate.search.batchindexing.BatchCoordinator
 
run() - Method in class org.hibernate.search.batchindexing.BatchIndexingWorkspace
 
run(Session) - Method in class org.hibernate.search.batchindexing.EntityConsumerLuceneworkProducer
 
run(Session) - Method in class org.hibernate.search.batchindexing.IdentifierConsumerEntityProducer
 
run(StatelessSession) - Method in class org.hibernate.search.batchindexing.IdentifierProducer
 
run() - Method in class org.hibernate.search.batchindexing.OptionallyWrapInJTATransaction
 
run(Session) - Method in interface org.hibernate.search.batchindexing.SessionAwareRunnable
 
run(StatelessSession) - Method in interface org.hibernate.search.batchindexing.StatelessSessionAwareRunnable
 

S

save(OutputStream, String) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
save(String, Object, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
save(Object, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
save(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
save(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
saveOrUpdate(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
saveOrUpdate(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
saveOrUpdateCopy(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
saveOrUpdateCopy(String, Object, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
saveOrUpdateCopy(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
saveOrUpdateCopy(Object, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
ScopedAnalyzer - Class in org.hibernate.search.util
A ScopedAnalyzer is a wrapper class containing all analyzers for a given class.
ScopedAnalyzer() - Constructor for class org.hibernate.search.util.ScopedAnalyzer
 
SCORE - Static variable in interface org.hibernate.search.ProjectionConstants
The legacy document's score from a search.
score(int) - Method in class org.hibernate.search.query.QueryHits
 
scoreDoc(int) - Method in class org.hibernate.search.query.QueryHits
 
scroll(String, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
scroll(CriteriaImpl, ScrollMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
scroll(NativeSQLQuerySpecification, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
scroll() - Method in class org.hibernate.search.query.FullTextQueryImpl
 
scroll(ScrollMode) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
scroll(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
ScrollableResultsImpl - Class in org.hibernate.search.query
Implements scrollable and paginated resultsets.
ScrollableResultsImpl(IndexSearcher, int, int, int, DocumentExtractor, Loader, SearchFactory, SessionImplementor) - Constructor for class org.hibernate.search.query.ScrollableResultsImpl
 
scrollCustomQuery(CustomQuery, QueryParameters) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
Search - Class in org.hibernate.search.jpa
Helper class that should be used when building a FullTextEntityManager
Search - Class in org.hibernate.search
Helper class to get a FullTextSession out of a regular session.
SearchConfiguration - Interface in org.hibernate.search.cfg
Provides configuration to Hibernate Search
SearchConfigurationFromHibernateCore - Class in org.hibernate.search.cfg
Search configuration implementation wrapping an Hibernate Core configuration
SearchConfigurationFromHibernateCore(Configuration) - Constructor for class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
searcher - Variable in class org.hibernate.search.query.QueryHits
 
SearchException - Exception in org.hibernate.search
Root of all search specific exceptions
SearchException() - Constructor for exception org.hibernate.search.SearchException
 
SearchException(String) - Constructor for exception org.hibernate.search.SearchException
 
SearchException(String, Throwable) - Constructor for exception org.hibernate.search.SearchException
 
SearchException(Throwable) - Constructor for exception org.hibernate.search.SearchException
 
searchExecuted(String, long) - Method in class org.hibernate.search.stat.StatisticsImpl
 
searchExecuted(String, long) - Method in interface org.hibernate.search.stat.StatisticsImplementor
Callback for an executed Lucene search.
searchFactory - Variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
searchFactory(SearchFactoryImplementor) - Method in class org.hibernate.search.query.ObjectLoaderBuilder
 
SearchFactory - Interface in org.hibernate.search
Provide application wide operations as well as access to the underlying Lucene resources.
SearchFactoryBuilder - Class in org.hibernate.search.spi
Build a search factory following the builder pattern.
SearchFactoryBuilder() - Constructor for class org.hibernate.search.spi.SearchFactoryBuilder
 
SearchFactoryImplementor - Interface in org.hibernate.search.engine
Interface which gives access to the metadata.
searchFactoryImplementor - Variable in class org.hibernate.search.event.FullTextIndexEventListener
 
SearchFactoryImplementorWithShareableState - Interface in org.hibernate.search.spi.internals
Search Factory implementor exposing its sharable state.
SearchFactoryIntegrator - Interface in org.hibernate.search.spi
This contract is considered experimental.
SearchFactoryState - Interface in org.hibernate.search.spi.internals
Represents the sharable state of a search factory
searchForContainers() - Method in enum org.hibernate.search.backend.WorkType
When references are changed, either null or another one, we expect dirty checking to be triggered (both sides have to be updated) When the internal object is changed, we apply the {Add|Update}Work on containedIns
SearchMapping - Class in org.hibernate.search.cfg
 
SearchMapping() - Constructor for class org.hibernate.search.cfg.SearchMapping
 
SearchMappingBuilder - Class in org.hibernate.search.impl
package class extracting the SearchMappingFactory if needed
sentence(String) - Method in class org.hibernate.search.query.dsl.impl.ConnectedPhraseMatchingContext
 
sentence(String) - Method in interface org.hibernate.search.query.dsl.PhraseMatchingContext
Sentence to match.
ServiceManager - Class in org.hibernate.search.engine
 
ServiceManager(SearchConfiguration) - Constructor for class org.hibernate.search.engine.ServiceManager
 
ServiceProvider<T> - Interface in org.hibernate.search.spi
Control the life cycle of a service attached and used by Hibernate Search It allows to: - start the service - stop the service - declare the key the service is exposed to TODO should it be the implementation name itself? - provide access tot he service
session(SessionImplementor) - Method in class org.hibernate.search.query.ObjectLoaderBuilder
 
SessionAwareRunnable - Interface in org.hibernate.search.batchindexing
 
set(String, Object, Document, LuceneOptions) - Method in class org.hibernate.search.bridge.builtin.NumericFieldBridge
 
set(String, Object, Document, LuceneOptions) - Method in interface org.hibernate.search.bridge.FieldBridge
Manipulate the document to index the given value.
set(String, Object, Document, LuceneOptions) - Method in class org.hibernate.search.bridge.NullEncodingTwoWayFieldBridge
 
set(String, Object, Document, LuceneOptions) - Method in class org.hibernate.search.bridge.String2FieldBridgeAdaptor
 
set(String, Object, Document, LuceneOptions) - Method in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
setAccessible(XMember) - Static method in class org.hibernate.search.util.ReflectionHelper
Always use this method to set accessibility regardless of the visibility.
setAccessible(AccessibleObject) - Static method in class org.hibernate.search.util.ReflectionHelper
Always use this method to set accessibility regardless of the visibility.
setAnalyzerDiscriminator(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setAnalyzerDiscriminator(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setAnalyzers(Map<String, Analyzer>) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setAppliedOnType(Class<?>) - Method in interface org.hibernate.search.bridge.AppliedOnTypeAwareBridge
Set the return type of the bridge (the type of the field linked to the bridge).
setAppliedOnType(Class<?>) - Method in class org.hibernate.search.bridge.builtin.EnumBridge
 
setAutoClear(boolean) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setBackendQueueProcessorFactory(BackendQueueProcessorFactory) - Method in class org.hibernate.search.impl.ImmutableSearchFactory
 
setBackendQueueProcessorFactory(BackendQueueProcessorFactory) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
setBackendQueueProcessorFactory(BackendQueueProcessorFactory) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setBackendQueueProcessorFactory(BackendQueueProcessorFactory) - Method in interface org.hibernate.search.spi.internals.SearchFactoryState
 
setBackendQueueProcessorFactory(BackendQueueProcessorFactory) - Method in interface org.hibernate.search.spi.WorkerBuildContext
Register the backend queue processor factory.
setBatchSize(int) - Method in class org.hibernate.search.jmx.IndexControl
 
setBatchSize(int) - Method in interface org.hibernate.search.jmx.IndexControlMBean
Sets the batch size for the mass indexer.
setBoost(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setCacheBitResultsSize(int) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setCacheMode(CacheMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setCalendarBridge(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setClass(Class<?>) - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
setClass(Class<?>) - Method in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
setClusterName(String) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
setConfigurationProperties(Properties) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setContainedIn(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setCriteria(Criteria) - Method in class org.hibernate.search.engine.QueryLoader
 
setCriteriaQuery(Criteria) - Method in interface org.hibernate.search.FullTextQuery
Defines the Database Query used to load the Lucene results.
setCriteriaQuery(Criteria) - Method in interface org.hibernate.search.jpa.FullTextQuery
Defines the Database Query used to load the Lucene results.
setCriteriaQuery(Criteria) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setCriteriaQuery(Criteria) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setCurrentValueFor(IndexWriterSetting, Integer) - Method in class org.hibernate.search.backend.LuceneIndexingParameters.ParameterSet
 
setDateBridge(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setDefaultReadOnly(boolean) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setDelegate(SearchFactoryImplementorWithShareableState) - Method in class org.hibernate.search.impl.MutableSearchFactory
 
setDelegate(Analyzer) - Method in class org.hibernate.search.util.DelegateNamedAnalyzer
 
setDirectoryProviderData(Map<DirectoryProvider<?>, DirectoryProviderData>) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setDirectoryProviderIndexingParams(Map<DirectoryProvider, LuceneIndexingParameters>) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setDocumentBuildersContainedEntities(Map<Class<?>, DocumentBuilderContainedEntity<?>>) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setDocumentBuildersIndexedEntities(Map<Class<?>, DocumentBuilderIndexedEntity<?>>) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setDocumentId(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setDynamicBoost(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setDynamicBoost(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setEntityState(EntityState) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
setEntityType(Class) - Method in class org.hibernate.search.engine.QueryLoader
 
setEntityTypes(Set<Class<?>>) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
setErrorHandler(ErrorHandler) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setExcludeFrom(boolean) - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
setExcludeTo(boolean) - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
setExclusiveIndexUsage(boolean) - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
setFactoryMethod(Method) - Method in class org.hibernate.search.engine.FilterDef
 
setFetchProfile(String) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setFetchSize(int) - Method in interface org.hibernate.search.FullTextQuery
Defines scrollable result fetch size as well as the JDBC fetch size
setFetchSize(int) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setFieldBridge(TwoWayFieldBridge) - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
setFieldBridge(FieldBridge) - Method in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
setFieldName(String) - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
setFieldName(String) - Method in class org.hibernate.search.bridge.util.ContextualExceptionBridge
 
setFilter(Filter) - Method in interface org.hibernate.search.FullTextQuery
Allows to use lucene filters.
setFilter(Filter) - Method in interface org.hibernate.search.jpa.FullTextQuery
Allows to use lucene filters.
setFilter(Filter) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setFilter(Filter) - Method in class org.hibernate.search.query.FullTextQueryImpl
Allows to use lucene filters.
setFilterCachingStrategy(FilterCachingStrategy) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setFilterDefinitions(Map<String, FilterDef>) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setFirstResult(int) - Method in interface org.hibernate.search.FullTextQuery
{link:Query#setFirstResult}
setFirstResult(int) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setFirstResult(int) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setFlushMode(FlushMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setFlushMode(FlushModeType) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
setFlushMode(FlushModeType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setFrom(Object) - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
setGlobalAnalyzer(Analyzer) - Method in class org.hibernate.search.util.ScopedAnalyzer
 
setHint(String, Object) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setIgnoreAnalyzer(boolean) - Method in class org.hibernate.search.query.dsl.impl.FieldContext
 
setIgnoreFieldBridge(boolean) - Method in class org.hibernate.search.query.dsl.impl.FieldContext
 
setImpl(Class) - Method in class org.hibernate.search.filter.FilterKey
 
setImpl(Class) - Method in class org.hibernate.search.filter.StandardFilterKey
 
setIndexed(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setIndexEmbedded(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setIndexHierarchy(PolymorphicIndexHierarchy) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setIndexingStrategy(String) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setKeyMethod(Method) - Method in class org.hibernate.search.engine.FilterDef
 
setLockMode(LockModeType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setLockMode(String, LockMode) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setLockOptions(LockOptions) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setMaxResults(int) - Method in interface org.hibernate.search.FullTextQuery
{link:Query#setMaxResults}
setMaxResults(int) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setMaxResults(int) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setName(String) - Method in class org.hibernate.search.query.FullTextFilterImpl
 
setNumberOfFetchingThreads(int) - Method in class org.hibernate.search.jmx.IndexControl
 
setNumberOfFetchingThreads(int) - Method in interface org.hibernate.search.jmx.IndexControlMBean
 
setNumberOfObjectLoadingThreads(int) - Method in class org.hibernate.search.jmx.IndexControl
 
setNumberOfObjectLoadingThreads(int) - Method in interface org.hibernate.search.jmx.IndexControlMBean
 
setNumericValue(Object, NumericField) - Static method in class org.hibernate.search.bridge.util.NumericFieldUtils
 
setOptimizerStrategy(OptimizerStrategy) - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
setParameter(String, Object) - Method in interface org.hibernate.search.FullTextFilter
 
setParameter(Parameter<T>, T) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(Parameter<Calendar>, Calendar, TemporalType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(Parameter<Date>, Date, TemporalType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(String, Object) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(String, Date, TemporalType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(String, Calendar, TemporalType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(int, Object) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(int, Date, TemporalType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(int, Calendar, TemporalType) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setParameter(String, Object) - Method in class org.hibernate.search.query.FullTextFilterImpl
 
setParameterValues(Map) - Method in class org.hibernate.search.bridge.builtin.CalendarBridge
 
setParameterValues(Map) - Method in class org.hibernate.search.bridge.builtin.DateBridge
 
setParameterValues(Map) - Method in interface org.hibernate.search.bridge.ParameterizedBridge
 
setParameterValues(Map) - Method in class org.hibernate.search.cfg.ConcatStringBridge
 
setProjection(String...) - Method in interface org.hibernate.search.FullTextQuery
Defines the Lucene field names projected and returned in a query result Each field is converted back to it's object representation, an Object[] being returned for each "row" (similar to an HQL or a Criteria API projection).
setProjection(String...) - Method in interface org.hibernate.search.jpa.FullTextQuery
Defines the Lucene field names projected and returned in a query result Each field is converted back to it's object representation, an Object[] being returned for each "row" (similar to an HQL or a Criteria API projection).
setProjection(String...) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setProjection(String...) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setProperty(String, String) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
setProperty(String, Object) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
setProvidedId(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setReaderProvider(ReaderProvider) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setReadOnly(Object, boolean) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setResultTransformer(ResultTransformer) - Method in interface org.hibernate.search.FullTextQuery
defines a result transformer used during projection, the Aliases provided are the projection aliases.
setResultTransformer(ResultTransformer) - Method in interface org.hibernate.search.jpa.FullTextQuery
defines a result transformer used during projection
setResultTransformer(ResultTransformer) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setResultTransformer(ResultTransformer) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setRowNumber(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
setSentence(String) - Method in class org.hibernate.search.query.dsl.impl.PhraseQueryContext
 
setServiceManager(ServiceManager) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
setSimilarity(Similarity) - Method in class org.hibernate.search.spi.internals.DirectoryProviderData
 
setSimilariy(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setSlop(int) - Method in class org.hibernate.search.query.dsl.impl.PhraseQueryContext
 
setSort(Sort) - Method in interface org.hibernate.search.FullTextQuery
Allows to let lucene sort the results.
setSort(Sort) - Method in interface org.hibernate.search.jpa.FullTextQuery
Allows to let lucene sort the results.
setSort(Sort) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
setSort(Sort) - Method in class org.hibernate.search.query.FullTextQueryImpl
Allows to let lucene sort the results.
setState(byte[]) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsMasterMessageListener
 
setStatisticsEnabled(boolean) - Method in class org.hibernate.search.jmx.StatisticsInfo
 
setStatisticsEnabled(boolean) - Method in interface org.hibernate.search.stat.Statistics
Enable statistics logs (this is a dynamic parameter)
setStatisticsEnabled(boolean) - Method in class org.hibernate.search.stat.StatisticsImpl
 
setStringBridge(StringBridge) - Method in class org.hibernate.search.bridge.util.ContextualException2WayBridge
 
setTimeout(long, TimeUnit) - Method in interface org.hibernate.search.FullTextQuery
Define a timeout period for a given unit of time.
setTimeout(int) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setTimeout(long, TimeUnit) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
setTimeout(long, TimeUnit) - Method in class org.hibernate.search.query.TimeoutManager
 
setTo(Object) - Method in class org.hibernate.search.query.dsl.impl.RangeQueryContext
 
setWorker(Worker) - Method in class org.hibernate.search.impl.MutableSearchFactoryState
 
ShardSensitiveOnlyFilter - Interface in org.hibernate.search.filter
When using this class in @FullTextFilterDef.impl, Hibernate Search considers the filter to be only influencing the sharding strategy.
SharedReaderProvider - Class in org.hibernate.search.reader
Deprecated. replaced by SharingBufferReaderProvider
SharedReaderProvider() - Constructor for class org.hibernate.search.reader.SharedReaderProvider
Deprecated.  
SharingBufferReaderProvider - Class in org.hibernate.search.reader
This ReaderProvider shares IndexReaders as long as they are "current"; main difference with SharedReaderProvider is the way to update the Readers when needed: this uses IndexReader.reopen() which should improve performance on larger indexes as it shares buffers with previous IndexReader generation for the segments which didn't change.
SharingBufferReaderProvider() - Constructor for class org.hibernate.search.reader.SharingBufferReaderProvider
 
SharingBufferReaderProvider.PerDirectoryLatestReader - Class in org.hibernate.search.reader
An instance for each DirectoryProvider, establishing the association between "current" ReaderUsagePair for a DirectoryProvider and it's lock.
SharingBufferReaderProvider.PerDirectoryLatestReader(Directory) - Constructor for class org.hibernate.search.reader.SharingBufferReaderProvider.PerDirectoryLatestReader
 
SharingBufferReaderProvider.ReaderUsagePair - Class in org.hibernate.search.reader
Container for the couple IndexReader,UsageCounter.
SHORT - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
ShortBridge - Class in org.hibernate.search.bridge.builtin
Map a short element
ShortBridge() - Constructor for class org.hibernate.search.bridge.builtin.ShortBridge
 
should(Query) - Method in interface org.hibernate.search.query.dsl.BooleanJunction
The boolean query results should match the subquery
shutdown() - Method in class org.hibernate.search.backend.impl.jms.AbstractJMSHibernateSearchController
 
Similarity - Annotation Type in org.hibernate.search.annotations
 
similarity(Class<?>) - Method in class org.hibernate.search.cfg.EntityMapping
 
similarity(Class<?>) - Method in class org.hibernate.search.cfg.IndexedMapping
 
SIMILARITY_CLASS - Static variable in class org.hibernate.search.Environment
Default Lucene similarity
SIMILARITY_CLASS_PER_INDEX - Static variable in class org.hibernate.search.Environment
Define the similarity class name for a given index
SimpleIndexingProgressMonitor - Class in org.hibernate.search.impl
A very simple implementation of MassIndexerProgressMonitor.
SimpleIndexingProgressMonitor() - Constructor for class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
SingleErrorContext - Class in org.hibernate.search.exception.impl
Simplest implementation of an ErrorContext, use it to wrap single exceptions in the backend which are hard to relate to the workqueue as a whole.
SingleErrorContext(Throwable) - Constructor for class org.hibernate.search.exception.impl.SingleErrorContext
 
size() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
size() - Method in class org.hibernate.search.backend.WorkQueue
Returns an estimate of the to be performed operations
SIZE - Static variable in class org.hibernate.search.cfg.ConcatStringBridge
 
size() - Method in class org.hibernate.search.engine.WorkPlan
Returns an approximation of the amount of work that #getPlannedLuceneWork(SearchFactoryImplementor) would return.
size() - Method in class org.hibernate.search.util.SoftLimitMRUCache
Gets the strong reference cache size.
size() - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns the number of key-value mappings in this map.
SlaveJGroupsBackendQueueProcessorFactory - Class in org.hibernate.search.backend.impl.jgroups
 
SlaveJGroupsBackendQueueProcessorFactory() - Constructor for class org.hibernate.search.backend.impl.jgroups.SlaveJGroupsBackendQueueProcessorFactory
 
SoftLimitMRUCache - Class in org.hibernate.search.util
Cache following a "Most Recently Used" (MRU) algorithm for maintaining a bounded in-memory size; the "Least Recently Used" (LRU) entry is the first available for removal from the cache.
SoftLimitMRUCache() - Constructor for class org.hibernate.search.util.SoftLimitMRUCache
Constructs a cache with the default settings.
SoftLimitMRUCache(int, int) - Constructor for class org.hibernate.search.util.SoftLimitMRUCache
Constructs a cache with the specified settings.
softSize() - Method in class org.hibernate.search.util.SoftLimitMRUCache
Gets the soft reference cache size.
sort - Variable in class org.hibernate.search.query.QueryHits
 
splitQueue() - Method in class org.hibernate.search.backend.WorkQueue
 
StandardFilterKey - Class in org.hibernate.search.filter
Implements a filter key usign all injected parameters to compute equals and hashCode the order the parameters are added is significant
StandardFilterKey() - Constructor for class org.hibernate.search.filter.StandardFilterKey
 
start() - Method in class org.hibernate.search.impl.MassIndexerImpl
 
start() - Method in interface org.hibernate.search.MassIndexer
Starts the indexing process in background (asynchronous).
start(Query) - Method in class org.hibernate.search.query.TimeoutManager
we start counting from this method call (if needed)
start(Properties) - Method in interface org.hibernate.search.spi.ServiceProvider
 
start() - Method in interface org.hibernate.search.store.DirectoryProvider
Executed after initialize, this method set up the heavy process of starting up the DirectoryProvider IO processing as well as background processing are expected to be set up here
start() - Method in class org.hibernate.search.store.FSDirectoryProvider
 
start() - Method in class org.hibernate.search.store.FSMasterDirectoryProvider
 
start() - Method in class org.hibernate.search.store.FSSlaveDirectoryProvider
 
start() - Method in class org.hibernate.search.store.RAMDirectoryProvider
 
startAndWait() - Method in class org.hibernate.search.impl.MassIndexerImpl
 
startAndWait() - Method in interface org.hibernate.search.MassIndexer
Starts the indexing process, and then block until it's finished.
startDirectoryProviders() - Method in class org.hibernate.search.store.DirectoryProviderFactory
 
StatelessSessionAwareRunnable - Interface in org.hibernate.search.batchindexing
 
Statistics - Interface in org.hibernate.search.stat
Interface which defines several methods allowing to access statistical data.
STATISTICS_MBEAN_OBJECT_NAME - Static variable in interface org.hibernate.search.jmx.StatisticsInfoMBean
 
StatisticsImpl - Class in org.hibernate.search.stat
A concurrent implementation of the Statistics interface.
StatisticsImpl(SearchFactoryImplementor) - Constructor for class org.hibernate.search.stat.StatisticsImpl
 
StatisticsImplementor - Interface in org.hibernate.search.stat
Statistics SPI for the Search.
StatisticsInfo - Class in org.hibernate.search.jmx
 
StatisticsInfo(Statistics) - Constructor for class org.hibernate.search.jmx.StatisticsInfo
 
StatisticsInfoMBean - Interface in org.hibernate.search.jmx
 
stop() - Method in class org.hibernate.search.query.TimeoutManager
 
stop() - Method in interface org.hibernate.search.spi.ServiceProvider
 
stop() - Method in interface org.hibernate.search.store.DirectoryProvider
Executed when the search factory is closed.
stop() - Method in class org.hibernate.search.store.FSDirectoryProvider
 
stop() - Method in class org.hibernate.search.store.FSMasterDirectoryProvider
 
stop() - Method in class org.hibernate.search.store.FSSlaveDirectoryProvider
 
stop() - Method in class org.hibernate.search.store.RAMDirectoryProvider
 
stopAndFlush(long, TimeUnit) - Method in interface org.hibernate.search.backend.impl.batchlucene.BatchBackend
Waits until all work is done and terminates the executors.
stopAndFlush(long, TimeUnit) - Method in class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
Stops the background threads and flushes changes; Please note the timeout is applied to each index in sequence, so it might take as much time as timeout*directoryproviders
stopServices() - Method in class org.hibernate.search.engine.ServiceManager
 
Store - Enum in org.hibernate.search.annotations
Whether or not the value is stored in the document
store(OutputStream, String) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
store(Store) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
store(Store) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
store(Store) - Method in class org.hibernate.search.cfg.FieldMapping
 
storeToXML(OutputStream, String, String) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
storeToXML(OutputStream, String) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
STRING - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
String2FieldBridgeAdaptor - Class in org.hibernate.search.bridge
Bridge to use a StringBridge as a FieldBridge.
String2FieldBridgeAdaptor(StringBridge) - Constructor for class org.hibernate.search.bridge.String2FieldBridgeAdaptor
 
StringBridge - Class in org.hibernate.search.bridge.builtin
Map a string element
StringBridge() - Constructor for class org.hibernate.search.bridge.builtin.StringBridge
 
StringBridge - Interface in org.hibernate.search.bridge
Transform an object into a string representation.
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.BigDecimalBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.BigIntegerBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.BooleanBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.CalendarBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.CharacterBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.ClassBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.DateBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.DoubleBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.EnumBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.FloatBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.IntegerBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.LongBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.ShortBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.StringBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.UriBridge
 
stringToObject(String) - Method in class org.hibernate.search.bridge.builtin.UrlBridge
 
stringToObject(String) - Method in interface org.hibernate.search.bridge.TwoWayStringBridge
Convert the index string representation to an object.
subClassSpecificCheck(XProperty, AbstractDocumentBuilder.PropertiesMetadata, boolean, String, ConfigContext) - Method in class org.hibernate.search.engine.AbstractDocumentBuilder
 
subClassSpecificCheck(XProperty, AbstractDocumentBuilder.PropertiesMetadata, boolean, String, ConfigContext) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
subClassSpecificCheck(XProperty, AbstractDocumentBuilder.PropertiesMetadata, boolean, String, ConfigContext) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
suspect(Address) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsMasterMessageListener
 
synchronizationPerTransaction - Variable in class org.hibernate.search.backend.impl.TransactionalWorker
 
synchronize(File, File, boolean) - Static method in class org.hibernate.search.util.FileHelper
 
synchronize(File, File, boolean, long) - Static method in class org.hibernate.search.util.FileHelper
 

T

take() - Method in class org.hibernate.search.batchindexing.ProducerConsumerQueue
Blocks until an object is available; when null is returned the client thread should quit.
targetedEntities(List<Class<?>>) - Method in class org.hibernate.search.query.ObjectLoaderBuilder
 
targetElement(Class<?>) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
TermContext - Interface in org.hibernate.search.query.dsl
 
TermFuzzy - Interface in org.hibernate.search.query.dsl
 
Termination<T> - Interface in org.hibernate.search.query.dsl
 
TermMatchingContext - Interface in org.hibernate.search.query.dsl
 
TermTermination - Interface in org.hibernate.search.query.dsl
 
TermVector - Enum in org.hibernate.search.annotations
Defines the term vector storing strategy
termVector(TermVector) - Method in class org.hibernate.search.cfg.ClassBridgeMapping
 
termVector(TermVector) - Method in class org.hibernate.search.cfg.FieldBridgeMapping
 
termVector(TermVector) - Method in class org.hibernate.search.cfg.FieldMapping
 
THIS - Static variable in interface org.hibernate.search.ProjectionConstants
Represents the Hibernate entity returned in a search.
threadsForSubsequentFetching(int) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
threadsForSubsequentFetching(int) - Method in interface org.hibernate.search.MassIndexer
Sets the number of threads used to load the lazy collections related to the indexed entities.
threadsToLoadObjects(int) - Method in class org.hibernate.search.impl.MassIndexerImpl
 
threadsToLoadObjects(int) - Method in interface org.hibernate.search.MassIndexer
Set the number of threads to be used to load the root entities.
timeoutManager(TimeoutManager) - Method in class org.hibernate.search.query.ObjectLoaderBuilder
 
TimeoutManager - Class in org.hibernate.search.query
 
TimeoutManager() - Constructor for class org.hibernate.search.query.TimeoutManager
 
TimeoutManager.Type - Enum in org.hibernate.search.query
 
to(T) - Method in interface org.hibernate.search.query.dsl.RangeMatchingContext.FromRangeContext
 
TokenFilterDef - Annotation Type in org.hibernate.search.annotations
Define a TokenFilterFactory and its parameters.
TokenFilterDefMapping - Class in org.hibernate.search.cfg
 
TokenizerDef - Annotation Type in org.hibernate.search.annotations
Define a TokenizerFactory and its parameters.
tokenizerParam(String, String) - Method in class org.hibernate.search.cfg.AnalyzerDefMapping
 
tokenStream(String, Reader) - Method in class org.hibernate.search.util.DelegateNamedAnalyzer
 
tokenStream(String, Reader) - Method in class org.hibernate.search.util.PassThroughAnalyzer
 
tokenStream(String, Reader) - Method in class org.hibernate.search.util.ScopedAnalyzer
 
topDocs - Variable in class org.hibernate.search.query.QueryHits
 
toString() - Method in class org.hibernate.search.backend.AddLuceneWork
 
toString() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
toString() - Method in class org.hibernate.search.backend.DeleteLuceneWork
 
toString() - Method in class org.hibernate.search.backend.LuceneIndexingParameters.ParameterSet
 
toString() - Method in class org.hibernate.search.backend.LuceneIndexingParameters
 
toString() - Method in class org.hibernate.search.backend.OptimizeLuceneWork
 
toString() - Method in class org.hibernate.search.backend.PurgeAllLuceneWork
 
toString() - Method in class org.hibernate.search.filter.CachingWrapperFilter
 
toString() - Method in class org.hibernate.search.filter.ChainedFilter
 
toString() - Method in class org.hibernate.search.reader.SharingBufferReaderProvider.ReaderUsagePair
 
totalHits - Variable in class org.hibernate.search.query.QueryHits
 
touch() - Static method in class org.hibernate.search.Version
 
TRANSACTION - Static variable in class org.hibernate.search.backend.LuceneIndexingParameters
 
TransactionalWorker - Class in org.hibernate.search.backend.impl
Queue works per transaction.
TransactionalWorker() - Constructor for class org.hibernate.search.backend.impl.TransactionalWorker
 
TransactionContext - Interface in org.hibernate.search.backend
Contract needed by Hibernate Search to batch changes per transaction.
TwoWayFieldBridge - Interface in org.hibernate.search.bridge
A FieldBridge able to convert the index representation back into an object without losing information.
TwoWayString2FieldBridgeAdaptor - Class in org.hibernate.search.bridge
Bridge to use a TwoWayStringBridge as a TwoWayFieldBridge
TwoWayString2FieldBridgeAdaptor(TwoWayStringBridge) - Constructor for class org.hibernate.search.bridge.TwoWayString2FieldBridgeAdaptor
 
TwoWayStringBridge - Interface in org.hibernate.search.bridge
StringBridge allowing a translation from the string representation back to the Object.

U

unproxy(Object) - Static method in class org.hibernate.search.util.HibernateHelper
 
unRegisterMBean(String) - Static method in class org.hibernate.search.jmx.JMXRegistrar
Unregister the MBean with the specified name.
unwrap(Class<T>) - Method in interface org.hibernate.search.FullTextQuery
return the underlying type if possible or IllegalArgumentException otherwise Supported types are: - org.apache.lucene.search.Query the underlying lucene query
unwrap(Class<T>) - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
unwrap(Class<T>) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
unwrap(Class<T>) - Method in class org.hibernate.search.query.FullTextQueryImpl
 
UpdatableBackendQueueProcessorFactory - Interface in org.hibernate.search.backend
Allow a BackendQueueProcessorFactory to be notified of DirectoryProvider changes.
update(String, Object, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
update(Object, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
update(String, Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
update(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
updateDirectoryProviders(Set<DirectoryProvider<?>>, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.blackhole.BlackHoleBackendQueueProcessorFactory
 
updateDirectoryProviders(Set<DirectoryProvider<?>>, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
updateDirectoryProviders(Set<DirectoryProvider<?>>, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
updateDirectoryProviders(Set<DirectoryProvider<?>>, WorkerBuildContext) - Method in class org.hibernate.search.backend.impl.lucene.LuceneBackendQueueProcessorFactory
 
updateDirectoryProviders(Set<DirectoryProvider<?>>, WorkerBuildContext) - Method in interface org.hibernate.search.backend.UpdatableBackendQueueProcessorFactory
Update the list of DirectoryProviders in case the SearchFactory is updated.
Uri - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
UriBridge - Class in org.hibernate.search.bridge.builtin
Bridge for URI
UriBridge() - Constructor for class org.hibernate.search.bridge.builtin.UriBridge
 
Url - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
UrlBridge - Class in org.hibernate.search.bridge.builtin
Bridge for URLs.
UrlBridge() - Constructor for class org.hibernate.search.bridge.builtin.UrlBridge
 
usageCounter - Variable in class org.hibernate.search.reader.SharingBufferReaderProvider.ReaderUsagePair
When reaching 0 (always test on change) the reader should be really closed and then discarded.
used - Variable in class org.hibernate.search.event.FullTextIndexEventListener
 

V

valueOf(String) - Static method in enum org.hibernate.search.annotations.FilterCacheModeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.annotations.Index
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.annotations.Resolution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.annotations.Store
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.annotations.TermVector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.backend.configuration.IndexWriterSetting
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.backend.WorkType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata.Container
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.engine.EntityState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.event.FullTextIndexEventListener.Installation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.hibernate.search.query.TimeoutManager.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.hibernate.search.annotations.FilterCacheModeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.annotations.Index
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.annotations.Resolution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.annotations.Store
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.annotations.TermVector
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.backend.configuration.IndexWriterSetting
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
values() - Static method in enum org.hibernate.search.backend.WorkType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.engine.AbstractDocumentBuilder.PropertiesMetadata.Container
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.engine.EntityState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.event.FullTextIndexEventListener.Installation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.hibernate.search.query.TimeoutManager.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.hibernate.search.util.WeakIdentityHashMap
Returns a collection view of the values contained in this map.
Version - Class in org.hibernate.search
 
Version() - Constructor for class org.hibernate.search.Version
 
viewAccepted(View) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsMasterMessageListener
 

W

WeakIdentityHashMap<K,V> - Class in org.hibernate.search.util
A hashtable-based Map implementation with weak keys and using reference-equality in place of object-equality when comparing keys (and values).
WeakIdentityHashMap(int, float) - Constructor for class org.hibernate.search.util.WeakIdentityHashMap
Constructs a new, empty WeakIdentityHashMap with the given initial capacity and the given load factor.
WeakIdentityHashMap(int) - Constructor for class org.hibernate.search.util.WeakIdentityHashMap
Constructs a new, empty WeakIdentityHashMap with the given initial capacity and the default load factor, which is 0.75.
WeakIdentityHashMap() - Constructor for class org.hibernate.search.util.WeakIdentityHashMap
Constructs a new, empty WeakIdentityHashMap with the default initial capacity (16) and the default load factor (0.75).
WeakIdentityHashMap(Map) - Constructor for class org.hibernate.search.util.WeakIdentityHashMap
Constructs a new WeakIdentityHashMap with the same mappings as the specified Map.
wildcard() - Method in interface org.hibernate.search.query.dsl.TermContext
Treat the query as a wildcard: - ? represents any single character - * represents any character sequence For faster results, it is recommended that the query text does not start with ? or *
WildcardContext - Interface in org.hibernate.search.query.dsl
 
withConstantScore() - Method in class org.hibernate.search.query.dsl.impl.ConnectedAllContext
 
withConstantScore() - Method in interface org.hibernate.search.query.dsl.QueryCustomization
All results matching the query have a constant score equals to the boost FIXME is that true?
withPrefixLength(int) - Method in interface org.hibernate.search.query.dsl.FuzzyContext
Size of the prefix ignored by the fuzzyness.
withPrefixLength(int) - Method in interface org.hibernate.search.query.dsl.TermFuzzy
Size of the prefix ignored by the fuzzyness.
withSlop(int) - Method in interface org.hibernate.search.query.dsl.PhraseContext
Sets the number of other words permitted between words in query phrase.
withThreshold(float) - Method in interface org.hibernate.search.query.dsl.FuzzyContext
Threshold above which two terms are considered similar enough.
withThreshold(float) - Method in interface org.hibernate.search.query.dsl.TermFuzzy
Threshold above which two terms are considered similar enough.
Work<T> - Class in org.hibernate.search.backend
A unit of work.
Work(T, Serializable, WorkType) - Constructor for class org.hibernate.search.backend.Work
 
Work(Class<T>, Serializable, WorkType) - Constructor for class org.hibernate.search.backend.Work
 
Work(T, XMember, WorkType) - Constructor for class org.hibernate.search.backend.Work
 
workCompleted(LuceneWork) - Method in class org.hibernate.search.exception.impl.ErrorContextBuilder
 
Worker - Interface in org.hibernate.search.backend
Perform work for a given context (eg a transaction).
WORKER_BACKEND - Static variable in class org.hibernate.search.Environment
 
WORKER_BATCHSIZE - Static variable in class org.hibernate.search.Environment
Defines the maximum number of indexing operation batched per transaction
WORKER_EXECUTION - Static variable in class org.hibernate.search.Environment
 
WORKER_PREFIX - Static variable in class org.hibernate.search.Environment
 
WORKER_SCOPE - Static variable in class org.hibernate.search.Environment
 
WORKER_THREADPOOL_SIZE - Static variable in class org.hibernate.search.Environment
only used then execution is async Thread pool size default 1
WORKER_WORKQUEUE_SIZE - Static variable in class org.hibernate.search.Environment
Size of the buffer queue (besides the thread pool size) only used then execution is async default infinite
WorkerBuildContext - Interface in org.hibernate.search.spi
Build context for the worker and other backend Available after all index, entity metadata are built.
WorkerFactory - Class in org.hibernate.search.backend
 
WorkerFactory() - Constructor for class org.hibernate.search.backend.WorkerFactory
 
WorkPlan - Class in org.hibernate.search.engine
Represents the set of changes going to be applied to the index for the entities.
WorkPlan(SearchFactoryImplementor) - Constructor for class org.hibernate.search.engine.WorkPlan
 
WorkQueue - Class in org.hibernate.search.backend
 
WorkQueue(SearchFactoryImplementor) - Constructor for class org.hibernate.search.backend.WorkQueue
 
WorkQueue(SearchFactoryImplementor, WorkPlan) - Constructor for class org.hibernate.search.backend.WorkQueue
 
Workspace - Class in org.hibernate.search.backend
Lucene workspace for a DirectoryProvider.

Before using Workspace.getIndexWriter(boolean, org.hibernate.search.exception.impl.ErrorContextBuilder) the lock must be acquired, and resources must be closed before releasing the lock.

Workspace(WorkerBuildContext, DirectoryProvider<?>, ErrorHandler) - Constructor for class org.hibernate.search.backend.Workspace
 
WorkType - Enum in org.hibernate.search.backend
Enumeration of the different types of Lucene work.
WorkVisitor<T> - Interface in org.hibernate.search.backend
A visitor delegate to manipulate a LuceneWork needs to implement this interface.
wrapLockException(HibernateException, LockOptions) - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
WritableBuildContext - Interface in org.hibernate.search.spi
Build context where new built element can be registered.

X

XMLHelper - Class in org.hibernate.search.util
A utility class to help with xml parsing
XMLHelper() - Constructor for class org.hibernate.search.util.XMLHelper
 

A B C D E F G H I J K L M N O P Q R S T U V W X

Copyright © 2006-2010 Red Hat Middleware, LLC. All Rights Reserved