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

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
 
AbstractTermQueryBuilder - Class in org.hibernate.search.query.dsl
Abstract class that can be used to store state and any information that all the various TermQueryBuilder types might need.
AbstractTermQueryBuilder() - Constructor for class org.hibernate.search.query.dsl.AbstractTermQueryBuilder
 
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
 
add(Query) - Method in class org.hibernate.search.query.dsl.BooleanContext
 
add(Query) - Method in class org.hibernate.search.query.dsl.NegatableBooleanContext
 
addAllWorkThatFailed(List<LuceneWork>) - Method in class org.hibernate.search.exception.impl.ErrorContextBuilder
 
addAnalyzerDef(AnalyzerDef) - Method in class org.hibernate.search.impl.InitContext
 
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
 
addClassBridgeDef(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
addClassToDirectoryProvider(Class<?>, DirectoryProvider<?>, boolean) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
addClassToDirectoryProvider(Class<?>, DirectoryProvider<?>, boolean) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
addDirectoryProvider(DirectoryProvider<?>, boolean) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
addDirectoryProvider(DirectoryProvider<?>, boolean) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
addField(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
addFieldToDocument(String, String, Document) - Method in interface org.hibernate.search.bridge.LuceneOptions
 
addFilter(Filter) - Method in class org.hibernate.search.filter.ChainedFilter
 
addFulltextFilterDef(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
addIndexingParameters(DirectoryProvider<?>, LuceneIndexingParameters) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
addIndexingParameters(DirectoryProvider<?>, LuceneIndexingParameters) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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
 
addOptimizerStrategy(DirectoryProvider<?>, OptimizerStrategy) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
addOptimizerStrategy(DirectoryProvider<?>, OptimizerStrategy) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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.
addTerm(Term) - Method in class org.hibernate.search.query.dsl.TermQueryBuilderDataStore
 
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
 
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
addWorkToDpProcessor(DirectoryProvider<?>, LuceneWork) - Method in interface org.hibernate.search.backend.impl.lucene.PerDirectoryWorkProcessor
 
addWorkToQueue(Class<T>, T, Serializable, WorkType, List<LuceneWork>, SearchFactoryImplementor) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
addWorkToQueue(Class<T>, T, Serializable, WorkType, List<LuceneWork>, SearchFactoryImplementor) - 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.v2.impl.ConnectedQueryBuilder
 
all() - Method in interface org.hibernate.search.query.dsl.v2.QueryBuilder
Query matching all documents Typically mixed with a boolean query.
AllContext - Interface in org.hibernate.search.query.dsl.v2
 
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.DocumentBuilderContainedEntity
 
analyzer - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.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
 
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.v2.impl.ConnectedTermMatchingContext
 
andField(String) - Method in interface org.hibernate.search.query.dsl.v2.TermMatchingContext
field / property the term query is executed on
appendFailureMessage(StringBuilder, LuceneWork) - Static method in class org.hibernate.search.exception.impl.LogErrorHandler
 
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
Implementors 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(SearchFactoryImplementor, 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.
beanClass - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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
 
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.v2.impl.ConnectedQueryBuilder
 
bool() - Method in interface org.hibernate.search.query.dsl.v2.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
 
BooleanContext - Class in org.hibernate.search.query.dsl
Class that allows users to create BooleanQueries.
BooleanContext(BooleanClause.Occur) - Constructor for class org.hibernate.search.query.dsl.BooleanContext
 
BooleanJunction<T extends BooleanJunction> - Interface in org.hibernate.search.query.dsl.v2
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.DocumentBuilderContainedEntity.PropertiesMetadata
 
BOOST - Static variable in interface org.hibernate.search.ProjectionConstants
Deprecated. always return 1
boostedTo(float) - Method in interface org.hibernate.search.query.dsl.v2.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.v2.impl.ConnectedAllContext
 
boostedTo(float) - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedTermMatchingContext
 
boostedTo(float) - Method in interface org.hibernate.search.query.dsl.v2.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
 
BridgeFactory - Class in org.hibernate.search.bridge
This factory is responsible for creating and initializing build-in and custom FieldBridges.
build() - Method in class org.hibernate.search.query.dsl.BuildableTermQueryBuilder
 
BuildableTermQueryBuilder - Class in org.hibernate.search.query.dsl
Class that will allow the user to actually build his query.
BuildableTermQueryBuilder(TermQueryBuilderDataStore) - Constructor for class org.hibernate.search.query.dsl.BuildableTermQueryBuilder
 
buildLazyAnalyzer(String) - Method in class org.hibernate.search.impl.InitContext
 
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.SearchFactoryImpl
 
buildQueryBuilder() - Method in interface org.hibernate.search.SearchFactory
Return a query builder providing a fluent API to create Lucene queries

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, DocumentBuilderContainedEntity.PropertiesMetadata, boolean, String, InitContext) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
checkDocumentId(XProperty, DocumentBuilderContainedEntity.PropertiesMetadata, boolean, String, InitContext) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
checkHasValidconstructor(Class<?>, String) - Static method in class org.hibernate.search.util.PluginLoader
Verifies if target class has a no-args constructor, and that it is accessible in current security manager.
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.DocumentBuilderContainedEntity.PropertiesMetadata
 
classBoostStrategy - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.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.DocumentBuilderContainedEntity.PropertiesMetadata
 
classIndexes - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
classNames - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
classStores - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
classTermVectors - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
CLAZZ - Static variable in class org.hibernate.search.bridge.BridgeFactory
 
clazz - Variable in class org.hibernate.search.engine.EntityInfo
 
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.impl.FullTextSessionImpl
 
clear() - Method in class org.hibernate.search.jpa.impl.FullTextEntityManagerImpl
 
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 interface org.hibernate.search.engine.SearchFactoryImplementor
 
close() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
close() - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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.
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() - Method in class org.hibernate.search.backend.Workspace
Commits changes to a previously opened IndexWriter.
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
 
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.v2.impl
 
ConnectedAllContext() - Constructor for class org.hibernate.search.query.dsl.v2.impl.ConnectedAllContext
 
ConnectedMultiFieldsTermQueryBuilder - Class in org.hibernate.search.query.dsl.v2.impl
 
ConnectedMultiFieldsTermQueryBuilder(QueryContext, String, List<FieldContext>, QueryCustomizer, Analyzer, SearchFactory) - Constructor for class org.hibernate.search.query.dsl.v2.impl.ConnectedMultiFieldsTermQueryBuilder
 
ConnectedQueryBuilder - Class in org.hibernate.search.query.dsl.v2.impl
Assuming connection with the search factory
ConnectedQueryBuilder(Analyzer, SearchFactory) - Constructor for class org.hibernate.search.query.dsl.v2.impl.ConnectedQueryBuilder
 
ConnectedQueryContextBuilder - Class in org.hibernate.search.query.dsl.v2.impl
Assuming connection with the search factory
ConnectedQueryContextBuilder(SearchFactory) - Constructor for class org.hibernate.search.query.dsl.v2.impl.ConnectedQueryContextBuilder
 
ConnectedQueryContextBuilder.HSearchEntityContext - Class in org.hibernate.search.query.dsl.v2.impl
 
ConnectedQueryContextBuilder.HSearchEntityContext(Class<?>, SearchFactory) - Constructor for class org.hibernate.search.query.dsl.v2.impl.ConnectedQueryContextBuilder.HSearchEntityContext
 
ConnectedTermMatchingContext - Class in org.hibernate.search.query.dsl.v2.impl
 
ConnectedTermMatchingContext(QueryContext, String, QueryCustomizer, Analyzer, SearchFactory) - Constructor for class org.hibernate.search.query.dsl.v2.impl.ConnectedTermMatchingContext
 
ConnectedTermMatchingContext(QueryContext, String[], QueryCustomizer, Analyzer, SearchFactory) - Constructor for class org.hibernate.search.query.dsl.v2.impl.ConnectedTermMatchingContext
 
connection() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
constantScore() - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedAllContext
 
constantScore() - Method in interface org.hibernate.search.query.dsl.v2.QueryCustomization
All results matching the query have a constant score equals to the boost FIXME is that true?
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.DocumentBuilderContainedEntity.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.  
ContextHolder - Class in org.hibernate.search.event
Holds already built SearchFactory per Hibernate Configuration object concurrent threads do not share this information This code uses ThreadLocal and despite the weak hashMap use, some users claim to see memory leaks (in Tomcat as usual).
ContextHolder() - Constructor for class org.hibernate.search.event.ContextHolder
 
COPYBUFFERSIZE_PROP_NAME - Static variable in class org.hibernate.search.store.DirectoryProviderHelper
 
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, SearchFactoryImplementor, ReflectionManager) - Method in class org.hibernate.search.store.DirectoryProviderFactory
 
createErrorContext() - Method in class org.hibernate.search.exception.impl.ErrorContextBuilder
 
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
 
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.BooleanContext
 
createQuery() - Method in class org.hibernate.search.query.dsl.NegatableBooleanContext
 
createQuery() - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedAllContext
 
createQuery() - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedMultiFieldsTermQueryBuilder
 
createQuery(FieldContext) - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedMultiFieldsTermQueryBuilder
 
createQuery() - Method in interface org.hibernate.search.query.dsl.v2.Termination
Return the lucene query representing the operation
createReaderProvider(SearchConfiguration, SearchFactoryImplementor) - 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, SearchFactoryImplementor) - Static method in class org.hibernate.search.backend.WorkerFactory
 
current - Variable in class org.hibernate.search.reader.SharingBufferReaderProvider.PerDirectoryLatestReader
Reference to the most current IndexReader for a DirectoryProvider; guarded by lockOnReplaceCurrent;
currentReaders - Variable in class org.hibernate.search.reader.SharingBufferReaderProvider
contains last updated Reader; protected by lockOnOpenLatest (in the values)

D

dataStore - Variable in class org.hibernate.search.query.dsl.AbstractTermQueryBuilder
 
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_SIZE - Static variable in class org.hibernate.search.filter.CachingWrapperFilter
 
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 delegated Analyzers are lazily configured
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 org.apache.lucene.store.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.
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[]) - Constructor for class org.hibernate.search.store.DirectoryProviderFactory.DirectoryProviders
 
