All Classes Interface Summary Class Summary Enum Summary Exception Summary Error Summary Annotation Types Summary
Class |
Description |
AbstractBackupRepository |
Abstract BackupRepository implementation providing some logic shared between real
implementations.
|
AbstractDefaultValueUpdateProcessorFactory |
Base class that can be extended by any UpdateRequestProcessorFactory designed to add
a default value to the document in an AddUpdateCommand when that field is not
already specified.
|
AbstractEnumField |
Abstract Field type for support of string values with custom sort order.
|
AbstractEnumField.EnumMapping |
Models all the info contained in an enums config XML file
|
AbstractLuceneSpellChecker |
Abstract base class for all Lucene-based spell checking implementations.
|
AbstractPluginLoader<T> |
An abstract super class that manages standard solr-style plugin configuration.
|
AbstractReRankQuery |
|
AbstractSolrEventListener |
|
AbstractSpatialFieldType<T extends org.apache.lucene.spatial.SpatialStrategy> |
Abstract base class for Solr FieldTypes based on a Lucene 4 SpatialStrategy .
|
AbstractSpatialPrefixTreeFieldType<T extends org.apache.lucene.spatial.prefix.PrefixTreeStrategy> |
|
AbstractSSLCredentialProvider |
Abstract provider with default implementation
|
AbstractSubTypeFieldType |
An abstract base class for FieldTypes that delegate work to another FieldType .
|
ActionThrottle |
|
ActiveReplicaWatcher |
Watch for replicas to become Replica.State.ACTIVE .
|
ActiveTasksListComponent |
List the active tasks that can be cancelled
|
ActiveTasksListHandler |
Handles request for listing all active cancellable tasks
|
AddReplicaCmd |
|
AddReplicaCmd.CreateReplica |
A data structure to keep all information required to create a new replica in one place.
|
AddReplicaProperty |
V2 API for adding a property to a collection replica
|
AddressUtils |
Simple utilities for working Hostname/IP Addresses
|
AddSchemaFieldsUpdateProcessorFactory |
This processor will dynamically add fields to the schema if an input document contains one or
more fields that don't match any field or dynamic field in the schema.
|
AddUpdateCommand |
|
AdjustableSemaphore |
|
AdminAPIBase |
A common parent for "admin" (i.e.
|
AdminHandlersProxy |
Static methods to proxy calls to an Admin (GET) API to other nodes in the cluster and return a
combined response
|
AffinityPlacementConfig |
|
AffinityPlacementFactory |
This factory is instantiated by config from its class name.
|
AffinityPlacementFactory.AffinityPlacementPlugin |
See AffinityPlacementFactory for instructions on how to configure a cluster to use this
plugin and details on what the plugin does.
|
AggregateBackupStats |
|
AggregateMetric |
This class is used for keeping several partial named values and providing useful statistics over
them.
|
AggregateMetric.Update |
Simple class to represent current value and how many times it was set.
|
AggUtil |
|
AggValueSource |
|
AliasProperty |
V2 APIs for managing and inspecting properties for collection aliases
|
AllCoresStatusAPI |
V2 API for retrieving status information for all cores on the receiving node.
|
AllowListUrlChecker |
Validates URLs based on an allow list or a ClusterState in SolrCloud.
|
AllValuesOrNoneFieldMutatingUpdateProcessor |
Abstract subclass of FieldMutatingUpdateProcessor for implementing UpdateProcessors that will
mutate all individual values of a selected field independently.
|
AltBufferPoolMetricSet |
This is an alternative implementation of BufferPoolMetricSet
that doesn't need an MBean server.
|
AnalysisRequestHandlerBase |
A base class for all analysis request handlers.
|
AnalysisRequestHandlerBase.AnalysisContext |
Serves as the context of an analysis process.
|
AnalysisRequestHandlerBase.ListBasedTokenStream |
TokenStream that iterates over a list of pre-existing Tokens
|
AnalysisRequestHandlerBase.TokenTrackingAttribute |
This is an Attribute used to track the positions of tokens in the analysis chain.
|
AnalysisRequestHandlerBase.TokenTrackingAttributeImpl |
|
AnalyticsQuery |
Note: This API is experimental and may change in non backward-compatible ways in the
future
|
AnalyzeEvaluator |
|
AnalyzingInfixLookupFactory |
Factory for AnalyzingInfixSuggester
|
AnalyzingLookupFactory |
Factory for AnalyzingSuggester
|
AnnotatedApi |
This class implements an Api just from an annotated java class The class must have an annotation
EndPoint Each method must have an annotation Command The methods that implement a
command should have the first 2 parameters SolrQueryRequest and SolrQueryResponse
or it may optionally have a third parameter which could be a java class annotated with jackson
annotations.
|
Api |
Every version 2 API must extend the this class.
|
ApiBag |
|
ApiBag.ExceptionWithErrObject |
|
ApiBag.IntrospectApi |
|
ApiBag.LazyLoadedApi |
|
ApiBag.ReqHandlerToApi |
|
APIConfigProvider<T extends APIConfigProvider.APIConfig> |
Interface to be implemented by the Request Handlers that need to provide some custom
configuration to the V2 APIs
|
APIConfigProvider.APIConfig |
|
APIConfigProviderBinder |
Jersey binder for APIConfigProvider
|
ApiSupport |
The interface that is implemented by a request handler to support the V2 end point
|
ApiTool |
|
AssertTool |
Asserts various conditions and exists with error code if fails, else continues with no output
|
Assign |
|
Assign.AssignmentException |
Thrown if there is an exception while assigning nodes for replicas
|
Assign.AssignRequest |
|
Assign.AssignRequestBuilder |
|
Assign.AssignStrategy |
Strategy for assigning replicas to nodes.
|
AtomicUpdateDocumentMerger |
|
AtomicUpdateProcessorFactory |
An update processor that will convert conventional field-value document to atomic update document
|
AttributeFetcher |
Instances of this interface are used to fetch various attributes from nodes (and other sources)
in the cluster.
|
AttributeFetcherImpl |
Implementation of AttributeFetcher that uses SolrCloudManager to access Solr
cluster details.
|
AttributeValues |
|
AttributeValuesImpl |
|
AuditEvent |
Audit event that takes request and auth context as input to be able to audit log custom things.
|
AuditEvent.EventType |
|
AuditEvent.Level |
|
AuditEvent.RequestType |
|
AuditLoggerPlugin |
Base class for Audit logger plugins.
|
AuditLoggerPlugin.AuditEventFormatter |
Interface for formatting the event
|
AuditLoggerPlugin.JSONAuditEventFormatter |
Event formatter that returns event as JSON string
|
AuditLoggerPlugin.MuteRule |
|
AuthenticationPlugin |
|
AuthorizationContext |
Request context for Solr to be used by Authorization plugin.
|
AuthorizationContext.CollectionRequest |
|
AuthorizationContext.RequestType |
|
AuthorizationPlugin |
Authorization interface that needs to be implemented to write an authorization plugin.
|
AuthorizationResponse |
|
AuthorizationUtils |
|
AuthorizationUtils.AuthorizationFailure |
|
AuthTool |
|
AveragingMetricProvider |
Averages the metric value over a period of time
|
AveragingMetricProvider.MetricProvider |
Interface to provide the metric value.
|
AvgAgg |
|
BackupAPIBase |
Base class that facilitates reuse of common validation logic for collection-backup APIs.
|
BackupCmd |
|
BackupFilePaths |
Utility class for getting paths related to backups, or parsing information out of those paths.
|
BackupId |
Represents the ID of a particular backup.
|
BackupManager |
This class implements functionality to create a backup with extension points provided to
integrate with different types of file-systems.
|
BackupProperties |
Represents a backup[-*].properties file, responsible for holding whole-collection and
whole-backup metadata.
|
BackupRepository |
This interface defines the functionality required to backup/restore Solr indexes to an arbitrary
storage system.
|
BackupRepository.PathType |
This enumeration defines the type of a given path.
|
BackupRepositoryFactory |
|
BalancePlan |
A fully specified plan or instructions for replica balancing to be applied to the cluster.
|
BalancePlanFactory |
Allows plugins to create BalancePlan s telling the Solr layer how to balance replicas
following the processing of a BalanceRequest .
|
BalancePlanFactoryImpl |
|
BalanceReplicas |
V2 API for balancing the replicas that already exist across a set of nodes.
|
BalanceReplicasCmd |
|
BalanceRequest |
A cluster related placement request that Solr asks a PlacementPlugin to resolve and
compute replica balancing plan for replicas that already exist across a set of Nodes.
|
BalanceRequestImpl |
|
BalanceShardUnique |
V2 API implementation for insuring that a particular property is distributed evenly amongst the
physical nodes comprising a collection.
|
BaseEditorialTransformer |
|
BaseHandlerApiSupport |
This is a utility class to provide an easy mapping of request handlers which support multiple
commands to the V2 API format (core admin api, collections api).
|
BaseHandlerApiSupport.ApiCommand |
|
BaseManagedTokenFilterFactory |
Abstract based class for implementing TokenFilterFactory objects that are managed by the REST
API.
|
BaseSolrResource |
Base class for delegating REST-oriented requests to ManagedResources.
|
BasicAuthPlugin |
|
BasicAuthPlugin.AuthenticationProvider |
|
BasicResultContext |
|
BBoxField |
|
BBoxStrategy |
Deprecated. |
BinaryField |
|
BinaryQueryResponseWriter |
Implementations of BinaryQueryResponseWriter are used to write response in binary
format.
|
BinaryResponseWriter |
|
BinaryResponseWriter.Resolver |
|
BitDocSet |
A FixedBitSet based implementation of a DocSet .
|
BitsFilteredPostingsEnum |
|
BlendedInfixLookupFactory |
|
BlobHandler |
|
BlobRepository |
The purpose of this class is to store the Jars loaded in memory and to keep only one copy of the
Jar in a single node.
|
BlobRepository.BlobContent<T> |
|
BlobRepository.BlobContentRef<T> |
|
BlobRepository.Decoder<T> |
|
BlockJoin |
|
BlockJoinChildQParser |
|
BlockJoinChildQParserPlugin |
Usage: {!child of="PARENT:true"}PARENT_PRICE:10
|
BlockJoinParentQParser |
|
BlockJoinParentQParserPlugin |
Usage: {!parent which="PARENT:true"}CHILD_PRICE:10 supports optional score parameter
with one of ScoreMode values: None,Avg,Total,Min,Max.
|
BM25SimilarityFactory |
Factory for BM25Similarity.
|
BooleanSimilarityFactory |
Factory for BooleanSimilarity
|
BoolField |
|
BoolQParserPlugin |
Create a boolean query from sub queries.
|
BoostQParserPlugin |
Create a boosted query from the input value.
|
BoundedTreeSet<E> |
A TreeSet that ensures it never grows beyond a max size.
|
BreakIteratorBoundaryScanner |
|
ByteBuffersDirectoryFactory |
Factory to instantiate ByteBuffersDirectory
|
ByteDenseVectorParser |
|
CacheConfig |
Contains the knowledge of how cache config is stored in the solrconfig.xml file, and implements a
factory to create caches.
|
CacheRegenerator |
Implementations of CacheRegenerator are used in autowarming to populate a new cache
based on an old cache.
|
CachingDirectoryFactory |
|
CachingDirectoryFactory.CacheValue |
|
CachingDirectoryFactory.CloseListener |
|
CaffeineCache<K,V> |
A SolrCache backed by the Caffeine caching library [1].
|
CancellableCollector |
Allows a query to be cancelled
|
CancellableCollector.QueryCancelledException |
Thrown when a query gets cancelled
|
CancellableQueryTracker |
Tracks metadata for active queries and provides methods for access
|
CancelTaskAPI |
V2 API for cancelling a currently running "task".
|
CatchAllExceptionMapper |
|
CategoryRoutedAlias |
|
CatStream |
|
CatStream.CrawlFile |
|
CborLoader |
This class can load a single document or a stream of documents in CBOR format this is equivalent
of loading a single json documet or an array of json documents
|
CborResponseWriter |
A response writer impl that can write results in CBOR (cbor.io) format when wt=cbor.
|
CertAuthPlugin |
An authentication plugin that sets principal based on the certificate subject
|
CharBuffer |
A simple StringBuffer replacement that aims to reduce copying as much as possible.
|
Checksum |
Represents checksum information for an index file being backed up.
|
ChildDocTransformerFactory |
Attaches all descendants (child documents) to each parent document.
|
ChildFieldValueSourceParser |
|
CircuitBreaker |
Default base class to define circuit breaker plugins for Solr.
|
CircuitBreakerManager |
Deprecated.
|
CircuitBreakerRegistry |
Keeps track of all registered circuit breaker instances for various request types.
|
CircularList<T> |
FIFO Circular List.
|
ClassicIndexSchemaFactory |
|
ClassicSimilarityFactory |
Factory for ClassicSimilarity
|
ClassificationUpdateProcessorFactory |
This class implements an UpdateProcessorFactory for the Classification Update Processor.
|
ClassificationUpdateProcessorFactory.Algorithm |
|
ClassificationUpdateProcessorParams |
|
ClassifyStream |
The classify expression retrieves a model trained by the train expression and uses it to classify
documents from a stream Syntax: classif(model(...), anyStream(...), field="body")
|
CLIO |
|
CloneFieldUpdateProcessorFactory |
Clones the values found in any matching source field into a configured dest
field.
|
CloseHook |
Used to request notification when the core is closed.
|
CloudConfig |
|
CloudConfig.CloudConfigBuilder |
|
CloudDescriptor |
|
CloudMLTQParser |
|
CloudUtil |
|
Cluster |
A representation of the SolrCloud cluster state, providing information on which nodes and
collections are part of the cluster and a way to get to more detailed info.
|
ClusterAPI |
All V2 APIs that have a prefix of /api/cluster/
|
ClusterAPI.RoleInfo |
|
ClusterEvent |
Cluster-level event.
|
ClusterEvent.EventType |
|
ClusterEventListener |
Components that want to be notified of cluster-wide events should use this.
|
ClusterEventProducer |
|
ClusterEventProducerBase |
|
ClusterEventProducerFactory |
This class helps in handling the initial registration of plugin-based listeners, when both the
final ClusterEventProducer implementation and listeners are configured using plugins.
|
ClusterPluginsSource |
A source for Cluster Plugin configurations
|
ClusterPropertiesChangedEvent |
Event generated when ZkStateReader.CLUSTER_PROPS is
modified.
|
ClusterSingleton |
Intended for components that should be enabled only one instance per cluster.
|
ClusterSingleton.State |
|
ClusterSingletons |
|
ClusterStateMutator |
|
ClusterStatus |
|
ClusterStatus.Health |
Shard / collection health state.
|
CodecFactory |
Factory for plugging in a custom Codec
|
CollApiCmds |
This class contains "smaller" Collection API commands implementation, the interface implemented
by all commands and the class mapping a collection action to the actual command.
|
CollApiCmds.AddReplicaPropCmd |
|
CollApiCmds.BalanceShardsUniqueCmd |
|
CollApiCmds.CollectionApiCommand |
Interface implemented by all Collection API commands.
|
CollApiCmds.CommandMap |
|
CollApiCmds.DeleteReplicaPropCmd |
|
CollApiCmds.MockOperationCmd |
|
CollApiCmds.ModifyCollectionCmd |
|
CollApiCmds.RebalanceLeadersCmd |
|
CollApiCmds.ReloadCollectionCmd |
|
CollApiCmds.TraceAwareCommand |
|
CollapseScoreFunction |
|
CollapseScoreFunction.CollapseScoreFunctionValues |
|
CollapsingQParserPlugin |
The CollapsingQParserPlugin is a PostFilter that performs field collapsing.
|
CollapsingQParserPlugin.CollapseScore |
|
CollapsingQParserPlugin.CollapsingPostFilter |
|
CollapsingQParserPlugin.GroupHeadSelector |
Models all the information about how group head documents should be selected
|
CollapsingQParserPlugin.GroupHeadSelectorType |
|
CollapsingQParserPlugin.NullPolicy |
|
CollationField |
Field for collated sort keys.
|
CollectionApiLockFactory |
This class implements a higher level locking abstraction for the Collection API using lower level
read and write locks.
|
CollectionCommandContext |
Data passed to Collection API command execution, to allow calls from either the OverseerCollectionMessageHandler when commands are executed on the Overseer, or - in a future
change - allow Collection API commands to be executed in a distributed way, unrelated to and not
depending upon Overseer abstractions (including overseer collection message handling).
|
CollectionHandlingUtils |
This class contains helper methods used by commands of the Collection API.
|
CollectionHandlingUtils.ShardRequestTracker |
|
CollectionMetrics |
Collection-level metrics.
|
CollectionMetricsBuilder |
|
CollectionMetricsBuilder.ReplicaMetricsBuilder |
|
CollectionMetricsBuilder.ShardMetricsBuilder |
|
CollectionMutator |
|
CollectionProperty |
V2 API implementations for modifying collection-level properties.
|
CollectionsAddedEvent |
Event generated when some collections have been added.
|
CollectionsHandler |
|
CollectionsHandler.CollectionOperation |
|
CollectionSnapshotMetaData |
This class defines the meta-data about a collection level snapshot
|
CollectionSnapshotMetaData.CoreSnapshotMetaData |
|
CollectionSnapshotMetaData.SnapshotStatus |
|
CollectionsRemovedEvent |
Event generated when some collections have been removed.
|
CollectionsRepairEventListener |
This is an illustration how to re-implement the combination of Solr 8x NodeLostTrigger and
AutoAddReplicasPlanAction to maintain the collection's replicas when nodes are lost.
|
CollectionStats |
Modifiable version of CollectionStatistics useful for aggregation of per-shard stats.
|
CollectionStatusAPI |
V2 API for displaying basic information about a single collection.
|
ColStatus |
Report low-level details of collection.
|
Command |
|
Command<T> |
Defines a grouping command.
|
CommandHandler |
Responsible for executing a search with a number of Command instances.
|
CommandHandler.Builder |
|
CommitTracker |
Helper class for tracking autoCommit state.
|
CommitUpdateCommand |
A commit index command encapsulated in an object.
|
ComplexPhraseQParserPlugin |
Parse Solr's variant on the Lucene ComplexPhraseQueryParser syntax.
|
ConcatFieldUpdateProcessorFactory |
Concatenates multiple values for fields matching the specified conditions using a configurable
delimiter which defaults to ", ".
|
ConcatStringFunction |
ConcatStringFunction concatenates the string values of its components in the order
given.
|
ConcurrentLRUCache<K,V> |
A LRU cache implementation based upon ConcurrentHashMap and other techniques to reduce contention
and synchronization overhead to utilize multiple CPU cores more effectively.
|
ConcurrentLRUCache.CacheEntry<K,V> |
|
ConcurrentLRUCache.EvictionListener<K,V> |
|
ConcurrentLRUCache.Stats |
|
ConfigEditablePlugin |
An interface to be implemented by a Plugin whose Configuration is runtime editable
|
ConfigOverlay |
This class encapsulates the config overlay json file.
|
ConfigSet |
Stores a core's configuration in the form of a SolrConfig and IndexSchema.
|
ConfigSetAPIBase |
Parent class for all APIs that manipulate configsets
|
ConfigSetApiLockFactory |
This class implements a higher level locking abstraction for the Config Set API using lower level
read and write locks.
|
ConfigSetCmds |
|
ConfigSetDownloadTool |
|
ConfigSetProperties |
Utility methods for reading configSet properties.
|
ConfigSetService |
Service class used by the CoreContainer to load ConfigSets for use in SolrCore creation.
|
ConfigSetService.ConfigResource |
|
ConfigSetsHandler |
|
ConfigSetUploadTool |
|
ConfigTool |
Sends a POST to the Config API to perform a specified action.
|
ConfigurablePlugin<T extends org.apache.solr.common.MapWriter> |
Implement this interface if your plugin needs to accept some configuration
|
ConjunctionSolrSpellChecker |
This class lets a query be run through multiple spell checkers.
|
Constants |
constants used in facets package
|
ContainerPluginsApi |
API to maintain container-level plugin configurations.
|
ContainerPluginsRegistry |
This class manages the container-level plugins and their Api-s.
|
ContainerPluginsRegistry.Diff |
|
ContainerPluginsRegistry.PluginRegistryListener |
Listener for notifications about added / deleted / modified plugins.
|
ContainerRequestUtils |
Utility methods for creating and populating a ContainerRequest for use with Jersey ApplicationHandler s
|
ContentStreamHandlerBase |
Shares common code between various handlers that manipulate ContentStream objects.
|
ContentStreamLoader |
Load a ContentStream into Solr
|
CoordinateFieldType |
A CoordinateFieldType is the base class for FieldType s that have
semantics related to items in a coordinate system.
|
CoordinatorHttpSolrCall |
A coordinator node can serve requests as if it hosts all collections in the cluster.
|
CoordinatorHttpSolrCall.Factory |
|
CoordinatorV2HttpSolrCall |
|
CopyField |
CopyField contains all the information of a valid copy fields in an index.
|
CoreAdminAPIBase |
A common parent for admin Core Jersey-based APIs.
|
CoreAdminAPIBase.CoreAdminAPIBaseException |
Helper RuntimeException to allow passing checked exceptions to the caller of the handle method.
|
CoreAdminHandler |
|
CoreAdminHandler.CallInfo |
|
CoreAdminHandler.CoreAdminAsyncTracker |
|
CoreAdminHandler.CoreAdminAsyncTracker.TaskObject |
Helper class to manage the tasks to be tracked.
|
CoreAdminHandler.CoreAdminOp |
|
CoreAdminOperation |
|
CoreAugmenterFactory |
|
CoreContainer |
|
CoreContainer.CoreLoadFailure |
|
CoreContainerProvider |
A service that can provide access to solr cores.
|
CoreDescriptor |
|
CorePropertiesLocator |
Persists CoreDescriptors as properties files
|
CoreReplicationAPI |
V2 APIs for inspecting and replicating indices
|
CoreReplicationAPI.FileListResponse |
|
CoreReplicationAPI.FileMetaData |
|
CoreReplicationAPI.IndexVersionResponse |
|
CoresLocator |
Manage the discovery and persistence of core definitions across Solr restarts
|
CoreSnapshot |
V2 API for Creating, Listing, and Deleting Core Snapshots.
|
CoreSorter |
This is a utility class that sorts cores in such a way as to minimize other cores waiting for
replicas in the current node.
|
CountAgg |
|
CountFieldValuesUpdateProcessorFactory |
Replaces any list of values for a field matching the specified conditions with the count of the
number of values for that field.
|
CountValsAgg |
|
CpuAllowedLimit |
Enforces a CPU-time based timeout on a given SolrQueryRequest, as specified by the
cpuAllowed query parameter.
|
CPUCircuitBreaker |
Tracks current CPU usage and triggers if the specified threshold is breached.
|
CreateAliasAPI |
V2 API for creating an alias
|
CreateAliasAPI.CategoryRoutedAliasProperties |
|
CreateAliasAPI.CreateAliasRequestBody |
|
CreateAliasAPI.RoutedAliasProperties |
|
CreateAliasAPI.TimeRoutedAliasProperties |
|
CreateAliasCmd |
|
CreateCollection |
V2 API for creating a SolrCLoud collection
|
CreateCollectionBackup |
V2 API for creating a new "backup" of a specified collection
|
CreateCollectionCmd |
|
CreateCollectionSnapshot |
V2 API implementation for creating a collection-level snapshot.
|
CreateCollectionTool |
Supports create_collection command in the bin/solr script.
|
CreateConfigSetAPI |
V2 API for creating a new configset as a copy of an existing one.
|
CreateCoreAPI |
V2 API for creating a new core on the receiving node.
|
CreateCoreBackup |
|
CreateCoreTool |
|
CreateReplica |
V2 API implementation for adding a new replica to an existing shard.
|
CreateShard |
V2 API for creating a new shard in a collection.
|
CreateShardCmd |
|
CreateSnapshotCmd |
This class implements the functionality of creating a collection level snapshot.
|
CreateTool |
|
CrossCollectionJoinQParser |
|
CrossCollectionJoinQuery |
|
CryptoKeys |
A utility class with helpers for various signature and certificate tasks
|
CryptoKeys.RSAKeyPair |
|
CSVLoader |
|
CSVLoaderBase |
|
CSVParser |
Parses CSV files according to the specified configuration.
|
CSVPrinter |
Print values as a comma separated list.
|
CSVResponseWriter |
Response writer for csv data
|
CSVStrategy |
CSVStrategy
|
CSVUtils |
Utility methods for dealing with CSV files
|
CurrencyField |
Deprecated.
|
CurrencyFieldType |
Field type for support of monetary values.
|
CurrencyValue |
Represents a Currency field value, which includes a long amount and ISO currency code.
|
CursorMark |
An object that encapsulates the basic information about the current Mark Point of a "Cursor"
based request.
|
DataConfigNode |
ConfigNode impl that copies and maintains data internally from DOM
|
DateMathParser |
A Simple Utility class for parsing "math" like strings relating to Dates.
|
DatePointField |
FieldType that can represent any Date/Time with millisecond precision.
|
DateRangeField |
A field for indexed dates and date ranges.
|
DateValueFieldType |
Marker interface for Date-valued field types.
|
DebugComponent |
Adds debugging information to a request.
|
DefaultClusterEventProducer |
|
DefaultEncoder |
Use the DefaultEncoder
|
DefaultMergePolicyFactory |
|
DefaultPackageRepository |
This is a serializable bean (for the JSON that is stored in /repository.json) representing a
repository of Solr packages.
|
DefaultSampleDocumentsLoader |
|
DefaultSchemaSuggester |
|
DefaultSolrCoreState |
|
DefaultSolrHighlighter |
|
DefaultSolrHighlighter.FvhContainer |
|
DefaultValueUpdateProcessorFactory |
An update processor that adds a constant default value to any document being added that does not
already have a value in the specified field.
|
DelegateRegistryCounter |
A counter implementation that is aware of both primary and delegate metrics belonging to
different registries and able to update metrics in multiple registries
|
DelegateRegistryHistogram |
A meter implementation that is aware of both primary and delegate metrics belonging to different
registries and able to update metrics in multiple registries
|
DelegateRegistryMeter |
A meter implementation that is aware of both primary and delegate metrics belonging to different
registries and able to update metrics in multiple registries
|
DelegateRegistryTimer |
A timer implementation that is aware of both primary and delegate metrics belonging to different
registries and able to update metrics in multiple registries
|
DelegatingBackupRepository |
|
DelegatingClusterEventProducer |
This implementation allows Solr to dynamically change the underlying implementation of ClusterEventProducer in response to the changed plugin configuration.
|
DelegatingCollector |
A simple delegating collector where one can set the delegate after creation
|
DelegatingEventListener |
A SolrEventListener wrapper that loads class from a package and reload if it's modified
|
DelegatingPlacementPluginFactory |
Helper class to support dynamic reloading of plugin implementations.
|
DelegatingSolrQueryRequest |
|
DeleteAlias |
|
DeleteAliasCmd |
|
DeleteBackupCmd |
An overseer command used to delete files associated with incremental backups.
|
DeleteCollection |
V2 API for deleting collections.
|
DeleteCollectionBackup |
V2 API definitions for collection-backup deletion.
|
DeleteCollectionCmd |
|
DeleteCollectionRequest |
Delete collection request.
|
DeleteCollectionSnapshot |
V2 API impl for Deleting Collection Snapshots.
|
DeleteConfigSetAPI |
V2 API for deleting an existing configset
|
DeleteNode |
V2 API for deleting all replicas of all collections in one node.
|
DeleteNodeCmd |
|
DeleteReplica |
V2 APIs for deleting one or more existing replicas from one or more shards.
|
DeleteReplicaCmd |
|
DeleteReplicaProperty |
V2 API implementation for removing a property from a collection replica
|
DeleteReplicasRequest |
Delete replicas request.
|
DeleteShard |
V2 API implementation for deleting a particular shard from its collection.
|
DeleteShardCmd |
|
DeleteShardsRequest |
Delete shards request.
|
DeleteSnapshotCmd |
This class implements the functionality of deleting a collection level snapshot.
|
DeleteTool |
|
DeleteUpdateCommand |
|
DenseVectorField |
Provides a field type to support Lucene's KnnVectorField .
|
DenseVectorParser |
|
DenseVectorParser.BuilderPhase |
|
DeprecationLog |
Utility to log a deprecation.
|
DFISimilarityFactory |
Factory for DFISimilarity
|
DFRSimilarityFactory |
Factory for DFRSimilarity
|
Diagnostics |
|
Diagnostics.Callable |
|
DictionaryFactory |
Encapsulates shared fields for all types of dictionaryFactory classes
|
DimensionalRoutedAlias |
|
DirectoryFactory |
Provides access to a Directory implementation.
|
DirectoryFactory.DirContext |
|
DirectSolrConnection |
DirectSolrConnection provides an interface to Solr that is similar to the HTTP interface, but
does not require an HTTP connection.
|
DirectSolrSpellChecker |
Spellchecker implementation that uses DirectSpellChecker
|
DirectUpdateHandler2 |
DirectUpdateHandler2 implements an UpdateHandler where documents are added directly
to the main Lucene index as opposed to adding to a separate smaller index.
|
DisMaxQParser |
Query parser for dismax queries
|
DisMaxQParserPlugin |
Create a dismax query from the input value.
|
DistanceUnits |
Used with a spatial field type for all distance measurements.
|
DistribFileStore |
|
DistributedApiAsyncTracker |
Class holding the implementation required for tracking asynchronous Collection API (or other)
tasks when the Collection API is distributed.
|
DistributedClusterStateUpdater |
Gives access to distributed cluster state update methods and allows code to inquire whether
distributed state update is enabled.
|
DistributedClusterStateUpdater.MutatingCommand |
Naming of enum instances are the mutator object name (e.g.
|
DistributedClusterStateUpdater.StateChangeRecorder |
Class handling the distributed updates of collection's Zookeeper files state.json based
on multiple updates applied to a single collection (as is sometimes done by *Cmd classes
implementing the Collection API commands).
|
DistributedCollectionCommandContext |
|
DistributedCollectionConfigSetCommandRunner |
|
DistributedCollectionLockFactory |
|
DistributedConfigSetLockFactory |
|
DistributedLock |
A lock that can be used across cluster nodes.
|
DistributedMap |
A distributed map.
|
DistributedMultiLock |
A lock as acquired for running a single API command (Collection or Config Set or anything else in
the future).
|
DistributedUpdateProcessor |
|
DistributedUpdateProcessor.DistribPhase |
Values this processor supports for the DISTRIB_UPDATE_PARAM .
|
DistributedUpdateProcessor.DistributedUpdatesAsyncException |
|
DistributedUpdateProcessor.LeaderRequestReplicationTracker |
|
DistributedUpdateProcessor.RollupRequestReplicationTracker |
|
DistributedUpdateProcessorFactory |
|
DistributedZkUpdateProcessor |
|
DistributingUpdateProcessorFactory |
A marker interface for denoting that a factory is responsible for handling distributed
communication of updates across a SolrCloud cluster.
|
DocBasedVersionConstraintsProcessor |
|
DocBasedVersionConstraintsProcessorFactory |
This Factory generates an UpdateProcessor that helps to enforce Version constraints on documents
based on per-document version numbers using a configured versionField , a
comma-delimited list of fields to check for version numbers.
|
DocExpirationUpdateProcessorFactory |
Update Processor Factory for managing automatic "expiration" of documents.
|
DocIdAugmenterFactory |
Augments the document with a [docid] integer containing it's current (internal) id
in the lucene index.
|
DocIterator |
Simple Iterator of document Ids which may include score information.
|
DocList |
DocList represents the result of a query: an ordered list of document ids with
optional score.
|
DocListAndSet |
A struct whose only purpose is to hold both a DocList and a DocSet so that both
may be returned from a single method.
|
DocSet |
An immutable ordered set of Lucene Document Ids.
|
DocSetBuilder |
Adapted from DocIdSetBuilder to build DocSets
|
DocSetCollector |
|
DocSetCollector.ExpandingIntArray |
|
DocSetProducer |
|
DocSetUtil |
|
DocSlice |
DocSlice implements DocList as an array of docids and optional scores.
|
DocsStreamer |
This streams SolrDocuments from a DocList and applies transformer
|
DocTermOrds |
This class enables fast access to multiple term ords for a specified field across all docIDs.
|
DocTransformer |
A DocTransformer can add, remove or alter a Document before it is written out to the Response.
|
DocTransformer.NoopFieldTransformer |
Trivial Impl that ensure that the specified field is requested as an "extra" field, but then
does nothing during the transformation phase.
|
DocTransformers |
Transform a document before it gets sent out
|
DocumentAnalysisRequestHandler |
An analysis handler that provides a breakdown of the analysis process of provided documents.
|
DocumentBuilder |
Builds a Lucene Document from a SolrInputDocument .
|
DocumentDictionaryFactory |
Factory for DocumentDictionary
|
DocumentExpressionDictionaryFactory |
Factory for DocumentValueSourceDictionary
|
DocValuesAcc |
Accumulates stats separated by slot number for the fields with DocValues
|
DocValuesFacets |
Computes term facets for docvalues field (single or multivalued).
|
DocValuesIteratorCache |
A helper class for random-order value access over docValues (such as in the case of
useDocValuesAsStored).
|
DocValuesIteratorCache.FieldDocValuesSupplier |
Supplies (and coordinates arbitrary-order value retrieval over) docValues iterators for a
particular field, encapsulating the logic of iterator creation, reuse/caching, and advancing.
|
DocValuesStats |
Computes term stats for docvalues field (single or multivalued).
|
DOMConfigNode |
Read using DOM
|
DoublePointField |
PointField implementation for Double values.
|
DoubleValueFieldType |
Marker interface for double-valued field types.
|
DualDoubleFunction |
Abstract ValueSource implementation which wraps two ValueSources and applies an
extendible double function to their values.
|
DumpRequestHandler |
|
DynamicMap |
An efficient map for storing keys as integer in range from 0..n with n can be estimated up-front.
|
EarlyTerminatingCollector |
|
EarlyTerminatingCollectorException |
Thrown by EarlyTerminatingCollector when the maximum to abort the scoring / collection
process early, when the specified maximum number of documents were collected.
|
ElectionContext |
|
ElevatedMarkerFactory |
Used to mark whether a document has been elevated or not
|
EmbeddedSolrServer |
SolrClient that connects directly to a CoreContainer.
|
EmbeddedSolrServer.RequestWriterSupplier |
|
EndPoint |
|
EndResultTransformer |
Responsible for transforming the grouped result into the final format for displaying purposes.
|
EndResultTransformer.SolrDocumentSource |
Abstracts the source for SolrDocument instances.
|
EnumField |
Deprecated.
|
EnumFieldType |
Field type for support of string values with custom sort order.
|
EnvSSLCredentialProvider |
Environment variable based SSL configuration provider
|
EnvSSLCredentialProvider.EnvVars |
|
EphemeralDirectoryFactory |
Directory provider for implementations that do not persist over reboots.
|
EqualFunction |
Compares two values for equality.
|
ExactSharedStatsCache |
This class implements exact caching of statistics.
|
ExactStatsCache |
This class implements exact caching of statistics.
|
ExactStatsCache.ExactStatsSource |
|
ExceptionWhileTracing |
|
ExchangeRateProvider |
Interface for providing pluggable exchange rate providers to @CurrencyField
|
ExcludedMarkerFactory |
|
ExpandComponent |
The ExpandComponent is designed to work with the CollapsingPostFilter.
|
ExperimentalResponse |
SolrJerseyResponse implementation with a warning field indicating that the format may
change
|
ExplainAugmenterFactory |
|
ExplainAugmenterFactory.Style |
|
ExportHandler |
|
ExportHandler.ExportHandlerStreamFactory |
|
ExportQParserPlugin |
|
ExportQParserPlugin.ExportQParser |
|
ExportQParserPlugin.ExportQuery |
|
ExportTool |
|
ExportTool.Info |
|
ExportWriter |
Prepares and writes the documents requested by /export requests
|
ExportWriter.IgnoreException |
|
ExportWriterStream |
Stream implementation that helps supporting 'expr' streaming in export writer.
|
ExtendedDismaxQParser |
Query parser that generates DisjunctionMaxQueries based on user configuration.
|
ExtendedDismaxQParser.Clause |
|
ExtendedDismaxQParser.ExtendedDismaxConfiguration |
Simple container for configuration information used when parsing queries
|
ExtendedDismaxQParser.ExtendedSolrQueryParser |
A subclass of SolrQueryParser that supports aliasing fields for constructing
DisjunctionMaxQueries.
|
ExtendedDismaxQParser.ExtendedSolrQueryParser.Alias |
A simple container for storing alias info
|
ExtendedDismaxQParserPlugin |
An advanced multi-field query parser based on the DisMax parser.
|
ExtendedQuery |
The ExtendedQuery interface provides extra metadata to a query.
|
ExtendedQueryBase |
|
ExternalFileField |
Get values from an external file instead of the index.
|
ExternalFileFieldReloader |
An event listener to reload ExternalFileFields for new searchers.
|
ExternalRoleRuleBasedAuthorizationPlugin |
Rule Based Authz plugin implementation which reads user roles from the request.
|
FacetBucket |
|
FacetComponent |
Computes facets -- aggregations with counts of terms or ranges over the whole search results.
|
FacetComponent.DistribFieldFacet |
This API is experimental and subject to change
|
FacetComponent.FacetBase |
This API is experimental and subject to change
|
FacetComponent.FacetContext |
Encapsulates facet ranges and facet queries such that their parameters are parsed and cached
for efficient re-use.
|
FacetComponent.FacetInfo |
This class is used exclusively for merging results from each shard in a distributed facet
request.
|
FacetComponent.FieldFacet |
This API is experimental and subject to change
|
FacetComponent.QueryFacet |
This API is experimental and subject to change
|
FacetComponent.ShardFacetCount |
This API is experimental and subject to change
|
FacetContext |
|
FacetDebugInfo |
|
FacetField |
|
FacetField.FacetMethod |
|
FacetFieldMerger |
|
FacetHeatmap |
JSON Facet API request for a 2D spatial summary of a rectangular region.
|
FacetMerger |
|
FacetMerger.Context |
|
FacetModule |
|
FacetProcessor<T extends FacetRequest> |
Base abstraction for a class that computes facets.
|
FacetQuery |
|
FacetRange |
|
FacetRangeMerger |
|
FacetRequest |
A request to do facets/stats that might itself be composed of sub-FacetRequests.
|
FacetRequest.Domain |
|
FacetRequest.Domain.GraphField |
Are we doing a query time graph across other documents
|
FacetRequest.Domain.JoinField |
Are we doing a query time join across other documents
|
FacetRequest.FacetSort |
Simple structure for encapsulating a sort variable and a direction
|
FacetRequest.RefineMethod |
|
FacetRequest.SortDirection |
|
FieldAnalysisRequestHandler |
Provides the ability to specify multiple field types and field names in the same request.
|
FieldCache |
Expert: Maintains caches of term values.
|
FieldCache.CacheEntry |
EXPERT: A unique Identifier/Description for each item in the FieldCache.
|
FieldCache.CreationPlaceholder |
Placeholder indicating creation of this cache is currently in-progress.
|
FieldCache.Parser |
interface to all parsers.
|
FieldCache.PointParser |
Base class for points parsers.
|
FieldCacheImpl |
Expert: The default cache implementation, storing all values in memory.
|
FieldCacheImpl.BinaryDocValuesImpl |
|
FieldCacheImpl.LongsFromArray |
|
FieldCacheImpl.SortedDocValuesImpl |
|
FieldFacetStats |
FieldFacetStats is a utility to accumulate statistics on a set of values in one field, for facet
values present in another field.
|
FieldLengthUpdateProcessorFactory |
Replaces any CharSequence values found in fields matching the specified conditions with the
lengths of those CharSequences (as an Integer).
|
FieldMutatingUpdateProcessor |
Reusable base class for UpdateProcessors that will consider AddUpdateCommands and mutate the
values associated with configured fields.
|
FieldMutatingUpdateProcessor.FieldNameSelector |
Interface for identifying which fields should be mutated
|
FieldMutatingUpdateProcessorFactory |
Base class for implementing Factories for FieldMutatingUpdateProcessors and
FieldValueMutatingUpdateProcessors.
|
FieldMutatingUpdateProcessorFactory.SelectorParams |
|
FieldNameMutatingUpdateProcessorFactory |
In the FieldNameMutatingUpdateProcessorFactory configured below, fields names will be mutated if
the name contains space.
|
FieldNameValueSource |
Placeholder value source.
|
FieldParams |
A class to hold "phrase slop" and "boost" parameters for pf, pf2, pf3 parameters
|
FieldProperties |
|
FieldQParserPlugin |
Create a field query from the input value, applying text analysis and constructing a phrase query
if appropriate.
|
FieldType |
Base class for all field types used by an index schema.
|
FieldType.MultiValueSelector |
An enumeration representing various options that may exist for selecting a single value from a
multivalued field.
|
FieldTypePluginLoader |
|
FieldTypeXmlAdapter |
Utility class for converting a JSON definition of a FieldType into the XML format expected by the
FieldTypePluginLoader.
|
FieldUtil |
|
FieldUtil.DVOrdValues |
|
FieldUtil.FCOrdValues |
|
FieldUtil.OrdFunc |
The following ord visitors and wrappers are a work in progress and experimental
|
FieldUtil.OrdValues |
|
FieldValueMutatingUpdateProcessor |
Abstract subclass of FieldMutatingUpdateProcessor for implementing UpdateProcessors that will
mutate all individual values of a selected field independently
|
FieldValueSubsetUpdateProcessorFactory |
Base class for processors that want to mutate selected fields to only keep a subset of the
original values.
|
FileBasedSpellChecker |
A spell checker implementation that loads words from a text file (one word per line).
|
FileDictionaryFactory |
Factory for FileDictionary
|
FileExchangeRateProvider |
Configuration for currency.
|
FileFloatSource |
Obtains float field values from an external file.
|
FileFloatSource.ReloadCacheRequestHandler |
|
FileStore |
The interface to be implemented by any package store provider * @lucene.experimental
|
FileStore.FileDetails |
|
FileStore.FileEntry |
|
FileStore.FileType |
|
FileStoreAPI |
|
FileStoreAPI.MetaData |
|
FileSystemConfigSetService |
FileSystem ConfigSetService impl.
|
FileTypeMagicUtil |
Utility class to guess the mime type of file based on its magic number.
|
FileUtils |
|
FilterCollector |
A collector that filters incoming doc ids that are not in the filter.
|
FilteredDocIdSet |
Abstract decorator class for a DocIdSet implementation that provides on-demand
filtering/validation mechanism on a given DocIdSet.
|
FilteringSolrMetricReporter |
|
FilterQuery |
A filtered query wrapped around another query similar to BooleanClause.Occur.FILTER -- it scores as 0.
|
FiltersQParser |
|
FiltersQParserPlugin |
|
FirstFieldValueUpdateProcessorFactory |
Keeps only the first value of fields matching the specified conditions.
|
FloatConsumer |
Represents an operation that accepts a single float -valued argument and returns no
result.
|
FloatDenseVectorParser |
|
FloatPayloadValueSource |
|
FloatPointField |
PointField implementation for Float values.
|
FloatValueFieldType |
Marker interface for float-valued field types.
|
ForceLeader |
V2 API implementation for triggering a leader election on a particular collection and shard.
|
FreeTextLookupFactory |
LookupFactory implementation for FreeTextSuggester
|
FSTLookupFactory |
Factory for FSTCompletionLookup
|
FunctionQParser |
|
FunctionQParserPlugin |
Create a function query from the input value.
|
FunctionRangeQParserPlugin |
Create a range query over a function.
|
FunctionRangeQuery |
|
FuzzyLookupFactory |
Factory for FuzzySuggester
|
GapFragmenter |
|
GeoDistValueSourceParser |
|
GeohashFunction |
Deprecated. |
GeohashHaversineFunction |
Deprecated. |
GeoJSONResponseWriter |
Extend the standard JSONResponseWriter to support GeoJSON.
|
GeoTransformerFactory |
This DocumentTransformer will write a Shape to the SolrDocument using the requested
format.
|
GetAuthenticationConfigAPI |
V2 API for fetching the authentication section from Solr's security.json configuration.
|
GetAuthorizationConfigAPI |
V2 API for fetching the authorization section of Solr's security.json configuration.
|
GetBlobInfoAPI |
V2 APIs for fetching blob(s) and their metadata
|
GetConfigAPI |
V2 APIs for retrieving some or all configuration relevant to a particular collection (or core).
|
GetNodeCommandStatus |
Implementation of V2 API interface GetNodeCommandStatusApi for checking the status of a
core-level asynchronous command.
|
GetPublicKey |
V2 API implementation to fetch the public key of the receiving node.
|
GetSchema |
|
GetSchemaFieldAPI |
GetSchemaFieldAPI contains the V2 APIs for all field related endpoint which are
/fields
/fields/{fieldName}
/copyfields
/dynamicfields
/dynamicfields/{fieldName}
/fieldtypes
/fieldtypes/{fieldTypeName}
|
GetSchemaFieldAPI.SchemaGetDynamicFieldInfoResponse |
|
GetSchemaFieldAPI.SchemaGetFieldInfoResponse |
|
GetSchemaFieldAPI.SchemaGetFieldTypeInfoResponse |
|
GetSchemaFieldAPI.SchemaListCopyFieldsResponse |
|
GetSchemaFieldAPI.SchemaListDynamicFieldsResponse |
|
GetSchemaFieldAPI.SchemaListFieldsResponse |
|
GetSchemaFieldAPI.SchemaListFieldTypesResponse |
|
GraphHandler |
Solr Request Handler for graph traversal with streaming functions that responds with GraphML
markup.
|
GraphHandler.DummyErrorStream |
|
GraphHandler.TimerStream |
|
GraphMLResponseWriter |
|
GraphPointsCollector |
|
GraphQParserPlugin |
Query parser plugin for solr to wrap the graph query parser.
|
GraphQuery |
GraphQuery - search for nodes and traverse edges in an index.
|
GraphQueryParser |
Solr query parser that will handle parsing graph query requests.
|
GraphTermsQParserPlugin |
The GraphTermsQuery builds a disjunction query from a list of terms.
|
GroupedEndResultTransformer |
Implementation of EndResultTransformer that keeps each grouped result separate in the
final response.
|
Grouping |
Basic Solr Grouping infrastructure.
|
Grouping.Format |
|
Grouping.TotalCount |
|
GroupingSpecification |
Encapsulates the grouping options like fields group sort and more specified by clients.
|
HashQParserPlugin |
syntax fq={!hash workers=11 worker=4 keys=field1,field2}
|
HashRangeQParser |
|
HashRangeQParserPlugin |
Matches documents where the specified field hashes to a value within the given range.
|
HashRangeQuery |
|
HasImplicitIndexAnalyzer |
Marker interface for field types that have an implicit (non-user-configurable) index-time schema.
|
HaversineConstFunction |
Haversine function with one point constant
|
HaversineFunction |
Calculate the Haversine formula (distance) between any two points on a sphere Takes in four value
sources: (latA, lonA); (latB, lonB).
|
HaversineMetersEvaluator |
|
HaversineMetersEvaluator.HaversineDistance |
|
HealthCheckHandler |
Health Check Handler for reporting the health of a specific node.
|
HealthcheckTool |
|
HighFrequencyDictionaryFactory |
Factory for HighFrequencyDictionary
|
HighlightComponent |
Highlights query words in the search results.
|
HighlightComponent.HighlightMethod |
|
HighlightingPluginBase |
|
HLL |
A probabilistic set of hashed long elements.
|
HLLAgg |
|
HLLAgg.HLLFactory |
|
HLLType |
The types of algorithm/data structure that HLL can utilize.
|
HtmlEncoder |
Use the SimpleHTMLEncoder
|
HtmlFormatter |
Use the SimpleHTMLFormatter
|
HTMLStripFieldUpdateProcessorFactory |
Strips all HTML Markup in any CharSequence values found in fields matching the specified
conditions.
|
HttpCacheHeaderUtil |
|
HttpClientBuilderPlugin |
Plugin interface for configuring internal HttpClients.
|
HttpClientMetricNameStrategy |
Strategy for creating metric names for HttpClient Copied from metrics-httpclient library
|
HttpServletAuthorizationContext |
An AuthorizationContext implementation that delegates many methods to an underlying
HttpServletRequest
|
HttpServletCarrier |
A Carrier for extract Span context out of request headers
|
HttpShardHandler |
|
HttpShardHandlerFactory |
|
HttpSolrCall |
This class represents a call made to Solr
|
IBSimilarityFactory |
Factory for IBSimilarity
|
IdUtils |
Helper class for generating unique ID-s.
|
IGainTermsQParserPlugin |
|
IgnoreCommitOptimizeUpdateProcessorFactory |
Gives system administrators a way to ignore explicit commit or optimize requests from clients.
|
IgnoreFieldUpdateProcessorFactory |
Ignores & removes fields matching the specified conditions from any document being added to
the index.
|
IgnoreLargeDocumentProcessorFactory |
Gives system administrators a way to ignore very large update from clients.
|
InactiveShardRemover |
This Cluster Singleton can be configured to periodically find and remove Slice.State.INACTIVE Shards that are left behind after a Shard is
split
|
InactiveShardRemoverConfig |
|
IncompleteRerankingException |
|
IncrementalShardBackup |
Responsible for orchestrating the actual incremental backup process.
|
IncrementalShardBackup.IncrementalShardSnapshotResponse |
|
IndexBasedSpellChecker |
A spell checker implementation that loads words from Solr as well as arbitrary Lucene indices.
|
IndexDeletionPolicyWrapper |
A wrapper for an IndexDeletionPolicy instance.
|
IndexFetcher |
Provides functionality of downloading changed index files as well as config files and a timer for
scheduling fetches from the leader.
|
IndexFetcher.CompareResult |
|
IndexFetcher.IndexFetchResult |
|
IndexFingerprint |
|
IndexOutputOutputStream |
|
IndexReaderFactory |
Factory used to build a new IndexReader instance.
|
IndexSchema |
IndexSchema contains information about the valid fields in an index and the types of
those fields.
|
IndexSchema.DynamicCopy |
|
IndexSchema.DynamicField |
|
IndexSchema.DynamicReplacement |
|
IndexSchema.DynamicReplacement.DynamicPattern |
|
IndexSchema.SchemaProps |
|
IndexSchema.SchemaProps.Handler |
|
IndexSchemaFactory |
Base class for factories for IndexSchema implementations
|
IndexSchemaFactory.VersionedConfig |
|
IndexSizeEstimator |
Estimates the raw size of all uncompressed indexed data by scanning term, docValues and stored
fields data.
|
IndexSizeEstimator.Estimate |
|
IndexSizeEstimator.Item |
|
IndexSizeEstimator.ItemPriorityQueue |
|
IndexSizeEstimator.MapWriterSummaryStatistics |
|
InfoHandler |
|
InitParams |
An Object which represents a <initParams> tag
|
InjectionFactories |
|
InjectionFactories.RequestContextBasedFactory |
Allows access to a ContainerRequestContext via a ServiceLocator
|
InjectionFactories.ReuseFromContextIndexSchemaFactory |
|
InjectionFactories.ReuseFromContextSolrCoreFactory |
Fetch the (existing) SolrCore from the request context
|
InjectionFactories.ReuseFromContextSolrParamsFactory |
|
InjectionFactories.SingletonFactory<T> |
|
InjectionFactories.SolrQueryRequestFactory |
|
InjectionFactories.SolrQueryResponseFactory |
|
InstallCoreData |
V2 API implementation of the "Install Core Data" Core-Admin API
|
InstallCoreDataOp |
v1 shim implementation of the "Install Core Data" API, a core-admin API used to implement the
"Install Shard Data" Collection-Admin functionality
|
InstallShardData |
V2 API implementation allowing users to import offline-constructed index into a shard.
|
InstallShardDataCmd |
Overseer processing for the "install shard data" API.
|
InstallShardDataCmd.RemoteMessage |
|
InstrumentedHttpListenerFactory |
A HttpListenerFactory tracking metrics and distributed tracing.
|
InstrumentedHttpListenerFactory.NameStrategy |
|
InstrumentedHttpRequestExecutor |
Sub-class of HttpRequestExecutor which tracks metrics interesting to solr Inspired and partially
copied from dropwizard httpclient library
|
InstrumentedPoolingHttpClientConnectionManager |
Sub-class of PoolingHttpClientConnectionManager which tracks metrics interesting to Solr.
|
IntComp |
|
IntComp.IntAsc |
|
IntComp.IntDesc |
|
IntervalFacets |
Computes interval facets for docvalues field (single or multivalued).
|
IntervalFacets.FacetInterval |
Helper class to match and count of documents in specified intervals
|
IntFloatDynamicMap |
|
IntIntDynamicMap |
|
IntLongDynamicMap |
|
IntPointField |
PointField implementation for Integer values.
|
IntValue |
|
IntValueFieldType |
Marker interface for int-valued field types.
|
IOFunction<T,R> |
A Function that may throw an IOException
|
ISchemaVersion |
A serialization schema for HLLs.
|
IterativeMergeStrategy |
|
IWordDeserializer |
Reads 'words' of a fixed width, in sequence, from a byte array.
|
JacksonJsonWriter |
A JSON ResponseWriter that uses jackson.
|
JacksonJsonWriter.WriterImpl |
|
JacksonReflectMapWriter |
A MapWriter implementation that relies on Jackson's JsonProperty annotation.
|
JaspellLookup |
Deprecated.
|
JaspellLookupFactory |
Factory for JaspellLookup Note: This Suggester is not very RAM efficient.
|
JaspellTernarySearchTrie |
Deprecated.
|
JaspellTernarySearchTrie.TSTNode |
An inner class of Ternary Search Trie that represents a node in the trie.
|
JavabinLoader |
Update handler which uses the JavaBin format
|
JerseyAppHandlerCache |
Stores Jersey 'ApplicationHandler' instances by an ID or hash derived from their ConfigSet .
|
JerseyApplications |
|
JerseyApplications.CoreContainerApp |
|
JerseyApplications.SolrCoreApp |
|
JerseyResource |
A marker parent type for all Jersey "resource" classes.
|
JettyBridgeResponseWriter |
A ResponseWriter which copies that output of JAX-RS computation over to HttpServletResponse object used by the Jetty server.
|
JmxMetricsReporter |
This is a modified copy of Dropwizard's JmxReporter and classes
that it internally uses, with a few important differences:
this class knows that it can directly use MetricsMap as a dynamic MBean.
|
JmxMetricsReporter.Builder |
|
JmxMetricsReporter.JmxCounterMBean |
|
JmxMetricsReporter.JmxGaugeMBean |
|
JmxMetricsReporter.JmxHistogramMBean |
|
JmxMetricsReporter.JmxMeterMBean |
|
JmxMetricsReporter.JmxTimerMBean |
|
JmxMetricsReporter.MetricMBean |
|
JmxObjectNameFactory |
Factory to create MBean names for a given metric.
|
JmxUtil |
Utility methods to find a MBeanServer.
|
JoinQParserPlugin |
|
JsonLoader |
|
JsonPreAnalyzedParser |
|
JSONResponseWriter |
|
JSONUtil |
|
JSONWriter |
|
JulInfo |
|
JulWatcher |
|
KnnQParser |
|
KnnQParserPlugin |
A neural query parser to run K-nearest neighbors search on Dense Vector fields.
|
LastFieldValueUpdateProcessorFactory |
Keeps only the last value of fields matching the specified conditions.
|
LatLonPointSpatialField |
A spatial implementation based on Lucene's LatLonPoint and LatLonDocValuesField .
|
LatLonPointSpatialField.LatLonPointSpatialStrategy |
|
LeaderElector |
Leader Election process.
|
LeaderRecoveryWatcher |
We use this watcher to wait for any eligible replica in a shard to become active so that it can
become a leader.
|
LegacyDoubleField |
Deprecated.
|
LegacyFacet |
|
LegacyFacet.Subfacet |
|
LegacyField |
Deprecated.
|
LegacyFieldType |
Deprecated.
|
LegacyFloatField |
Deprecated.
|
LegacyIntField |
Deprecated.
|
LegacyLongField |
Deprecated.
|
LegacyNumericRangeQuery<T extends Number> |
Deprecated.
|
LegacyNumericRangeQueryBuilder |
Deprecated.
|
LegacyNumericTokenStream |
Deprecated.
|
LegacyNumericTokenStream.LegacyNumericTermAttribute |
Expert: Use this attribute to get the details of the currently generated token.
|
LegacyNumericTokenStream.LegacyNumericTermAttributeImpl |
|
LegacyNumericType |
Deprecated.
|
LegacyNumericUtils |
Deprecated.
|
LegacyNumericUtils.IntRangeBuilder |
|
LegacyNumericUtils.LongRangeBuilder |
|
ListActiveTasksAPI |
V2 API for listing any currently running "tasks".
|
ListAliases |
V2 API implementation for listing and inspecting collection aliases
|
ListCollectionBackups |
V2 API implementations for collection-backup "listing".
|
ListCollections |
V2 API for listing collections.
|
ListCollectionSnapshotsAPI |
V2 API for Listing Collection Snapshots.
|
ListCollectionSnapshotsAPI.ListSnapshotsResponse |
|
ListConfigSets |
V2 API implementation for listing all available configsets.
|
ListenerConfig |
|
LMDirichletSimilarityFactory |
Factory for LMDirichletSimilarity
|
LMJelinekMercerSimilarityFactory |
Factory for LMJelinekMercerSimilarity
|
LoadAdminUiServlet |
A simple servlet to load the Solr Admin UI
|
LoadAverageCircuitBreaker |
Tracks current system load average and triggers if the specified threshold is breached.
|
LocaleUtils |
|
LocalFileSystemRepository |
A concrete implementation of BackupRepository interface supporting backup/restore of
Solr indexes to a local file-system.
|
LocalSolrQueryRequest |
|
LocalStatsCache |
Default implementation that simply ignores global term statistics, and always uses local term
statistics.
|
LocalStatsSource |
|
LockTree |
This is a utility class that offers fine grained locking for various Collection Operations This
class is designed for single threaded operation.
|
Log4j2Watcher |
|
Log4j2Watcher.Log4j2Appender |
|
Log4j2Watcher.Log4j2Info |
|
LogByteSizeMergePolicyFactory |
|
LogDocMergePolicyFactory |
|
LoggerInfo |
Wrapper class for Logger implementations
|
LoggingHandler |
A request handler to show which loggers are registered and allows you to set them
|
LoggingInfoStream |
An InfoStream implementation which passes messages on to Solr's logging.
|
LogUpdateProcessorFactory |
A logging processor.
|
LogWatcher<E> |
A Class to monitor Logging events and hold N events in memory
|
LogWatcherConfig |
|
LongIterator |
A long -based iterator.
|
LongPointField |
PointField implementation for Long values.
|
LongPriorityQueue |
A native long priority queue.
|
LongValue |
|
LongValueFieldType |
Marker interface for long-valued field types.
|
Lookup3Signature |
|
LookupFactory |
Suggester factory for creating Lookup instances.
|
LowerCaseTokenizer |
Deprecated.
|
LowerCaseTokenizerFactory |
Deprecated.
|
LRUStatsCache |
Unlike ExactStatsCache this implementation preserves term stats across queries in a set
of LRU caches (with the same life-cycle as SolrIndexSearcher), and based on surface features of a
query it determines the need to send additional requests to retrieve local term and collection
statistics from shards.
|
LuceneDefaultCodecFactory |
Simple factory for returning the Lucene default Codec
|
LuceneQParser |
|
LuceneQParserPlugin |
Parse Solr's variant on the Lucene QueryParser syntax.
|
LukeRequestHandler |
Exposes the internal lucene index.
|
MacroExpander |
|
MainEndResultTransformer |
Implementation of EndResultTransformer that transforms the grouped result into the main
result list in the response.
|
MaintainRoutedAliasCmd |
|
ManagedIndexSchema |
Solr-managed schema - non-user-editable, but can be mutable via internal and external REST API
requests.
|
ManagedIndexSchema.FieldExistsException |
|
ManagedIndexSchema.SchemaChangedInZkException |
|
ManagedIndexSchemaFactory |
Factory for ManagedIndexSchema
|
ManagedResource |
Supports Solr components that have external data that needs to be managed using the REST API.
|
ManagedResource.ChildResourceSupport |
Marker interface to indicate a ManagedResource implementation class also supports managing
child resources at path: /<resource>/{child}
|
ManagedResourceObserver |
Allows a Solr component to register as an observer of important ManagedResource events, such as
when the managed data is loaded.
|
ManagedResourceStorage |
Abstract base class that provides most of the functionality needed to store arbitrary data for
managed resources.
|
ManagedResourceStorage.FileStorageIO |
Local file-based storage implementation.
|
ManagedResourceStorage.InMemoryStorageIO |
Memory-backed storage IO; not really intended for storage large amounts of data in production,
but useful for testing and other transient workloads.
|
ManagedResourceStorage.JsonStorage |
Default storage implementation that uses JSON as the storage format for managed data.
|
ManagedResourceStorage.StorageIO |
Hides the underlying storage implementation for data being managed by a ManagedResource.
|
ManagedResourceStorage.ZooKeeperStorageIO |
ZooKeeper based storage implementation that uses the SolrZkClient provided by the
CoreContainer.
|
ManagedSchemaDiff |
Utility methods for comparing managed index schemas
|
ManagedStopFilterFactory |
TokenFilterFactory that uses the ManagedWordSetResource implementation for managing stop words
using the REST API.
|
ManagedSynonymFilterFactory |
Deprecated.
|
ManagedSynonymFilterFactory.SynonymManager |
ManagedResource implementation for synonyms, which are so specialized that it makes sense to
implement this class as an inner class as it has little application outside the
SynonymFilterFactory use cases.
|
ManagedSynonymGraphFilterFactory |
TokenFilterFactory and ManagedResource implementation for doing CRUD on synonyms using the REST
API.
|
ManagedSynonymGraphFilterFactory.SynonymManager |
ManagedResource implementation for synonyms, which are so specialized that it makes sense to
implement this class as an inner class as it has little application outside the
SynonymFilterFactory use cases.
|
ManagedWordSetResource |
ManagedResource implementation for managing a set of words using the REST API; useful for
managing stop words and/or protected words for analysis components like the KeywordMarkerFilter.
|
MapInitializedPlugin |
A plugin that can be initialized with a Map<String,String>
|
MapListener<K,V> |
|
MapPluginLoader<T extends MapInitializedPlugin> |
|
MatchCostQuery |
Wraps a Query to customize the TwoPhaseIterator.matchCost() .
|
MaxFieldValueUpdateProcessorFactory |
An update processor that keeps only the maximum value from any selected fields where multiple
values are found.
|
MaxScoreCollector |
A Collector for the maximum score value.
|
MaxScoreQParser |
|
MaxScoreQParserPlugin |
Parses a query like Lucene query parser, but scoring with max score, not sum
Accepts the "tie" request parameter as with dismax.
|
MD5Signature |
|
MDCLoggingContext |
Set's per thread context info for logging.
|
MDCSnapshot |
Takes a 'snapshot' of the current MDC context map which is restored on (auto) close.
|
MediaTypeOverridingFilter |
Overrides the content-type of the response based on an optional user-provided 'wt' parameter
|
MemoryCircuitBreaker |
Tracks the current JVM heap usage and triggers if a moving heap usage average over 30 seconds
exceeds the defined percentage of the maximum heap size allocated to the JVM.
|
MemOutputStream |
|
MergeIndexes |
Implementation of V2 API interface MergeIndexesApi for merging one or more indexes to
another index.
|
MergeIndexesCommand |
A merge indexes command encapsulated in an object.
|
MergePolicyFactory |
A factory for creating a MergePolicy .
|
MergePolicyFactoryArgs |
|
MergeStrategy |
The MergeStrategy class defines custom merge logic for distributed searches.
|
MessageBodyReaders |
A collection point for various MessageBodyReader implementations.
|
MessageBodyReaders.CachingDelegatingMessageBodyReader |
Caches the deserialized request body in the ContainerRequestContext for use later in
the request lifecycle.
|
MessageBodyReaders.CachingJsonMessageBodyReader |
A JSON MessageBodyReader that caches request bodies for use later in the request
lifecycle.
|
MessageBodyWriters |
|
MessageBodyWriters.BaseMessageBodyWriter |
|
MessageBodyWriters.CsvMessageBodyWriter |
|
MessageBodyWriters.JavabinMessageBodyWriter |
|
MessageBodyWriters.RawMessageBodyWriter |
|
MessageBodyWriters.XmlMessageBodyWriter |
|
Method |
|
Metric<T> |
Metric-related attribute of a node or replica.
|
MetricImpl<T> |
Base class for Metric implementations.
|
MetricsCollectorHandler |
Handler to collect and aggregate metric reports.
|
MetricsConfig |
|
MetricsConfig.CacheConfig |
|
MetricsConfig.MetricsConfigBuilder |
|
MetricsHandler |
Request handler to return metrics
|
MetricsMap |
Dynamically constructed map of metrics, intentionally different from MetricSet where each metric had to be known in advance and registered
separately in MetricRegistry .
|
MetricSuppliers |
Helper class for constructing instances of MetricRegistry.MetricSupplier based on plugin configuration.
|
MetricSuppliers.DefaultCounterSupplier |
Default Counter supplier.
|
MetricSuppliers.DefaultHistogramSupplier |
Default supplier of Histogram instances, with configurable reservoir.
|
MetricSuppliers.DefaultMeterSupplier |
Default Meter supplier.
|
MetricSuppliers.DefaultTimerSupplier |
Default supplier of Timer instances, with configurable clock and reservoir.
|
MetricSuppliers.NoOpCounterSupplier |
No-op implementation of Counter supplier.
|
MetricSuppliers.NoOpGauge |
No-op implementation of Gauge .
|
MetricSuppliers.NoOpHistogramSupplier |
No-op implementation of Histogram supplier.
|
MetricSuppliers.NoOpMeterSupplier |
No-op implementation of Meter supplier.
|
MetricSuppliers.NoOpMetric |
Marker interface for all no-op metrics.
|
MetricSuppliers.NoOpTimerSupplier |
No-op implementation of Timer supplier.
|
MetricUtils |
Metrics specific utility functions.
|
MigrateCmd |
|
MigrateDocsAPI |
V2 API for migrating docs from one collection to another.
|
MigrateReplicas |
V2 API for migrating replicas from a set of nodes to another set of nodes.
|
MigrateReplicasCmd |
|
MinFieldValueUpdateProcessorFactory |
An update processor that keeps only the minimum value from any selected fields where multiple
values are found.
|
MinHashQParser |
The query parser can be used in two modes 1) where text is analysed and generates min hashes as
part of normal lucene analysis 2) where text is pre-analysed and hashes are added as string to
the index An analyzer can still be defined to support text based query against the text field
|
MinHashQParserPlugin |
|
MinimizeCoresPlacementFactory |
Factory for creating MinimizeCoresPlacementFactory.MinimizeCoresPlacementPlugin , a Placement plugin implementing
placing replicas to minimize number of cores per Node , while not placing two replicas of
the same shard on the same node.
|
MinMaxAgg |
|
MissingAgg |
|
MLTContentQParserPlugin |
|
MLTQParserPlugin |
Usage: {!mlt qf=queryField1,queryField2}uniqueId
|
MMapDirectoryFactory |
Directly provide MMapDirectory instead of relying on FSDirectory.open(java.nio.file.Path) .
|
MockSearchableSolrClient |
Simple mock client that collects added documents and supports simple search by id (both
{!term f=id} and id: syntax is supported) or *:*.
|
ModificationRequest |
Collection modification request.
|
ModificationRequestImpl |
Helper class to create modification request instances.
|
ModifyBasicAuthConfigAPI |
|
ModifyCollectionAPI |
V2 API for modifying collections.
|
ModifyConfigComponentAPI |
V2 APIs for creating, updating, or deleting individual components in a collection configuration.
|
ModifyMultiPluginAuthConfigAPI |
|
ModifyNoAuthPluginSecurityConfigAPI |
V2 API for POST requests received when no authentication plugin is active.
|
ModifyNoAuthzPluginSecurityConfigAPI |
V2 API for POST requests received when no authorization plugin is active.
|
ModifyParamSetAPI |
V2 APIs for creating, modifying, or deleting paramsets.
|
ModifyRuleBasedAuthConfigAPI |
|
ModuleUtils |
Parses the list of modules the user has requested in solr.xml, property solr.modules or
environment SOLR_MODULES.
|
MoreLikeThisAPI |
V2 API for performing a more like this request to a solr collection.
|
MoreLikeThisComponent |
TODO!
|
MoreLikeThisHandler |
Solr MoreLikeThis --
|
MoreLikeThisHandler.InterestingTerm |
|
MoreLikeThisHandler.MoreLikeThisHelper |
Helper class for MoreLikeThis that can be called from other request handlers
|
MoveReplicaAPI |
V2 API for moving a collection replica to a different physical node.
|
MoveReplicaCmd |
|
MultiAuthPlugin |
Authentication plugin that supports multiple Authorization schemes, such as Bearer and Basic.
|
MultiAuthRuleBasedAuthorizationPlugin |
Authorization plugin designed to work with the MultiAuthPlugin to support different
AuthorizationPlugin per scheme.
|
MultiDestinationAuditLogger |
Audit logger that chains other loggers.
|
MultiStringFunction |
Abstract ValueSource implementation which wraps multiple ValueSources and applies an
extendible string function to their values.
|
MultiValueTermOrdinalCollector |
Populates a bitset of (top-level) ordinals based on field values in a multi-valued field.
|
NamedListInitializedPlugin |
A plugin that can be initialized with a NamedList
|
NamedListPluginLoader<T extends NamedListInitializedPlugin> |
|
NestedQParserPlugin |
Create a nested query, with the ability of that query to redefine its type via local parameters.
|
NestedRequestHandler |
An interface for RequestHandlers need to handle all paths under its registered path
|
NestedUpdateProcessorFactory |
Adds fields to nested documents to support some nested search requirements.
|
NestPathField |
|
NIOFSDirectoryFactory |
Factory to instantiate NIOFSDirectory
|
Node |
Representation of a SolrCloud node or server in the SolrCloud cluster.
|
NodeConfig |
|
NodeConfig.NodeConfigBuilder |
|
NodeConfigClusterPluginsSource |
Plugin configurations that are defined in solr.xml.
|
NodeHealthAPI |
V2 API for checking the health of the receiving node.
|
NodeLoggingAPI |
V2 APIs for getting or setting log levels on an individual node.
|
NodeLoggingAPI.ListLevelsResponse |
Response format for the 'GET /api/node/logging/levels' API.
|
NodeLoggingAPI.LoggingResponse |
Generic logging response that includes the name of the log watcher (e.g.
|
NodeLoggingAPI.LogLevelChange |
A user-requested modification in the level that a specified logger reports at.
|
NodeLoggingAPI.LogLevelInfo |
Representation of a single logger and its current state.
|
NodeLoggingAPI.LogMessageInfo |
Metadata about the log messages returned by the 'GET /api/node/logging/messages' API
|
NodeLoggingAPI.LogMessagesResponse |
Response format for the 'GET /api/node/logging/messages' API.
|
NodeLoggingAPI.SetThresholdRequestBody |
The request body for the 'PUT /api/node/logging/messages/threshold' API.
|
NodeMetric<T> |
Node metric identifier, corresponding to a node-level metric registry and the internal metric
name.
|
NodeMetric.Registry |
Registry options for node metrics.
|
NodeMetricImpl<T> |
Node metric identifier, corresponding to a node-level metric registry and the internal metric
name.
|
NodeMutator |
|
NodePropertiesAPI |
V2 API for listing system properties for each node.
|
NodeRoles |
|
NodeRoles.Role |
|
NodesDownEvent |
Event generated when some nodes went down.
|
NodesUpEvent |
Event generated when some nodes went up.
|
NodeSystemInfoAPI |
V2 API for getting "system" information from the receiving node.
|
NodeThreadsAPI |
V2 API for triggering a thread dump on the receiving node.
|
NoMergePolicyFactory |
|
NoOpDistributingUpdateProcessorFactory |
A No-Op implementation of DistributingUpdateProcessorFactory that allways returns the next
processor instead of inserting a new URP in front of it.
|
NoOpProducer |
|
NoOpRegenerator |
Cache regenerator that just populates the new cache with the old items.
|
NotFoundExceptionMapper |
An ExceptionMapper for the exception produced by JAX-RS when no match could be found for
an incoming request.
|
NotFoundRequestHandler |
Does nothing other than showing a 404 message
|
NRTCachingDirectoryFactory |
Factory to instantiate NRTCachingDirectory
|
NumberType |
|
NumberUtils |
|
NumericFieldType |
|
NumericHidingLeafReader |
Deprecated. |
NumericValueFieldType |
Marker interface for numeric-valued field types.
|
ObjectUtil |
|
ObjectUtil.ConflictHandler |
|
OcmhCollectionCommandContext |
Context passed to Collection API commands when they execute in the Overseer.
|
OffsetCorrector |
|
OpenExchangeRatesOrgProvider |
Exchange Rates Provider for CurrencyField and CurrencyFieldType capable of
fetching & parsing the freely available exchange rates from openexchangerates.org
|
OperatingSystemMetricSet |
This is an extended replacement for FileDescriptorRatioGauge -
that class uses reflection and doesn't work under Java 9.
|
OrderedExecutor |
|
OrderedNodePlacementPlugin |
|
OrderedNodePlacementPlugin.WeightedNode |
A class that determines the weight of a given node and the replicas that reside on it.
|
OrdFieldSource |
Obtains the ordinal of the field value from LeafReader.getSortedDocValues(java.lang.String) .
|
Overseer |
Cluster leader.
|
Overseer.Message |
|
Overseer.OverseerThread |
|
OverseerAction |
Enum of actions supported by the overseer only.
|
OverseerCollectionConfigSetProcessor |
An OverseerTaskProcessor that handles: 1) collection-related Overseer messages 2)
configset-related Overseer messages
|
OverseerCollectionMessageHandler |
|
OverseerConfigSetMessageHandler |
|
OverseerMessageHandler |
|
OverseerMessageHandler.Lock |
|
OverseerNodePrioritizer |
Responsible for prioritization of Overseer nodes, for example with the ADDROLE collection
command.
|
OverseerOperationAPI |
V2 API for triggering a node to rejoin leader election for the 'overseer' role.
|
OverseerRoleCmd |
|
OverseerSolrResponse |
|
OverseerSolrResponseSerializer |
|
OverseerStatusCmd |
This command returns stats about the Overseer, the cluster state updater and collection API
activity occurring within the current Overseer node (this is important because distributed
operations occurring on other nodes are not included in these stats, for example
distributed cluster state updates or Per Replica States updates).
|
OverseerTaskProcessor |
A generic processor run in the Overseer, used for handling items added to a distributed work
queue.
|
OverseerTaskProcessor.OverseerMessageHandlerSelector |
|
OverseerTaskQueue |
|
OverseerTaskQueue.QueueEvent |
|
PackageAPI |
This implements the public end points (/api/cluster/package) of package API.
|
PackageAPI.Packages |
|
PackageAPI.PkgVersion |
|
PackageListeners |
|
PackageListeners.Listener |
|
PackageListeners.Listener.Ctx |
|
PackageListeningClassLoader |
A SolrClassLoader that is designed to listen to a set of packages.
|
PackageManager |
Handles most of the management of packages that are already installed in Solr.
|
PackagePluginHolder<T> |
|
PackageRepository |
Abstract class for a repository, holding SolrPackage items.
|
PackageTool |
|
PackageUtils |
|
ParseBooleanFieldUpdateProcessorFactory |
Attempts to mutate selected fields that have only CharSequence-typed values into Boolean values.
|
ParseDateFieldUpdateProcessorFactory |
Attempts to mutate selected fields that have only CharSequence-typed values into Date values.
|
ParseDoubleFieldUpdateProcessorFactory |
Attempts to mutate selected fields that have only CharSequence-typed values into Double values.
|
ParseException |
This exception is thrown when parse errors are encountered.
|
ParseFloatFieldUpdateProcessorFactory |
Attempts to mutate selected fields that have only CharSequence-typed values into Float values.
|
ParseIntFieldUpdateProcessorFactory |
Attempts to mutate selected fields that have only CharSequence-typed values into Integer values.
|
ParseLongFieldUpdateProcessorFactory |
Attempts to mutate selected fields that have only CharSequence-typed values into Long values.
|
ParseNumericFieldUpdateProcessorFactory |
Abstract base class for numeric parsing update processor factories.
|
PathExcluder |
Denotes an object, usually a servlet that denies access to some paths based on the supplied
patterns.
|
PayloadCheckQParserPlugin |
|
PayloadObj<T> |
Holds the deserialized object for each command and also holds request , response objects
|
PayloadScoreQParserPlugin |
Creates a PayloadScoreQuery wrapping a SpanQuery created from the input value, applying text
analysis and constructing SpanTermQuery or SpanNearQuery based on number of terms.
|
PayloadUtils |
|
PeerSync |
This class is useful for performing peer to peer synchronization of recently indexed update
commands during recovery process.
|
PeerSync.MissedUpdatesFinder |
Helper class for doing comparison ourUpdates and other replicas's updates to find the updates
that we missed
|
PeerSync.MissedUpdatesRequest |
|
PeerSync.PeerSyncResult |
|
PeerSyncWithLeader |
|
PeerSyncWithLeader.MissedUpdatesFinder |
Helper class for doing comparison ourUpdates and other replicas's updates to find the updates
that we missed
|
PercentileAgg |
|
PercentileAgg.Parser |
|
PermissionName |
|
PermissionNameProvider |
A requestHandler should implement this interface to provide the well known permission at request
time
|
PermissionNameProvider.Name |
|
PHPResponseWriter |
|
PHPSerializedResponseWriter |
A description of the PHP serialization format can be found here:
http://www.hurring.com/scott/code/perl/serialize/
|
PhrasesIdentificationComponent |
A component that can be used in isolation, or in conjunction with QueryComponent to
identify & score "phrases" found in the input string, based on shingles in indexed fields.
|
PhrasesIdentificationComponent.Phrase |
Model the data known about a single (candidate) Phrase -- which may or may not be indexed
|
PhrasesIdentificationComponent.PhrasesContextData |
Simple container for all request options and data this component needs to store in the Request
Context
|
PingRequestHandler |
Ping Request Handler for reporting SolrCore health to a Load Balancer.
|
PingRequestHandler.ACTIONS |
|
PivotFacet |
Models a single instance of a "pivot" specified by a FacetParams.FACET_PIVOT param, which
may contain multiple nested fields.
|
PivotFacetField |
Models a single field somewhere in a hierarchy of fields as part of a pivot facet.
|
PivotFacetFieldValueCollection |
|
PivotFacetFieldValueCollection.PivotFacetCountComparator |
|
PivotFacetFieldValueCollection.PivotFacetValueComparator |
|
PivotFacetHelper |
|
PivotFacetProcessor |
Processes all Pivot facet logic for a single node -- both non-distrib, and per-shard
|
PivotFacetValue |
Models a single (value, count) pair that will exist in the collection of values for a PivotFacetField parent.
|
PivotListEntry |
Enum for modeling the elements of a (nested) pivot entry as expressed in a NamedList
|
PKIAuthenticationPlugin |
|
PKIAuthenticationPlugin.PKIHeaderData |
|
PlacementContext |
Placement context makes it easier to pass around and access main placement-related components.
|
PlacementException |
|
PlacementModificationException |
Exception thrown when a placement modification is rejected by the placement plugin.
|
PlacementPlan |
A fully specified plan or instructions for placement, deletion or move to be applied to the
cluster.
|
PlacementPlanFactory |
|
PlacementPlanFactoryImpl |
|
PlacementPlugin |
Implemented by external plugins to control replica placement and movement on the search cluster
(as well as other things such as cluster elasticity?) when cluster changes are required
(initiated elsewhere, most likely following a Collection API call).
|
PlacementPluginAssignStrategy |
This assign strategy delegates placement computation to "plugin" code.
|
PlacementPluginConfig |
Configuration beans should use this interface to define public (mutable) configuration
properties.
|
PlacementPluginFactory<T extends PlacementPluginConfig> |
|
PlacementPluginFactory.NoConfig |
Useful type for plugins that don't use any configuration.
|
PlacementPluginFactoryLoader |
|
PlacementRequest |
|
PlacementRequestImpl |
|
PluginBag<T> |
This manages the lifecycle of a set of plugin of the same type .
|
PluginBag.JaxrsResourceToHandlerMappings |
Allows JAX-RS 'filters' to find the requestHandler (if any) associated particular JAX-RS
resource classes
|
PluginBag.PluginHolder<T> |
An indirect reference to a plugin.
|
PluginInfo |
An Object which represents a Plugin of any type
|
PluginInfo.ClassName |
|
PluginInfoHandler |
|
PluginInfoInitialized |
A plugin that can be initialized with a PluginInfo
|
PointField |
Provides field types to support for Lucene's IntPoint , LongPoint , FloatPoint and DoublePoint .
|
PointMerger |
Merge multiple numeric point fields (segments) together.
|
PointMerger.ValueIterator |
|
PointType |
A point type that indexes a point in an n-dimensional space as separate fields and supports range
queries.
|
PossibilityIterator |
Given a list of possible Spelling Corrections for multiple mis-spelled words in a query, This
iterator returns Possible Correction combinations ordered by reasonable probability that such a
combination will return actual hits if re-queried.
|
PossibilityIterator.RankedSpellPossibility |
|
PostFilter |
The PostFilter interface provides a mechanism to further filter documents after they have already
gone through the main query and other filters.
|
PostLogsTool |
A command line tool for indexing Solr logs in the out-of-the-box log format.
|
PostLogsTool.LogRecordReader |
|
PostRequestDecorationFilter |
Applies standard post-processing decorations to a SolrJerseyResponse that are needed on
all responses.
|
PostRequestLoggingFilter |
|
PostTool |
|
PostTool.PageFetcherResult |
Utility class to hold the result form a page fetch
|
PreAnalyzedField |
Pre-analyzed field type provides a way to index a serialized token stream, optionally with an
independent stored value of a field.
|
PreAnalyzedField.ParseResult |
This is a simple holder of a stored part and the collected states (tokens with attributes).
|
PreAnalyzedField.PreAnalyzedParser |
Parse the input and return the stored part and the tokens with attributes.
|
PreAnalyzedUpdateProcessorFactory |
An update processor that parses configured fields of any document being added using PreAnalyzedField with the configured format parser.
|
PrefixQParserPlugin |
Create a prefix query from the input value.
|
PrepareCoreRecoveryAPI |
Internal V2 API used to prepare a core for recovery.
|
PrimitiveFieldType |
Abstract class defining shared behavior for primitive types Intended to be used as base class for
non-analyzed fields like int, float, string, date etc, and set proper defaults for them
|
PrimUtils |
Utilities for primitive Java data types.
|
PrimUtils.IntComparator |
|
PrintWriterWrapper |
Wrapper for PrintWriter that delegates to constructor arg
|
PropertiesInputStream |
|
PropertiesRequestHandler |
|
PublicKeyHandler |
|
PythonResponseWriter |
|
QParser |
Note: This API is experimental and may change in non backward-compatible ways in the
future
|
QParserPlugin |
|
QueryCancellationComponent |
Responsible for handling query cancellation requests
|
QueryCancellationHandler |
Handles requests for query cancellation for cancellable queries
|
QueryCommand |
|
QueryCommand |
A query request command to avoid having to change the method signatures if we want to pass
additional information to the searcher.
|
QueryCommand.Builder |
|
QueryCommandResult |
Encapsulates TopDocs and the number of matches.
|
QueryComponent |
TODO!
|
QueryComponent.ScoreAndDoc |
Fake scorer for a single document
|
QueryContext |
|
QueryConverter |
The QueryConverter is an abstract base class defining a method for converting input "raw" queries
into a set of tokens for spell checking.
|
QueryElevationComponent |
A component to elevate some documents to the top of the result set.
|
QueryElevationComponent.ElevatingQuery |
Query triggering elevation.
|
QueryElevationComponent.Elevation |
Elevation of some documents in search results, with potential exclusion of others.
|
QueryElevationComponent.ElevationProvider |
Provides the elevations defined for queries.
|
QueryElevationComponent.InitializationExceptionCause |
|
QueryElevationComponent.TrieSubsetMatcher<E extends Comparable<? super E>,M> |
Matches a potentially large collection of subsets with a trie implementation.
|
QueryElevationComponent.TrieSubsetMatcher.Builder<E extends Comparable<? super E>,M> |
|
QueryLimits |
Represents the limitations on the query.
|
QueryLimitsExceededException |
|
QueryParser |
|
QueryParser.Operator |
The default operator for parsing queries.
|
QueryParserConstants |
Token literal values and constants.
|
QueryParserTokenManager |
Token Manager.
|
QueryParsing |
Collection of static utilities useful for query parsing.
|
QueryRateLimiter |
Implementation of RequestRateLimiter specific to query request types.
|
QueryResponseWriter |
Implementations of QueryResponseWriter are used to format responses to query
requests.
|
QueryResponseWriterUtil |
|
QueryResult |
The result of a search.
|
QueryResultKey |
A hash key encapsulating a query, a list of filters, and a sort
|
QuerySenderListener |
|
QueryUtils |
|
RAMDirectoryFactory |
Factory to instantiate RAM-resident directory implementation.
|
RandomPlacementFactory |
Factory for creating RandomPlacementFactory.RandomPlacementPlugin , a placement plugin implementing random
placement for new collection creation while preventing two replicas of same shard from being
placed on same node..
|
RandomPlacementFactory.RandomPlacementPlugin |
|
RandomSortField |
Utility Field used for random sorting.
|
RandomSortField.RandomValueSource |
|
RangeFacetProcessor |
Processor for Range Facets
|
RangeFacetRequest |
Encapsulates a single facet.range request along with all its parameters.
|
RangeFacetRequest.FacetRange |
Represents a single facet range (or gap) for which the count is to be calculated
|
RankField |
RankField s can be used to store scoring factors to improve document ranking.
|
RankQParserPlugin |
RankQParserPlugin can be used to introduce document-depending scoring factors to ranking.
|
RankQParserPlugin.RankQParser |
|
RankQuery |
Note: This API is experimental and may change in non backward-compatible ways in the
future
|
RateLimiterConfig |
|
RateLimitManager |
This class is responsible for managing rate limiting per request type.
|
RateLimitManager.Builder |
|
RawQParserPlugin |
Create a term query from the input value without any text analysis or transformation whatsoever.
|
RawResponseWriter |
Writes a ContentStream directly to the output.
|
RawValueTransformerFactory |
|
RealTimeGetAPI |
V2 API for fetching the latest (possibly uncommitted) version of one or more documents.
|
RealTimeGetComponent |
|
RealTimeGetComponent.Resolution |
Lookup strategy for some methods on this class.
|
RealTimeGetHandler |
|
RebalanceLeadersAPI |
V2 API for balancing shard leaders in a collection across nodes.
|
RecordHandler |
|
RecordingJSONParser |
|
RecoveringCoreTermWatcher |
Start recovery of a core if its term is less than leader's term
|
RecoveryStrategy |
This class may change in future and customisations are not supported between versions in terms of
API or back compat behaviour.
|
RecoveryStrategy.Builder |
|
RecoveryStrategy.RecoveryListener |
|
RedirectServlet |
A Simple redirection servlet to help us deprecate old UI elements
|
RefCounted<Type> |
Keep track of a reference count on a resource and close it when the count hits zero.
|
RefreshCollectionMessage |
Refresh the ClusterState for a given collection.
|
RegexBytesRefFilter |
An implementation of Predicate which returns true if the BytesRef matches the supplied
regular expression.
|
RegexFileFilter |
Accepts any file whose name matches the pattern
|
RegexFragmenter |
Fragmenter that tries to produce snippets that "look"
like a regular expression.
|
RegexpBoostProcessor |
A processor which will match content of "inputField" against regular expressions found in
"boostFilename", and if it matches will return the corresponding boost value from the file and
output this to "boostField" as a double value.
|
RegexpBoostProcessorFactory |
Factory which creates RegexBoostProcessors
|
RegexReplaceProcessorFactory |
An updated processor that applies a configured regex to any CharSequence values found in the
selected fields, and replaces any matches with the configured replacement string.
|
ReindexCollectionCmd |
Reindex a collection, usually in order to change the index schema.
|
ReindexCollectionCmd.Cmd |
|
ReindexCollectionCmd.State |
|
RejoinLeaderElectionAPI |
V2 API for triggering a core to rejoin leader election for the shard it constitutes.
|
RelatednessAgg |
An aggregation function designed to be nested under other (possibly deeply nested) facets for the
purposes of computing the "relatedness" of facet buckets relative to "foreground" and
"background" sets -- primarily for the purpose of building "Semantic Knowledge Graphs"
|
ReloadCollectionAPI |
V2 API implementation for reloading collections.
|
ReloadCore |
V2 API implementation for reloading an individual core.
|
RemoveBlankFieldUpdateProcessorFactory |
Removes any values found which are CharSequence with a length of 0.
|
RenameCmd |
|
RenameCollection |
V2 API implementation to "rename" an existing collection
|
RenameCore |
V2 API for renaming an existing Solr core.
|
RenameCoreAPI |
V2 API for renaming an existing Solr core.
|
RenameCoreAPI.RenameCorePayload |
|
RenameFieldTransformer |
Return a field with a name that is different that what is indexed
|
ReplaceNode |
V2 API for recreating replicas in one node (the source) on another node(s) (the target).
|
ReplaceNodeCmd |
|
Replica |
|
Replica.ReplicaState |
|
Replica.ReplicaType |
The order of this enum is important from the most to least "important" replica type.
|
ReplicaMetric<T> |
Replica metric identifier, corresponding to one of the internal replica-level metric names (as
reported in solr.core.[collection].[replica] registry)
|
ReplicaMetricImpl<T> |
Replica metric identifier, corresponding to one of the internal replica-level metric names (as
reported in solr.core.[collection].[replica] registry)
|
ReplicaMetrics |
Strongly-typed replica-level metrics.
|
ReplicaMigrationUtils |
|
ReplicaMutator |
|
ReplicaPlacement |
Placement decision for a single Replica .
|
ReplicateFromLeader |
|
ReplicationAPIBase |
A common parent for "replication" (i.e.
|
ReplicationHandler |
A Handler which provides a REST API for replication and serves replication requests from
Followers.
|
ReplicationHandler.PollListener |
|
ReplicationHandler.ReplicationHandlerConfig |
|
ReporterClientCache<T> |
Simple cache for reusable service clients used by some implementations of SolrMetricReporter .
|
ReporterClientCache.ClientProvider<T> |
Provide an instance of service client.
|
RepositoryManager |
Handles most of the management of repositories and packages present in external repositories.
|
RequestApplyCoreUpdatesAPI |
Internal V2 API used to apply updates to a core.
|
RequestBufferUpdatesAPI |
Internal V2 API used to start update-buffering on the specified core.
|
RequestContextKeys |
Keys used to store and retrieve values from the Jersey request context.
|
RequestCoreRecoveryAPI |
Internal V2 API triggering recovery on a core.
|
RequestHandlerBase |
Base class for all request handlers.
|
RequestHandlerBase.HandlerMetrics |
Metrics for this handler.
|
RequestHandlers |
|
RequestHandlerUtils |
Common helper functions for RequestHandlers
|
RequestMetricHandling |
A request and response filter used to initialize and report per-request metrics.
|
RequestMetricHandling.PostRequestMetricsFilter |
Adjusts post-request metrics (timing, etc.)for individual Jersey requests.
|
RequestMetricHandling.PreRequestMetricsFilter |
Sets up the metrics-context for individual requests
|
RequestParams |
The class encapsulates the request time parameters .
|
RequestParams.ParamSet |
|
RequestParams.VersionedParams |
|
RequestRateLimiter |
Handles rate limiting for a specific request type.
|
RequestSyncShardAPI |
Internal V2 API used to request a core sync with its shard leader.
|
RequestUtil |
|
ReRankCollector |
|
ReRankCollector.BoostedComp |
|
ReRankOperator |
|
ReRankQParserPlugin |
|
ReRankScaler |
|
ReRankScaler.MinMaxExplain |
|
ReRankScaler.ReRankScalerExplain |
|
ReRankWeight |
A Weight used by reranking queries.
|
ResponseBuilder |
This class is experimental and will be changing in the future.
|
ResponseLogComponent |
Adds to the log file the document IDs that are sent in the query response.
|
ResponseUtils |
Response helper methods.
|
RestManager |
Supports runtime mapping of REST API endpoints to ManagedResource implementations; endpoints can
be registered at either the /schema or /config base paths, depending on which base path is more
appropriate for the type of managed resource.
|
RestManager.ManagedEndpoint |
Request handling needs a lightweight object to delegate a request to.
|
RestManager.Registry |
Per-core registry of ManagedResources found during core initialization.
|
RestoreCmd |
|
RestoreCollectionAPI |
V2 API for restoring data into a collection
|
RestoreCollectionAPI.RestoreCollectionRequestBody |
Request body for the v2 "restore collection" API.
|
RestoreCore |
V2 API implementation for restoring a previously taken backup to a core
|
RestoreCore |
|
ResultContext |
A class to hold the QueryResult and the Query
|
ResultEntry |
|
ReturnFields |
A class representing the return fields
|
ReversedWildcardFilter |
This class produces a special form of reversed tokens, suitable for better handling of leading
wildcards.
|
ReversedWildcardFilterFactory |
|
ReverseOrdFieldSource |
Obtains the ordinal of the field value from LeafReader.getSortedDocValues(java.lang.String) and reverses the order.
|
RollbackUpdateCommand |
|
RoutedAlias |
|
RoutedAlias.Action |
|
RoutedAliasUpdateProcessor |
Distributes update requests to a series of collections partitioned by a "routing" field.
|
RptWithGeometrySpatialField |
A Solr Spatial FieldType based on CompositeSpatialStrategy .
|
RTimer |
A simple timer.
|
RTimer.TimerImpl |
|
RTimerTree |
A recursive timer.
|
RubyResponseWriter |
|
RuleBasedAuthorizationPlugin |
Original implementation of Rule Based Authz plugin which configures user/role mapping in the
security.json configuration
|
RuleBasedAuthorizationPluginBase |
Base class for rule based authorization plugins
|
RunExampleTool |
Supports an interactive session with the user to launch (or relaunch the -e cloud example)
|
RunUpdateProcessorFactory |
Executes the update commands using the underlying UpdateHandler.
|
SafeXMLParsing |
Some utility methods for parsing XML in a safe way.
|
SampleDocuments |
|
SampleDocumentsLoader |
|
SchemaAware |
An interface that can be extended to provide a callback mechanism for informing an IndexSchema instance of changes to it, dynamically performed at runtime.
|
SchemaBulkModifyAPI |
V2 APIs for creating, updating, or deleting individual components in a collection's schema.
|
SchemaCodecFactory |
Per-field CodecFactory implementation, extends Lucene's and returns postings format
implementations according to the schema configuration.
|
SchemaDesignerAPI |
All V2 APIs that have a prefix of /api/schema-designer/
|
SchemaDesignerConstants |
|
SchemaField |
Encapsulates all information about a Field in a Solr Schema
|
SchemaHandler |
|
SchemaManager |
A utility class to manipulate schema using the bulk mode.
|
SchemaManager.OpType |
|
SchemaSimilarityFactory |
SimilarityFactory that returns a global PerFieldSimilarityWrapper that
delegates to the field type, if it's configured.
|
SchemaSuggester |
|
SchemaXmlResponseWriter |
|
SchemaXmlWriter |
|
ScoreAugmenter |
Simple Augmenter that adds the score
|
ScoreJoinQParserPlugin |
Create a query-time join query with scoring.
|
ScoreOrderFragmentsBuilder |
|
SearchComponent |
TODO!
|
SearchGroupsFieldCommand |
Creates all the collectors needed for the first phase and how to handle the results.
|
SearchGroupsFieldCommand.Builder |
|
SearchGroupsFieldCommandResult |
|
SearchGroupShardResponseProcessor |
Concrete implementation for merging SearchGroup instances from shard responses.
|
SearchGroupsRequestFactory |
|
SearchGroupsResultTransformer |
Implementation for transforming SearchGroup into a NamedList structure and visa
versa.
|
SearchHandler |
Refer SOLR-281
|
SecurityConfHandler |
|
SecurityConfHandler.SecurityConfig |
Object to hold security.json as nested Map<String,Object> and optionally its
version.
|
SecurityConfHandlerLocal |
Security Configuration Handler which works on standalone local files
|
SecurityConfHandlerZk |
Security Configuration Handler which works with Zookeeper
|
SecurityPluginHolder<T> |
|
SegmentsInfoRequestHandler |
This handler exposes information about last commit generation segments
|
ServletInputStreamWrapper |
Provides a convenient extension of the ServletInputStream class that can be subclassed by
developers wishing to adapt the behavior of a Stream.
|
ServletOutputStreamWrapper |
Provides a convenient extension of the ServletOutputStream class that can be subclassed
by developers wishing to adapt the behavior of a Stream.
|
ServletUtils |
Various Util methods for interaction on servlet level, i.e.
|
ServletUtils.ClosedServletInputStream |
|
ServletUtils.ClosedServletOutputStream |
|
SetAliasPropCmd |
|
Sha256AuthenticationProvider |
|
Shard |
|
Shard.ShardState |
|
ShardAugmenterFactory |
|
ShardAugmenterFactory.Style |
|
ShardBackupId |
Represents the ID of a particular backup point for a particular shard.
|
ShardBackupMetadata |
Represents the shard-backup metadata file.
|
ShardBackupMetadata.BackedFile |
|
ShardDoc |
|
ShardFieldSortedHitQueue |
|
ShardHandler |
|
ShardHandlerFactory |
|
ShardMetrics |
Shard-level metrics.
|
ShardRequest |
|
ShardRequestFactory |
Responsible for creating shard requests to the shards in the cluster to perform distributed
grouping.
|
ShardResponse |
|
ShardResponseProcessor |
Responsible for processing shard responses.
|
ShardResultTransformer<T,R> |
A ShardResultTransformer is responsible for transforming a grouped shard result into
group related structures (such as TopGroups and SearchGroup ) and visa versa.
|
ShowFileRequestHandler |
This handler uses the RawResponseWriter to give client access to files inside ${solr.home}/conf
|
ShutdownAwareDirectory |
CachingDirectoryFactory will call this method rather than Directory.close() on
shutdown if a Directory implements this interface.
|
Signature |
|
SignatureUpdateProcessorFactory |
|
SignificantTermsQParserPlugin |
|
SimilarityFactory |
A factory interface for configuring a Similarity in the Solr schema.xml.
|
SimpleAggValueSource |
|
SimpleBoundaryScanner |
|
SimpleEndResultTransformer |
|
SimpleFacets |
A class that generates simple Facet information for a request.
|
SimpleFacets.CountPair<K extends Comparable<? super K>,V extends Comparable<? super V>> |
A simple key=>val pair whose natural order is such that higher vals come before lower
vals.
|
SimpleFacets.ParsedParams |
|
SimpleFragListBuilder |
|
SimpleFragmentsBuilder |
|
SimpleMergePolicyFactory |
|
SimpleMLTQParser |
|
SimplePlacementContextImpl |
Implementation of PlacementContext that uses SimpleClusterAbstractionsImpl to
create components necessary for the placement plugins to use.
|
SimplePlacementFactory |
|
SimplePlacementFactory.SimplePlacementPlugin |
|
SimplePostTool |
Deprecated.
|
SimplePostTool.PageFetcherResult |
Utility class to hold the result form a page fetch
|
SimplePreAnalyzedParser |
|
SimplePropagator |
|
SimpleQParserPlugin |
Create a query from the input value that will be parsed by Lucene's SimpleQueryParser.
|
SimpleTextCodecFactory |
|
SimpleUpdateProcessorFactory |
A base class for writing a very simple UpdateProcessor without worrying too much about the API.
|
SingleCoreStatusAPI |
V2 API for checking the status of a specific core.
|
SingleFragListBuilder |
|
SizeLimitedDistributedMap |
A size limited distributed map maintained in zk.
|
SkipExistingDocumentsProcessorFactory |
This Factory generates an UpdateProcessor that will (by default) skip inserting new documents if
there already exists a document with the same uniqueKey value in the index.
|
SliceMutator |
|
SlotAcc |
Accumulates statistics separated by a slot number.
|
SlotAcc.DoubleFuncSlotAcc |
|
SlotAcc.FuncSlotAcc |
|
SlotAcc.IntSlotAcc |
|
SlotAcc.LongFuncSlotAcc |
|
SlotAcc.Resizer |
|
SlotAcc.SlotContext |
Incapsulates information about the current slot, for Accumulators that may want additional info
during collection.
|
SlowCompositeReaderWrapper |
This class forces a composite reader (eg a MultiReader or DirectoryReader ) to
emulate a LeafReader .
|
SmileResponseWriter |
|
SmileResponseWriter.SmileWriter |
|
SnapShooter |
Provides functionality equivalent to the snapshooter script This is no longer used in standard
replication.
|
SnapShooter.CoreSnapshotResponse |
|
SnapshotBackupAPI |
V2 endpoint for Backup API used for User-Managed clusters and Single-Node Installation.
|
SnapshotBackupAPI.BackupReplicationRequestBody |
|
SnapshotBackupAPI.BackupReplicationResponse |
|
SolrAnalyzer |
|
SolrApacheHttpRequestCarrier |
An OpenTracing Carrier for injecting Span context through an Apache HttpRequest
|
SolrAuthenticationException |
|
SolrBoundaryScanner |
|
SolrCache<K,V> |
Primary API for dealing with Solr's internal caches.
|
SolrCache.State |
Enumeration of possible States for cache instances.
|
SolrCacheBase |
Common base class of reusable functionality for SolrCaches
|
SolrCacheBase.AutoWarmCountRef |
Decides how many things to autowarm based on the size of another cache
|
SolrCLI |
Command-line utility for working with Solr.
|
SolrCLI.AssertionFailureException |
|
SolrCmdDistributor |
Used for distributing commands from a shard leader to its replicas.
|
SolrCmdDistributor.ForwardNode |
|
SolrCmdDistributor.Node |
|
SolrCmdDistributor.Req |
|
SolrCmdDistributor.Response |
|
SolrCmdDistributor.SolrError |
|
SolrCmdDistributor.StdNode |
|
SolrCollection |
Represents a Collection in SolrCloud (unrelated to Collection that uses the
nicer name).
|
SolrComparisonBoolFunction |
Refines ComparisonBoolFunction to compare based on a 'long' or 'double' depending on if
the any of the FunctionValues are LongDocValues .
|
SolrComparisonBoolFunction.Compare |
|
SolrConfig |
Provides a static reference to a Config object modeling the main configuration data for a Solr
instance -- typically found in "solrconfig.xml".
|
SolrConfig.HttpCachingConfig |
|
SolrConfig.HttpCachingConfig.LastModFrom |
|
SolrConfig.PluginOpts |
|
SolrConfig.SolrPluginInfo |
|
SolrConfig.UpdateHandlerInfo |
|
SolrConfigHandler |
|
SolrCore |
SolrCore got its name because it represents the "core" of Solr -- one index and everything needed
to make it work.
|
SolrCore.Provider |
Provides the core instance if the core instance is still alive.
|
SolrCore.RawWriter |
|
SolrCoreAware |
|
SolrCoreContainerReporter |
|
SolrCoreInitializationException |
|
SolrCoreMetricManager |
|
SolrCoreParser |
Assembles a QueryBuilder which uses Query objects from Solr's search module in
addition to Query objects supported by the Lucene CoreParser .
|
SolrCoreReporter |
|
SolrCores |
|
SolrCoreState |
The state in this class can be easily shared between SolrCores across SolrCore reloads.
|
SolrCoreState.CoreIsClosedException |
|
SolrCoreState.IndexWriterCloser |
|
SolrDefaultStreamFactory |
A default collection of mappings, used to convert strings into stream expressions.
|
SolrDelegateRegistryMetricsContext |
This class represents a metrics context that is delegate aware in that it is aware of multiple
metric registries, a primary and a delegate.
|
SolrDeletionPolicy |
Standard Solr deletion policy that allows reserving index commit points for certain amounts of
time to support features such as index replication or snapshotting directly out of a live index
directory.
|
SolrDispatchFilter |
This filter looks at the incoming URL maps them to handlers defined in solrconfig.xml
|
SolrDispatchFilter.Action |
Enum to define action that needs to be processed.
|
SolrDispatchFilter.HttpSolrCallFactory |
internal API
|
SolrDocumentFetcher |
A helper class of SolrIndexSearcher for stored Document related
matters including DocValue substitutions.
|
SolrEncoder |
|
SolrEnvironment |
It is possible to define an environment code when starting Solr, through
-Dsolr.environment=prod|stage|test|dev or by setting the cluster property "environment".
|
SolrEventListener |
|
SolrFieldCacheBean |
A SolrInfoBean that provides introspection of the Solr FieldCache
|
SolrFormatter |
|
SolrFragListBuilder |
|
SolrFragmenter |
|
SolrFragmentsBuilder |
|
SolrGraphiteReporter |
Metrics reporter that wraps GraphiteReporter .
|
SolrHighlighter |
|
SolrIndexConfig |
This config object encapsulates IndexWriter config params, defined in the <indexConfig>
section of solrconfig.xml
|
SolrIndexSearcher |
SolrIndexSearcher adds schema awareness and caching functionality over IndexSearcher .
|
SolrIndexSearcher.DocsEnumState |
|
SolrIndexSearcher.LimitExceededFromScorerException |
Thrown when CommonParams.TIME_ALLOWED is exceeded.
|
SolrIndexSearcher.ProcessedFilter |
|
SolrIndexSplitter |
|
SolrIndexSplitter.SplitMethod |
|
SolrIndexWriter |
An IndexWriter that is configured via Solr config mechanisms.
|
SolrInfoBean |
Interface for getting various ui friendly strings for use by objects which are 'pluggable' to
make server administration easier.
|
SolrInfoBean.Category |
Category of Solr component.
|
SolrInfoBean.Group |
Top-level group of beans or metrics for a subsystem.
|
SolrInfoMBeanHandler |
A request handler that provides info about all registered SolrInfoMBeans.
|
SolrJacksonAnnotationInspector |
this class provides a mapping between Solr's JsonProperty annotation to a corresponding
annotation in jackson see SOLR-13841 for more details
|
SolrJacksonMapper |
Customizes the ObjectMapper settings used for serialization/deserialization in Jersey
|
SolrJacksonMapper.NamedListSerializer |
|
SolrJettyRequestCarrier |
An OpenTracing Carrier for injecting Span context through a Jetty Request
|
SolrJmxReporter |
A SolrMetricReporter that finds (or creates) a MBeanServer from the given configuration
and registers metrics to it with JMX.
|
SolrLogAuditLoggerPlugin |
Audit logger that writes to the Solr log.
|
SolrLogPostTool |
Deprecated.
|
SolrMetricInfo |
Wraps meta-data for a metric.
|
SolrMetricManager |
This class maintains a repository of named MetricRegistry instances, and provides several
helper methods for managing various aspects of metrics reporting:
registry creation, clearing and removal,
creation of most common metric implementations,
management of SolrMetricReporter -s specific to a named registry.
|
SolrMetricManager.AndFilter |
An implementation of MetricFilter that selects metrics that match all filters in a list
of filters.
|
SolrMetricManager.GaugeWrapper<T> |
This is a wrapper for Gauge metrics, which are usually implemented as lambdas that
often keep a reference to their parent instance.
|
SolrMetricManager.OrFilter |
An implementation of MetricFilter that selects metrics that match any filter in a list
of filters.
|
SolrMetricManager.PrefixFilter |
An implementation of MetricFilter that selects metrics with names that start with one
of prefixes.
|
SolrMetricManager.RegexFilter |
An implementation of MetricFilter that selects metrics with names that match regular
expression patterns.
|
SolrMetricManager.ResolutionStrategy |
Potential conflict resolution strategies when attempting to register a new metric that already
exists
|
SolrMetricProducer |
|
SolrMetricReporter |
Interface for 'pluggable' metric reporters.
|
SolrMetricsContext |
This class represents a metrics context that ties together components with the same life-cycle
and provides convenient access to the metric registry.
|
SolrNodeKeyPair |
Creates and mediates access to the CryptoKeys.RSAKeyPair used by this Solr node.
|
SolrPackage |
Describes a package (along with all released versions) as it appears in a repository.
|
SolrPackage.Artifact |
|
SolrPackage.Command |
|
SolrPackage.Manifest |
|
SolrPackage.Plugin |
|
SolrPackage.SolrPackageRelease |
|
SolrPackageInstance |
Describes one instance of a package as it exists in Solr when installed.
|
SolrPackageLoader |
The class that holds a mapping of various packages and classloaders
|
SolrPaths |
Utility methods about paths in Solr.
|
SolrPaths.AllowPathBuilder |
Builds a set of allowed Path .
|
SolrPluginUtils |
Utilities that may be of use to RequestHandlers.
|
SolrPluginUtils.DisjunctionMaxQueryParser |
A subclass of SolrQueryParser that supports aliasing fields for constructing
DisjunctionMaxQueries.
|
SolrPluginUtils.DisjunctionMaxQueryParser.Alias |
A simple container for storing alias info
|
SolrQueryBuilder |
|
SolrQueryParser |
Solr's default query parser, a schema-driven superset of the classic lucene query parser.
|
SolrQueryParserBase |
This class is overridden by QueryParser in QueryParser.jj and acts to separate the majority of
the Java code from the .jj grammar file.
|
SolrQueryParserBase.MagicFieldName |
Identifies the list of all known "magic fields" that trigger special parsing behavior
|
SolrQueryParserBase.RawQuery |
|
SolrQueryParserBase.SynonymQueryStyle |
Query strategy when analyzed query terms overlap the same position (ie synonyms) consider if
pants and khakis are query time synonyms
|
SolrQueryRequest |
Container for a request to execute a query.
|
SolrQueryRequestBase |
Base implementation of SolrQueryRequest that provides some convenience methods for
accessing parameters, and manages an IndexSearcher reference.
|
SolrQueryResponse |
SolrQueryResponse is used by a query handler to return the response to a query
request.
|
SolrRangeQuery |
|
SolrReporter |
Implementation of ScheduledReporter that reports metrics from selected registries and
sends them periodically as update requests to a selected Solr collection and to a configured
handler.
|
SolrReporter.Builder |
|
SolrReporter.Report |
Specification of what registries and what metrics to send.
|
SolrRequestAuthorizer |
A JAX-RS request filter that blocks or allows requests based on the authorization plugin
configured in security.json.
|
SolrRequestHandler |
Implementations of SolrRequestHandler are called to handle query requests.
|
SolrRequestInfo |
Information about the Solr request/response held in a ThreadLocal .
|
SolrRequestParsers |
|
SolrResourceLoader |
|
SolrResourceLoader.SolrFileInputStream |
|
SolrResourceNotFoundException |
|
SolrResponseUtil |
|
SolrReturnFields |
The default implementation of return fields parsing for Solr.
|
SolrReturnFields.FIELD_SOURCES |
|
SolrSlf4jReporter |
Metrics reporter that wraps Slf4jReporter .
|
SolrSnapshotManager |
This class provides functionality required to handle the data files corresponding to Solr
snapshots.
|
SolrSnapshotMetaDataManager |
This class is responsible to manage the persistent snapshots meta-data for the Solr indexes.
|
SolrSnapshotMetaDataManager.SnapshotMetaData |
A class defining the meta-data for a specific snapshot.
|
SolrSpanQueryBuilder |
|
SolrSpellChecker |
|
SolrSuggester |
Responsible for loading the lookup and dictionary Implementations specified by the SolrConfig.
|
SolrXmlConfig |
Loads solr.xml .
|
SolrZkServer |
|
SortableTextField |
SortableTextField is a specialized form of TextField that supports Sorting
and ValueSource functions, using docValues built from the first
maxCharsForDocValues characters of the original (pre-analyzed) String values of this
field.
|
SortedDateStatsValues |
|
SortedIntDocSet |
A simple sorted int[] array implementation of DocSet , good for small sets.
|
SortedNumericStatsValues |
|
SortingMergePolicy |
|
SortingMergePolicyFactory |
|
SortSpec |
SortSpec encapsulates a Lucene Sort and a count of the number of documents to return.
|
SortSpecParsing |
|
SpatialBoxQParserPlugin |
|
SpatialFilterQParser |
|
SpatialFilterQParserPlugin |
Creates a spatial Filter based on the type of spatial point used.
|
SpatialHeatmapFacets |
A 2D spatial faceting summary of a rectangular region.
|
SpatialHeatmapFacets.HeatmapFacet |
|
SpatialOptions |
|
SpatialQueryable |
Indicate that the implementing class is capable of generating a Query against spatial resources.
|
SpatialRecursivePrefixTreeFieldType |
|
SpatialUtils |
Utility methods pertaining to spatial.
|
SpellCheckCollation |
|
SpellCheckCollator |
|
SpellCheckComponent |
A SearchComponent implementation which provides support for spell checking and suggestions using
the Lucene contributed SpellChecker.
|
SpellCheckCorrection |
|
SpellCheckMergeData |
|
SpellingOptions |
|
SpellingQueryConverter |
Converts the query string to a Collection of Lucene tokens using a regular expression.
|
SpellingResult |
Implementations of SolrSpellChecker must return suggestions as SpellResult instance.
|
SplitCoreAPI |
V2 API for splitting a single core into multiple pieces
|
SplitCoreAPI.SplitCorePayload |
|
SplitIndexCommand |
A split index command encapsulated in an object.
|
SplitShardAPI |
V2 API for splitting an existing shard up into multiple pieces.
|
SplitShardCmd |
SolrCloud logic for splitting a shard.
|
SquaredEuclideanFunction |
While not strictly a distance, the Sq.
|
SSLConfigurations |
Dedicated object to handle Solr configurations
|
SSLConfigurations.SysProps |
|
SSLConfigurationsFactory |
|
SSLCredentialProvider |
Interface for different source of SSL configurations.
|
SSLCredentialProvider.CredentialType |
|
SSLCredentialProviderFactory |
Class responsible to build SSL credential providers
|
StandardDirectoryFactory |
Directory provider which mimics original Solr FSDirectory based
behavior.
|
StandardIndexReaderFactory |
Default IndexReaderFactory implementation.
|
StandardRequestHandler |
Deprecated. |
StartupLoggingUtils |
Handles programmatic modification of logging during startup
|
Stats |
Used to hold statistics about some SolrCloud operations.
|
Stats.FailedOp |
|
Stats.Stat |
|
StatsCache |
This class represents a cache of global document frequency information for selected terms.
|
StatsCache.StatsCacheMetrics |
|
StatsComponent |
Stats component calculates simple statistics on numeric field values
|
StatsField |
Models all of the information associated with a single StatsParams.STATS_FIELD instance.
|
StatsField.HllOptions |
Helper Struct for parsing and encapsulating all of the options relaed to building a HLL
|
StatsField.Stat |
An enumeration representing the sumer set of all possible stat values that can be computed.
|
StatsSource |
The purpose of this class is only to provide two pieces of information necessary to create Weight from a Query , that is TermStatistics for a term and CollectionStatistics for the whole collection.
|
StatsUtil |
Various utilities for de/serialization of term stats and collection stats.
|
StatsValues |
StatsValue defines the interface for the collection of statistical values about fields and
facets.
|
StatsValuesFactory |
|
StatusTool |
|
StddevAgg |
|
StoredFieldsShardRequestFactory |
|
StoredFieldsShardResponseProcessor |
Concrete implementation for processing the stored field values from shard responses.
|
StrAggValueSource |
|
StreamHandler |
Solr Request Handler for streaming data.
|
StreamHandler.DaemonCollectionStream |
|
StreamHandler.DaemonResponseStream |
|
StreamHandler.DummyErrorStream |
|
StreamHandler.ExpressibleHolder |
|
StreamHandler.TimerStream |
|
StreamingSolrClients |
|
StrField |
|
StrFieldSource |
|
StringDistanceFunction |
|
StrParser |
Simple class to help with parsing a string.
|
SubQueryAugmenterFactory |
This transformer executes subquery per every result document.
|
SubstringBytesRefFilter |
An implementation of Predicate which returns true if the BytesRef contains a given
substring.
|
SuggestComponent |
SuggestComponent: interacts with multiple SolrSuggester to serve up suggestions
Responsible for routing commands and queries to the appropriate SolrSuggester and for
initializing them as specified by SolrConfig
|
Suggester |
|
SuggesterOptions |
Encapsulates the inputs required to be passed on to the underlying suggester in SolrSuggester
|
SuggesterParams |
|
SuggesterResult |
Encapsulates the results returned by the suggester in SolrSuggester
|
SuggestQueryConverter |
Passes the entire query string to the configured analyzer as-is.
|
SumAgg |
|
SumAgg.Merger |
|
SumsqAgg |
|
SurroundQParserPlugin |
Plugin for lucene Surround query parser, bringing SpanQuery support to Solr.
|
SwapCores |
|
SweetSpotSimilarityFactory |
Factory for SweetSpotSimilarity .
|
SwitchQParserPlugin |
A QParserPlugin that acts like a "switch/case" statement.
|
SyncShard |
V2 API implementation for triggering a shard-sync operation within a particular collection and
shard.
|
SyncStrategy |
|
SyntaxError |
Simple checked exception for parsing errors
|
SysPropSSLCredentialProvider |
System property based SSL configuration provider
|
SystemIdResolver |
This is a helper class to support resolving of XIncludes or other hrefs inside XML files on top
of a ResourceLoader .
|
SystemInfoHandler |
This handler returns system info
|
TabularResponseWriter |
Base response writer for table-oriented data
|
TagClusterReducer |
|
Tagger |
Tags maximum string of words in a corpus.
|
TaggerRequestHandler |
Scans posted text, looking for matching strings in the Solr index.
|
TaggingAttribute |
Attribute used by the Tagger to decide if a token can start a new tag .
|
TaggingAttributeImpl |
|
TagLL |
This is a Tag -- a startOffset, endOffset and value.
|
TaskManagementHandler |
Abstract class which serves as the root of all task managing handlers
|
TemplateUpdateProcessorFactory |
Adds new fields to documents based on a template pattern specified via Template.field request
parameters (multi-valued) or 'field' value specified in initArgs.
|
TemplateUpdateProcessorFactory.Resolved |
|
TermQParserPlugin |
Create a single term query from the input value equivalent to readableToIndexed().
|
TermsComponent |
Return TermEnum information, useful for things like auto suggest.
|
TermsComponent.TermCountComparator |
Comparator for TermsResponse.Term sorting This
sorts term by frequency in descending order
|
TermsComponent.TermsHelper |
|
TermsQParserPlugin |
Finds documents whose specified field has any of the specified values.
|
TermStats |
Modifiable version of TermStatistics useful for aggregation of per-shard stats.
|
TermVectorComponent |
Return term vectors for the documents in a query result set.
|
TestInjection |
Allows random faults to be injected in running code during test runs.
|
TestInjection.Hook |
|
TestInjection.TestShutdownFailError |
|
TextField |
TextField is the basic type for configurable text analysis.
|
TextLogisticRegressionQParserPlugin |
Returns an AnalyticsQuery implementation that performs one Gradient Descent iteration of a result
set to train a logistic regression model
|
TextProfileSignature |
This implementation is copied from Apache Nutch.
|
TextResponseWriter |
Base class for text-oriented response writers.
|
ThreadCpuTimer |
Allows tracking information about the current thread using the JVM's built-in management bean
ThreadMXBean .
|
ThreadDumpHandler |
|
TieredMergePolicyFactory |
|
TimeAllowedLimit |
Enforces a wall clock based timeout on a given SolrQueryRequest.
|
TimedVersionBucket |
This implementation uses lock and condition and will throw exception if it can't obtain the lock
within lockTimeoutMs .
|
TimeOut |
|
TimeRoutedAlias |
Holds configuration for a routed alias, and some common code and constants.
|
TimestampUpdateProcessorFactory |
An update processor that adds a newly generated Date value of "NOW" to any document
being added that does not already have a value in the specified field.
|
TimeZoneUtils |
Simple utilities for working with TimeZones
|
Token |
Describes the input token stream.
|
Token |
Deprecated. |
TokenizerChain |
An analyzer that uses a tokenizer and a list of token filters to create a TokenStream.
|
TokenMgrError |
Token Manager Error.
|
TolerantUpdateProcessor |
Suppresses errors for individual add/delete commands within a single request.
|
TolerantUpdateProcessorFactory |
Suppresses errors for individual add/delete commands within a single request.
|
Tool |
|
ToolBase |
|
TopGroupsFieldCommand |
Defines all collectors for retrieving the second phase and how to handle the collector result.
|
TopGroupsFieldCommand.Builder |
|
TopGroupsResultTransformer |
Implementation for transforming TopGroups and TopDocs into a NamedList
structure and vice versa.
|
TopGroupsShardRequestFactory |
|
TopGroupsShardResponseProcessor |
Concrete implementation for merging TopGroups instances from shard responses.
|
TopLevelJoinQuery |
JoinQuery implementation using global (top-level) DocValues ordinals to efficiently
compare values in the "from" and "to" fields.
|
TopLevelJoinQuery.BitsetBounds |
|
TracerConfigurator |
Produces an OpenTracing Tracer from configuration.
|
TraceUtils |
Utilities for distributed tracing.
|
TransactionLog |
Log Format: List{Operation, Version, ...} ADD, VERSION, DOC DELETE, VERSION, ID_BYTES
DELETE_BY_QUERY, VERSION, String
|
TransactionLog.ChannelFastInputStream |
|
TransactionLog.ChannelInputStreamOpener |
|
TransactionLog.OutputStreamOpener |
|
TransactionLog.ReverseReader |
|
TransformerFactory |
New instance for each request
|
TransformerFactory.FieldRenamer |
|
TransientSolrCoreCache |
Deprecated. |
TransientSolrCoreCacheDefault |
Deprecated. |
TransientSolrCores |
Deprecated. |
TrieDateField |
Deprecated.
|
TrieDoubleField |
Deprecated.
|
TrieField |
Deprecated.
|
TrieFloatField |
Deprecated.
|
TrieIntField |
Deprecated.
|
TrieLongField |
Deprecated.
|
TrimFieldUpdateProcessorFactory |
Trims leading and trailing whitespace from any CharSequence values found in fields matching the
specified conditions and returns the resulting String.
|
TruncateFieldUpdateProcessorFactory |
Truncates any CharSequence values found in fields matching the specified conditions to a maximum
character length.
|
TSTLookupFactory |
Factory for TSTLookup
|
UnifiedSolrHighlighter |
Highlighter impl that uses UnifiedHighlighter
|
UnifiedSolrHighlighter.SolrExtendedUnifiedHighlighter |
|
UnInvertedField |
Final form of the un-inverted field: Each document points to a list of term numbers that are
contained in that document.
|
UnInvertedField.Callback |
|
UnInvertedFieldAcc |
|
UninvertingReader |
A FilterReader that exposes indexed values as if they also had docvalues.
|
UninvertingReader.FieldCacheStats |
Return information about the backing cache
|
UninvertingReader.Type |
Specifies the type of uninversion to apply for the field.
|
UniqFieldsUpdateProcessorFactory |
Removes duplicate values found in fields matching the specified conditions.
|
UniqueAgg |
|
UniqueBlockAgg |
|
UniqueBlockAgg.UniqueBlockSlotAcc |
|
UniqueBlockFieldAgg |
|
UniqueBlockQueryAgg |
|
UnloadCore |
V2 API implementation for unloading a Solr core.
|
UpdateAPI |
All v2 APIs that share a prefix of /update
|
UpdateCommand |
An index update command encapsulated in an object (Command pattern)
|
UpdateHandler |
UpdateHandler handles requests to change the index (adds, deletes, commits,
optimizes, etc).
|
UpdateLog |
This holds references to the transaction logs.
|
UpdateLog.DBQ |
Holds the query and the version for a DeleteByQuery command
|
UpdateLog.DeleteUpdate |
|
UpdateLog.LogPtr |
|
UpdateLog.RecoveryInfo |
|
UpdateLog.State |
|
UpdateLog.SyncLevel |
|
UpdateLog.Update |
|
UpdateRequestHandler |
UpdateHandler that uses content-type to pick the right Loader
|
UpdateRequestProcessor |
This is a good place for subclassed update handlers to process the document before it is indexed.
|
UpdateRequestProcessorChain |
Manages a chain of UpdateRequestProcessorFactories.
|
UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder |
|
UpdateRequestProcessorChain.LazyUpdateProcessorFactoryHolder.LazyUpdateRequestProcessorFactory |
|
UpdateRequestProcessorChain.ProcessorInfo |
|
UpdateRequestProcessorFactory |
A factory to generate an UpdateRequestProcessor for each request.
|
UpdateRequestProcessorFactory.RunAlways |
A marker interface for UpdateRequestProcessorFactory implementations indicating that the
factory should be used even if the update.distrib parameter would otherwise cause it to not be
run.
|
UpdateShardHandler |
|
UpdateShardHandlerConfig |
|
UpgradeIndexMergePolicyFactory |
|
UploadBlobAPI |
V2 API for uploading blobs into Solr's .system blobstore
|
UploadConfigSetAPI |
V2 API for uploading a new configset (or overwriting an existing one).
|
UploadConfigSetFileAPI |
V2 API for adding or updating a single file within a configset.
|
URLClassifyProcessor |
Update processor which examines a URL and outputs to various other fields characteristics of that
URL, including length, number of path levels, whether it is a top level URL (levels==0), whether
it looks like a landing/index page, a canonical representation of the URL (e.g.
|
URLClassifyProcessorFactory |
Creates URLClassifyProcessor
|
UUIDField |
This FieldType accepts UUID string values, as well as the special value of "NEW" which triggers
generation of a new random UUID.
|
UUIDUpdateProcessorFactory |
An update processor that adds a newly generated UUID value to any document being
added that does not already have a value in the specified field.
|
V2ApiUtils |
Utilities helpful for common V2 API declaration tasks.
|
V2HttpCall |
|
V2HttpCall.CompositeApi |
|
V2NodeLoggingAPI |
V2 API for getting log levels on an individual node.
|
V2UpdateRequestHandler |
|
ValueAugmenterFactory |
|
ValueAugmenterFactory.ValueAugmenter |
|
ValueSourceAugmenter |
Add values from a ValueSource (function query etc)
|
ValueSourceParser |
A factory that parses user queries to generate ValueSource instances.
|
ValueSourceRangeFilter |
RangeFilter over a ValueSource.
|
VarianceAgg |
|
VectorDistanceFunction |
Calculate the p-norm for a Vector.
|
VectorSimilaritySourceParser |
This class provides implementation for two variants for parsing function query vectorSimilarity
which is used to calculate the similarity between two vectors.
|
VerifiedUserRoles |
Interface used to pass verified user roles in a Principal object.
|
VersionBucket |
The default implementation which uses the intrinsic object monitor.
|
VersionBucket.CheckedFunction<T,R> |
|
VersionedFile |
|
VersionInfo |
|
VersionTool |
|
WeightedFragListBuilder |
|
WFSTLookupFactory |
Factory for WFSTCompletionLookup
|
WordBreakSolrSpellChecker |
A spellchecker that breaks and combines words.
|
WordBreakSolrSpellChecker.BreakSuggestionTieBreaker |
Specify a value on the "breakSuggestionTieBreaker" parameter.
|
WrappedQuery |
A simple query that wraps another query and implements ExtendedQuery.
|
WrapperMergePolicyFactory |
|
XmlConfigFile |
Wrapper around an XML DOM object to provide convenient accessors to it.
|
XMLLoader |
|
XmlOffsetCorrector |
Corrects offsets to adjust for XML formatted data.
|
XmlQParserPlugin |
|
XMLResponseWriter |
|
XMLWriter |
|
ZkCLI |
|
ZkClusterPluginsSource |
The plugin configurations are stored and retrieved from the ZooKeeper cluster properties, stored
at the ZkStateReader.CONTAINER_PLUGINS location This supports mutable configurations, and
management via the /cluster/plugin APIs
|
ZkConfigSetService |
SolrCloud Zookeeper ConfigSetService impl.
|
ZkContainer |
|
ZkController |
Handle ZooKeeper interactions.
|
ZkController.NotInClusterStateException |
Thrown during pre register process if the replica is not present in clusterstate
|
ZkController.ResourceModifiedInZkException |
|
ZkCpTool |
|
ZkDistributedCollectionLockFactory |
A distributed lock implementation using Zookeeper "directory" nodes created within a collection
znode hierarchy, for use with the distributed Collection API implementation.
|
ZkDistributedConfigSetLockFactory |
A distributed lock implementation using Zookeeper "directory" nodes created within a collection
znode hierarchy, for use with the distributed Collection API implementation.
|
ZkDistributedQueue |
A ZK-based distributed queue.
|
ZkIndexSchemaReader |
Keeps a ManagedIndexSchema up-to-date when changes are made to the serialized managed schema in
ZooKeeper
|
ZkIndexSchemaReader.SchemaWatcher |
|
ZkLsTool |
|
ZkMkrootTool |
|
ZkMvTool |
|
ZkRmTool |
|
ZkShardTerms |
Class used for interact with a ZK term node.
|
ZkSolrResourceLoader |
ResourceLoader that works with ZooKeeper.
|
ZkSolrResourceLoader.ZkByteArrayInputStream |
|
ZkStateWriter |
ZkStateWriter is responsible for writing updates to the cluster state stored in ZooKeeper for
collections each of which gets their own individual state.json in ZK.
|
ZkStateWriter.ZkWriteCallback |
|
ZkWriteCommand |
|
ZookeeperInfoHandler |
Zookeeper Info
|
ZookeeperReadAPI |
Exposes the content of the Zookeeper This is an expert feature that exposes the data inside the
back end zookeeper.This API may change or be removed in future versions.
|
ZookeeperReadAPI.AnnotatedStat |
|
ZookeeperReadAPI.ListZkChildrenResponse |
|
ZookeeperReadAPI.ZooKeeperFileResponse |
|
ZookeeperStatusHandler |
Zookeeper Status handler, talks to ZK using sockets and four-letter words
|