DirectoryProviderHelper - Class in org.hibernate.search.store
 
DirectoryProviderHelper() - Constructor for class org.hibernate.search.store.DirectoryProviderHelper
 
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.DocumentBuilderContainedEntity.PropertiesMetadata
 
discriminatorGetter - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
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 Experimental: If you use this feature, please speak up in the forum

Expert: Lucene document id can change overtime between 2 different IndexReader opening.

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, InitContext, ReflectionManager) - Constructor for class org.hibernate.search.engine.DocumentBuilderContainedEntity
Constructor used on contained entities not annotated with @Indexed themselves.
DocumentBuilderContainedEntity.PropertiesMetadata - Class in org.hibernate.search.engine
Wrapper class containing all the meta data extracted out of a single entity.
DocumentBuilderContainedEntity.PropertiesMetadata() - Constructor for class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
DocumentBuilderContainedEntity.PropertiesMetadata.Container - Enum 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, InitContext, DirectoryProvider[], IndexShardingStrategy, 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
 
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
 
DOUBLE - 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
 
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.DocumentBuilderContainedEntity.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.DocumentBuilderContainedEntity.PropertiesMetadata
 
embeddedGetters - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
embeddedPropertiesMetadata - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.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
 
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.v2
 
EntityDescriptor - Class in org.hibernate.search.cfg
 
EntityDescriptor(Class<?>) - Constructor for class org.hibernate.search.cfg.EntityDescriptor
 
EntityInfo - Class in org.hibernate.search.engine
 
EntityInfo(Class, 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 - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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(Class<? extends Enum>) - Constructor for class org.hibernate.search.bridge.builtin.EnumBridge
 
Environment - Class in org.hibernate.search
 
Environment() - Constructor for class org.hibernate.search.Environment
 
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
 
exact() - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedQueryBuilder
 
exact() - Method in interface org.hibernate.search.query.dsl.v2.QueryBuilder
build a term query
except(Query...) - Method in interface org.hibernate.search.query.dsl.v2.AllContext
Exclude the documents matching these queries
except(Query...) - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedAllContext
 
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.
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) - Static method in class org.hibernate.search.bridge.BridgeFactory
Takes in a fieldBridge and will return you a TwoWayFieldBridge instance.
extractType(ClassBridge) - Static method in class org.hibernate.search.bridge.BridgeFactory
This extracts and instantiates the implementation class from a ClassBridge annotation.
extractType(FieldBridge) - 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
Mark 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.DocumentBuilderContainedEntity.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.DocumentBuilderContainedEntity.PropertiesMetadata
 
FieldContext - Class in org.hibernate.search.query.dsl.v2.impl
 
FieldContext(String) - Constructor for class org.hibernate.search.query.dsl.v2.impl.FieldContext
 
FieldCustomization<T> - Interface in org.hibernate.search.query.dsl.v2
 
fieldGetters - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
fieldIndex - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
FieldMapping - Class in org.hibernate.search.cfg
 
FieldMapping(PropertyDescriptor, EntityDescriptor, SearchMapping) - Constructor for class org.hibernate.search.cfg.FieldMapping
 
fieldNames - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.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.DocumentBuilderContainedEntity.PropertiesMetadata
 
fieldTermVectors - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity.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(Filter) - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedAllContext
 
filter(Filter) - Method in interface org.hibernate.search.query.dsl.v2.QueryCustomization
Filter the query results with the Filter instance
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
 
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
 
FloatBridge - Class in org.hibernate.search.bridge.builtin
Map a float element
FloatBridge() - Constructor for class org.hibernate.search.bridge.builtin.FloatBridge
 
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.
forEntity(Class<?>) - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedQueryContextBuilder
 
forEntity(Class<?>) - Method in interface org.hibernate.search.query.dsl.v2.QueryContextBuilder
 
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
 
FullTextIndexCollectionEventListener - Class in org.hibernate.search.event
Deprecated. As of release 3.1.0, replaced by FullTextIndexEventListener
FullTextIndexCollectionEventListener() - Constructor for class org.hibernate.search.event.FullTextIndexCollectionEventListener
Deprecated.  
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
 
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 class org.hibernate.search.query.dsl.v2.impl.ConnectedQueryBuilder
 
fuzzy() - Method in interface org.hibernate.search.query.dsl.v2.QueryBuilder
Use a fuzzy search approximation (aka edit distance)
FuzzyContext - Interface in org.hibernate.search.query.dsl.v2
 

G

get(Object) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
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(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.v2.EntityContext
return the query builder
get() - Method in class org.hibernate.search.query.dsl.v2.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.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(XAnnotatedElement, InitContext) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getAnalyzer(Analyzer, InitContext) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getAnalyzer() - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getAnalyzer(String) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getAnalyzer(Class<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getAnalyzer(String) - Method in interface org.hibernate.search.SearchFactory
Experimental API 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
 
getAnnotationReader(AnnotatedElement) - Method in class org.hibernate.search.impl.MappingModelMetadataProvider
 
getApproximation() - Method in class org.hibernate.search.query.dsl.v2.impl.QueryContext
 
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.SearchFactoryImpl
 
getBatcher() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getBatchIndexParameters() - Method in class org.hibernate.search.backend.LuceneIndexingParameters
 
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
Deprecated. likely to be removed in version 3.3, use #addFieldToDocument
getBoost() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getBoost(XProperty, Field) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getBoost(XClass) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getByte(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
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
getClassBoost(Object) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
getClassBridgeDefs() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getClassesInDirectoryProvider(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getClassesInDirectoryProvider(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getClassLuceneOptions(int) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity.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
 
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
 
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
 
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.InitContext
 
getDefaults() - Method in class org.hibernate.search.impl.MappingModelMetadataProvider
 
getDefaultSimilarity() - Method in class org.hibernate.search.impl.InitContext
 
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
 
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
 
getDirectoryProviderLock(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDirectoryProviderLock(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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.SearchFactoryImpl
 
getDirectoryProviders(Class<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getDirectoryProviders(Class<?>) - Method in interface org.hibernate.search.SearchFactory
Provide access to the DirectoryProviders (hence the Lucene Directories) for a given entity In most cases, the returned type will be a one element array.
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
 
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.SearchFactoryImpl
 
getDocumentBuilderIndexedEntity(Class<T>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDocumentBuilderIndexedEntity(Class<T>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getDocumentBuildersIndexedEntities() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getDocumentBuildersIndexedEntities() - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getDocumentClass(Document) - Static method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getDocumentFields(SearchFactoryImplementor, Class<?>, Document, String[]) - Static method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
getDocumentId() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getDocumentId(SearchFactoryImplementor, Class<?>, Document) - Static method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
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.DocumentBuilderContainedEntity
 
getDynamicBoost(XClass) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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.DocumentBuilderContainedEntity
 
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.SearchFactoryImpl
 
getFactory() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getFactoryMethod() - Method in class org.hibernate.search.engine.FilterDef
 
getFailingOperations() - Method in interface org.hibernate.search.exception.ErrorContext
 
getFetchProfile() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getField() - Method in class org.hibernate.search.query.dsl.v2.impl.FieldContext
 
getFieldCustomizer() - Method in class org.hibernate.search.query.dsl.v2.impl.FieldContext
 
getFieldLuceneOptions(int, Object) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity.PropertiesMetadata
 
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.SearchFactoryImpl
 
getFilterCachingStrategy() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getFilterCachingStrategy() - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getFilterDefinition(String) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getFilterDefinition(String) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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
 
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.DocumentBuilderIndexedEntity
Return the entity id if possible An IllegalStateException otherwise If the id is provided, we can't extract it from the entity
getIdAttributeName(XProperty, Annotation) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
Determines the property name for the document id.
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
 
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
Deprecated. likely to be removed in version 3.3, use #addFieldToDocument
getIndex(Index) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getIndexed() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getIndexedTypesPolymorphic(Class<?>[]) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getIndexedTypesPolymorphic(Class<?>[]) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getIndexEmbedded() - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
getIndexingParameters(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getIndexingParameters(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getIndexingStrategy() - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getIndexingStrategy() - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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) - Method in class org.hibernate.search.backend.Workspace
Gets the IndexWriter, opening one if needed.
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
 
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.InitContext
 
getLines(String) - Method in class org.hibernate.search.util.HibernateSearchResourceLoader
 
getListeners() - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
getLoadQueryInfluencers() - 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
getLuceneResolution(Resolution) - Static method in class org.hibernate.search.bridge.builtin.DateResolutionUtil
 
getMappedSubclasses() - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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
 
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
 
getOccur() - Method in class org.hibernate.search.query.dsl.BooleanContext
 
getOperationAtFault() - Method in interface org.hibernate.search.exception.ErrorContext
 
getOptimizerStrategy(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getOptimizerStrategy(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getOrBuildSearchFactory(Configuration) - Static method in class org.hibernate.search.event.ContextHolder
 
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
 
getPositionIncrementGap(String) - Method in class org.hibernate.search.util.DelegateNamedAnalyzer
 
getPositionIncrementGap(String) - Method in class org.hibernate.search.util.ScopedAnalyzer
 
getPrefixLength() - Method in class org.hibernate.search.query.dsl.v2.impl.QueryContext
 
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
returns the programmatic configuration or null //TODO remove hard dep with solr classes
getProgrammaticMapping() - Method in class org.hibernate.search.cfg.SearchConfigurationFromHibernateCore
 
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.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
 
getPropertyDescriptor(String, ElementType) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getProvidedId() - Method in class org.hibernate.search.cfg.EntityDescriptor
 
getProviders() - Method in class org.hibernate.search.store.DirectoryProviderFactory.DirectoryProviders
 
getQueue() - Method in class org.hibernate.search.backend.WorkQueue
 
getReaderProvider() - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getReaderProvider() - Method in interface org.hibernate.search.SearchFactory
Provide the configured readerProvider strategy, hence access to a Lucene IndexReader
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
 
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
 
getSelectionStrategy() - Method in class org.hibernate.search.store.DirectoryProviderFactory.DirectoryProviders
 
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.DocumentBuilderContainedEntity
 
getSimilarity(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
getSimilarity(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
getSingleResult() - Method in class org.hibernate.search.jpa.impl.FullTextQueryImpl
 
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
 
getStatusMessagePeriod() - Method in class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
getStore() - Method in interface org.hibernate.search.bridge.LuceneOptions
Deprecated. use addToDocument to add fields to the Document if possible
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
 
getTerms() - Method in class org.hibernate.search.query.dsl.TermQueryBuilderDataStore
 
getTermVector() - Method in interface org.hibernate.search.bridge.LuceneOptions
Deprecated. likely to be removed in version 3.3, use #addFieldToDocument
getTermVector(TermVector) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
getText(int) - Method in class org.hibernate.search.query.ScrollableResultsImpl
This method is not supported on Lucene based queries
getThreshold() - Method in class org.hibernate.search.query.dsl.v2.impl.QueryContext
 
getThrowable() - Method in interface org.hibernate.search.exception.ErrorContext
 
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
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
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 interface org.hibernate.search.engine.SearchFactoryImplementor
 
getWorker() - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
guessEntityName(Object) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
guessType(Field, 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
 
hasErrors() - Method in interface org.hibernate.search.exception.ErrorContext
 
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
 
HibernateSearchResourceLoader - Class in org.hibernate.search.util
 
HibernateSearchResourceLoader() - Constructor for class org.hibernate.search.util.HibernateSearchResourceLoader
 

I

id - Variable in class org.hibernate.search.engine.EntityInfo
 
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
 
idGetter - Variable in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
The class member used as document id.
IdHashShardingStrategy - Class in org.hibernate.search.store
This implementation use idInString as the hashKey.
IdHashShardingStrategy() - Constructor for class org.hibernate.search.store.IdHashShardingStrategy
 
idKeywordName - Variable in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
Name of the document id field.
ignoreAnalyzer() - Method in interface org.hibernate.search.query.dsl.v2.FieldCustomization
Advanced Do not execute the analyzer on the text.
ignoreAnalyzer() - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedTermMatchingContext
 
immediateLoad(String, Serializable) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
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
 
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(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.
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
 
IndexedMapping - Class in org.hibernate.search.cfg
 
IndexedMapping(SearchMapping, EntityDescriptor, EntityMapping) - Constructor for class org.hibernate.search.cfg.IndexedMapping
 
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_STRATEGY - Static variable in class org.hibernate.search.Environment
Defines the indexing strategy, default event Other options manual
indexName(String) - Method in class org.hibernate.search.cfg.IndexedMapping
 
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(XClass, InitContext) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
init(XClass, InitContext) - Method in class org.hibernate.search.engine.DocumentBuilderIndexedEntity
 
init(Session, SearchFactoryImplementor) - Method in interface org.hibernate.search.engine.Loader
 
init(Session, SearchFactoryImplementor) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
init(Session, SearchFactoryImplementor) - Method in class org.hibernate.search.engine.ObjectLoader
 
init(Session, SearchFactoryImplementor) - Method in class org.hibernate.search.engine.ProjectionLoader
 
init(Session, SearchFactoryImplementor, ResultTransformer, String[]) - Method in class org.hibernate.search.engine.ProjectionLoader
 
init(Session, SearchFactoryImplementor) - Method in class org.hibernate.search.engine.QueryLoader
 
InitContext - 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.
InitContext(SearchConfiguration) - Constructor for class org.hibernate.search.impl.InitContext
 
initialize(Properties, SearchFactoryImplementor) - Method in interface org.hibernate.search.backend.BackendQueueProcessorFactory
Used at startup, called once as first method.
initialize(Properties, MassIndexerProgressMonitor, SearchFactoryImplementor) - Method in interface org.hibernate.search.backend.impl.batchlucene.BatchBackend
Used at startup, called once as first method.
initialize(Properties, MassIndexerProgressMonitor, SearchFactoryImplementor) - Method in class org.hibernate.search.backend.impl.batchlucene.LuceneBatchBackend
 
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.backend.impl.blackhole.BlackHoleBackendQueueProcessorFactory
 
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.backend.impl.jgroups.MasterJGroupsBackendQueueProcessorFactory
 
initialize() - Method in class org.hibernate.search.backend.impl.jms.AbstractJMSHibernateSearchController
 
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.backend.impl.lucene.LuceneBackendQueueProcessorFactory
 
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.backend.impl.TransactionalWorker
 
initialize(Properties, SearchFactoryImplementor) - 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, SearchFactoryImplementor) - Method in class org.hibernate.search.reader.NotSharedReaderProvider
 
initialize(Properties, SearchFactoryImplementor) - Method in interface org.hibernate.search.reader.ReaderProvider
Inialize the reader provider before its use.
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.reader.SharedReaderProvider
Deprecated.  
initialize(Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.reader.SharingBufferReaderProvider
 
initialize(String, Properties, SearchFactoryImplementor) - Method in interface org.hibernate.search.store.DirectoryProvider
get the information to initialize the directory and build its hashCode/equals method
initialize(String, Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.store.FSDirectoryProvider
 
initialize(String, Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.store.FSMasterDirectoryProvider
 
initialize(String, Properties, SearchFactoryImplementor) - 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, SearchFactoryImplementor) - Method in class org.hibernate.search.store.optimization.IncrementalOptimizerStrategy
 
initialize(DirectoryProvider, Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.store.optimization.NoOpOptimizerStrategy
 
initialize(DirectoryProvider, Properties, SearchFactoryImplementor) - Method in interface org.hibernate.search.store.optimization.OptimizerStrategy
 
initialize(String, Properties, SearchFactoryImplementor) - Method in class org.hibernate.search.store.RAMDirectoryProvider
 
initializeCollection(PersistentCollection, boolean) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
initializeMemberLevelAnnotations(XProperty, DocumentBuilderContainedEntity.PropertiesMetadata, boolean, String, Set<XClass>, InitContext) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
initializeObjects(EntityInfo[], Criteria, Class<?>, SearchFactoryImplementor) - Static method in class org.hibernate.search.engine.ObjectLoaderHelper
 
initLazyAnalyzers() - Method in class org.hibernate.search.impl.InitContext
 
instanceFromClass(Class<T>, Class<?>, String) - Static method in class org.hibernate.search.util.PluginLoader
Creates an instance of target class
instanceFromName(Class<T>, String, Class<?>, String) - Static method in class org.hibernate.search.util.PluginLoader
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
 
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
 
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
 
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
 
isExclusiveIndexUsageEnabled(DirectoryProvider<?>) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
isExclusiveIndexUsageEnabled(DirectoryProvider<?>) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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.v2.impl.FieldContext
 
isJpaPresent() - Method in class org.hibernate.search.impl.InitContext
 
isLast() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
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 - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
isRoot() - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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
 
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.

L

last() - Method in class org.hibernate.search.query.ScrollableResultsImpl
 
level - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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 interface org.hibernate.search.engine.Loader
 
load(EntityInfo...) - Method in interface org.hibernate.search.engine.Loader
 
load(EntityInfo) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
load(EntityInfo...) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
load(EntityInfo) - Method in class org.hibernate.search.engine.ObjectLoader
 
load(EntityInfo...) - Method in class org.hibernate.search.engine.ObjectLoader
 
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(EntityInfo) - Method in class org.hibernate.search.engine.QueryLoader
 
load(EntityInfo...) - Method in class org.hibernate.search.engine.QueryLoader
 
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
 
LoaderHelper() - Constructor for class org.hibernate.search.engine.LoaderHelper
 
loadFromXML(InputStream) - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
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
 
LongBridge - Class in org.hibernate.search.bridge.builtin
Map a long element
LongBridge() - Constructor for class org.hibernate.search.bridge.builtin.LongBridge
 
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
First EXPERIMENTAL BatchBackend; 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 wrapper class for Lucene parameters needed for indexing.
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) - 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.SearchFactoryImpl
 
mappedSubclasses - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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
 
matches(String) - Method in class org.hibernate.search.query.dsl.UnbuildableTermQueryBuilderOnSearch
 
matching(String) - Method in class org.hibernate.search.query.dsl.v2.impl.ConnectedTermMatchingContext
 
matching(String) - Method in interface org.hibernate.search.query.dsl.v2.TermMatchingContext
text searched in the term query (the term is pre-analyzer unless ignoreAnalyzer is called)
maxLevel - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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.
metadata - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
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
 
MultiClassesQueryLoader() - Constructor for class org.hibernate.search.engine.MultiClassesQueryLoader
 
must() - Method in class org.hibernate.search.query.dsl.SealedQueryBuilder
 
must(Query) - Method in interface org.hibernate.search.query.dsl.v2.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.v2
Represents the context in which a must clause is described.

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
NegatableBooleanContext - Class in org.hibernate.search.query.dsl
// TODO: Document this
NegatableBooleanContext(BooleanClause.Occur) - Constructor for class org.hibernate.search.query.dsl.NegatableBooleanContext
 
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 class org.hibernate.search.query.dsl.NegatableBooleanContext
 
not() - Method in interface org.hibernate.search.query.dsl.v2.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
 
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
 

O

OBJECT_CLASS - Static variable in interface org.hibernate.search.ProjectionConstants
Represents the Hibernate entity class returned in a search.
ObjectLoader - Class in org.hibernate.search.engine
 
ObjectLoader() - Constructor for class org.hibernate.search.engine.ObjectLoader
 
ObjectLoaderHelper - Class in org.hibernate.search.engine
 
ObjectLoaderHelper() - Constructor for class org.hibernate.search.engine.ObjectLoaderHelper
 
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.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 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.cfg.ConcatStringBridge
 
on(String) - Method in class org.hibernate.search.query.dsl.BuildableTermQueryBuilder
 
on(String) - Method in class org.hibernate.search.query.dsl.UnbuildableTermQueryBuilderOnField
 
onField(String) - Method in interface org.hibernate.search.query.dsl.v2.FuzzyContext
field / property the term query is executed on
onField(String) - Method in interface org.hibernate.search.query.dsl.v2.TermContext
field / property the term query is executed on
onField(String) - Method in interface org.hibernate.search.query.dsl.v2.WildcardContext
field / property the term query is executed on
onFields(String...) - Method in interface org.hibernate.search.query.dsl.v2.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.FullTextIndexCollectionEventListener
Deprecated. As of release 3.1.0, replaced by FullTextIndexEventListener.onPostRecreateCollection(PostCollectionRecreateEvent)
onPostRecreateCollection(PostCollectionRecreateEvent) - Method in class org.hibernate.search.event.FullTextIndexEventListener
 
onPostRemoveCollection(PostCollectionRemoveEvent) - Method in class org.hibernate.search.event.FullTextIndexCollectionEventListener
Deprecated. As of release 3.1.0, replaced by FullTextIndexEventListener.onPostRemoveCollection(PostCollectionRemoveEvent)
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.FullTextIndexCollectionEventListener
Deprecated. As of release 3.1.0, replaced by FullTextIndexEventListener.onPostUpdateCollection(PostCollectionUpdateEvent)
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.SearchFactoryImpl
 
optimize(Class) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
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
 
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.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.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.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
This package contains various experimentations.
org.hibernate.search.query.dsl.v2 - package org.hibernate.search.query.dsl.v2
 
org.hibernate.search.query.dsl.v2.impl - package org.hibernate.search.query.dsl.v2.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.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.v2.EntityContext
 
overridesForField(String, String) - Method in class org.hibernate.search.query.dsl.v2.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.
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
 
PluginLoader - 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.
PluginLoader() - Constructor for class org.hibernate.search.util.PluginLoader
 
postInitialize(Set<Class<?>>) - Method in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
PostTransactionWorkQueueSynchronization - Class in org.hibernate.search.backend.impl
Execute some work inside a transaction synchronization
PostTransactionWorkQueueSynchronization(QueueingProcessor, WeakIdentityHashMap) - Constructor for class org.hibernate.search.backend.impl.PostTransactionWorkQueueSynchronization
in transaction work
prefix(String) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
prefixLength(int) - Method in interface org.hibernate.search.query.dsl.v2.FuzzyContext
Size of the prefix ignored by the fuzzyness.
prefixLength(int) - Method in interface org.hibernate.search.query.dsl.v2.TermFuzzy
Size of the prefix ignored by the fuzzyness.
preparedQuery - Variable in class org.hibernate.search.query.QueryHits
 
prepareJMSTools() - Method in class org.hibernate.search.backend.impl.jms.JMSBackendQueueProcessorFactory
 
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
 
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
 
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(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.
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(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.v2
 
QueryContext - Class in org.hibernate.search.query.dsl.v2.impl
 
QueryContext(QueryContext.Approximation) - Constructor for class org.hibernate.search.query.dsl.v2.impl.QueryContext
 
QueryContext.Approximation - Enum in org.hibernate.search.query.dsl.v2.impl
 
QueryContextBuilder - Interface in org.hibernate.search.query.dsl.v2
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.v2
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(Searcher, Query, Filter, Sort) - Constructor for class org.hibernate.search.query.QueryHits
 
QueryHits(Searcher, Query, Filter, Sort, Integer) - 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

RAMDirectoryProvider - Class in org.hibernate.search.store
Use a Lucene RAMDirectory
RAMDirectoryProvider() - Constructor for class org.hibernate.search.store.RAMDirectoryProvider
 
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.DocumentBuilderContainedEntity
 
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.
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.
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.
removeSearchFactoryFromCache(SearchFactoryImplementor) - Static method in class org.hibernate.search.event.ContextHolder
 
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
 
Resolution - Enum in org.hibernate.search.annotations
Date indexing resolution.
RESOLUTION_PARAMETER - Static variable in class org.hibernate.search.bridge.builtin.CalendarBridge
 
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() - Method in class org.hibernate.search.batchindexing.EntityConsumerLuceneworkProducer
 
run() - Method in class org.hibernate.search.batchindexing.IdentifierConsumerEntityProducer
 
run() - Method in class org.hibernate.search.batchindexing.IdentifierProducer
 

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
 
SealedQueryBuilder - Class in org.hibernate.search.query.dsl
Starting class that will allow users to build their queries using the DSL.
SealedQueryBuilder() - Constructor for class org.hibernate.search.query.dsl.SealedQueryBuilder
 
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
 
searchFactory - Variable in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
SearchFactory - Interface in org.hibernate.search
Provide application wide operations as well as access to the underlying Lucene resources.
SearchFactoryImpl - Class in org.hibernate.search.impl
 
SearchFactoryImpl(SearchConfiguration) - Constructor for class org.hibernate.search.impl.SearchFactoryImpl
 
SearchFactoryImplementor - Interface in org.hibernate.search.engine
Interface which gives access to the different directory providers and their configuration.
searchFactoryImplementor - Variable in class org.hibernate.search.event.FullTextIndexEventListener
 
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
 
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.String2FieldBridgeAdaptor
 
setAccessible(XMember) - Static method in class org.hibernate.search.util.ReflectionHelper
 
setAnalyzerDiscriminator(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setAnalyzerDiscriminator(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setAutoClear(boolean) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setBackendQueueProcessorFactory(BackendQueueProcessorFactory) - Method in interface org.hibernate.search.engine.SearchFactoryImplementor
 
setBackendQueueProcessorFactory(BackendQueueProcessorFactory) - Method in class org.hibernate.search.impl.SearchFactoryImpl
 
setBoost(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
setCacheMode(CacheMode) - Method in class org.hibernate.search.impl.FullTextSessionImpl
 
setCalendarBridge(Map<String, Object>) - Method in class org.hibernate.search.cfg.PropertyDescriptor
 
setClusterName(String) - Method in class org.hibernate.search.backend.impl.jgroups.JGroupsBackendQueueProcessorFactory
 
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(Analyzer) - Method in class org.hibernate.search.util.DelegateNamedAnalyzer
 
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
 
setEntityType(Class) - Method in class org.hibernate.search.engine.QueryLoader
 
setEntityTypes(Set<Class<?>>) - Method in class org.hibernate.search.engine.MultiClassesQueryLoader
 
setEntityTypes(Set<Class<?>>) - Method in class org.hibernate.search.engine.ProjectionLoader
 
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
 
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.
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
 
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.v2.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
 
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
 
setOccur(BooleanClause.Occur) - Method in class org.hibernate.search.query.dsl.BooleanContext
 
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
 
setPrefixLength(int) - Method in class org.hibernate.search.query.dsl.v2.impl.QueryContext
 
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
 
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
 
setSealedQueue(List<LuceneWork>) - Method in class org.hibernate.search.backend.WorkQueue
 
setSimilariy(Map<String, Object>) - Method in class org.hibernate.search.cfg.EntityDescriptor
 
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
 
setThreshold(float) - Method in class org.hibernate.search.query.dsl.v2.impl.QueryContext
 
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() - Method in class org.hibernate.search.query.dsl.SealedQueryBuilder
 
should(Query) - Method in interface org.hibernate.search.query.dsl.v2.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 - Variable in class org.hibernate.search.engine.DocumentBuilderContainedEntity
 
SIMILARITY_CLASS - Static variable in class org.hibernate.search.Environment
Default Lucene similarity
SimpleIndexingProgressMonitor - Class in org.hibernate.search.impl
A very simple implementation of MassIndexerProgressMonitor
SimpleIndexingProgressMonitor() - Constructor for class org.hibernate.search.impl.SimpleIndexingProgressMonitor
 
size() - Method in class org.hibernate.search.backend.configuration.MaskedProperty
 
size() - Method in class org.hibernate.search.backend.WorkQueue
 
SIZE - Static variable in class org.hibernate.search.cfg.ConcatStringBridge
 
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
 
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() - 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
 
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
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.
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.
targetElement(Class<?>) - Method in class org.hibernate.search.cfg.IndexEmbeddedMapping
 
term() - Method in class org.hibernate.search.query.dsl.SealedQueryBuilder
 
TermContext - Interface in org.hibernate.search.query.dsl.v2
 
TermFuzzy - Interface in org.hibernate.search.query.dsl.v2
 
Termination<T> - Interface in org.hibernate.search.query.dsl.v2
 
TermMatchingContext - Interface in org.hibernate.search.query.dsl.v2
 
TermQueryBuilderDataStore - Class in org.hibernate.search.query.dsl
This class will just store the required terms.
TermQueryBuilderDataStore() - Constructor for class org.hibernate.search.query.dsl.TermQueryBuilderDataStore
 
TermTermination - Interface in org.hibernate.search.query.dsl.v2
 
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.
threshold(float) - Method in interface org.hibernate.search.query.dsl.v2.FuzzyContext
Threshold above which two terms are considered similar enough.
threshold(float) - Method in interface org.hibernate.search.query.dsl.v2.TermFuzzy
Threshold above which two terms are considered similar enough.
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.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.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

UnbuildableTermQueryBuilderOnField - Class in org.hibernate.search.query.dsl
Class that exposes only the on(String field) method as this class will only be returned to a user when SealedQueryBuilder.term() is called.
UnbuildableTermQueryBuilderOnField() - Constructor for class org.hibernate.search.query.dsl.UnbuildableTermQueryBuilderOnField
 
UnbuildableTermQueryBuilderOnSearch - Class in org.hibernate.search.query.dsl
Class that allows users to continue building their TermQueries.
UnbuildableTermQueryBuilderOnSearch(TermQueryBuilderDataStore, String) - Constructor for class org.hibernate.search.query.dsl.UnbuildableTermQueryBuilderOnSearch
 
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
 
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
 
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.DocumentBuilderContainedEntity.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.dsl.v2.impl.QueryContext.Approximation
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.DocumentBuilderContainedEntity.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.dsl.v2.impl.QueryContext.Approximation
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 class org.hibernate.search.query.dsl.v2.impl.ConnectedQueryBuilder
 
wildcard() - Method in interface org.hibernate.search.query.dsl.v2.QueryBuilder
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.v2
 
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 session.
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
WorkerFactory - Class in org.hibernate.search.backend
 
WorkerFactory() - Constructor for class org.hibernate.search.backend.WorkerFactory
 
WorkQueue - Class in org.hibernate.search.backend
 
WorkQueue(int) - Constructor for class org.hibernate.search.backend.WorkQueue
 
WorkQueue() - 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) the lock must be acquired, and resources must be closed before releasing the lock.

Workspace(SearchFactoryImplementor, DirectoryProvider<?>) - 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.

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 Hibernate. All Rights Reserved.