Modifier and Type | Class and Description |
---|---|
class |
BulkUdpService |
Modifier and Type | Interface and Description |
---|---|
interface |
Client
A client provides a one stop interface for performing actions/operations against the cluster.
|
Modifier and Type | Class and Description |
---|---|
class |
FilterClient
|
Modifier and Type | Class and Description |
---|---|
class |
NodeClient |
Modifier and Type | Class and Description |
---|---|
class |
AbstractClient |
Modifier and Type | Class and Description |
---|---|
class |
TransportClient
The transport client allows to create a client that is not part of the cluster, but simply connects to one
or more nodes directly by adding their respective addresses using
TransportClient.addTransportAddress(org.elasticsearch.common.transport.TransportAddress) . |
Modifier and Type | Class and Description |
---|---|
class |
InternalTransportClient |
Modifier and Type | Interface and Description |
---|---|
interface |
ClusterService
The cluster service allowing to both register for cluster state events (
ClusterStateListener )
and submit state update tasks (ClusterStateUpdateTask . |
Modifier and Type | Class and Description |
---|---|
class |
RoutingService
A
RoutingService listens to clusters state. |
Modifier and Type | Class and Description |
---|---|
class |
InternalClusterService |
Modifier and Type | Interface and Description |
---|---|
interface |
ReleasableBytesReference
A bytes reference that needs to be released once its usage is done.
|
Modifier and Type | Class and Description |
---|---|
class |
ReleasablePagedBytesReference
An extension to
PagedBytesReference that requires releasing its content. |
Modifier and Type | Interface and Description |
---|---|
interface |
LifecycleComponent<T> |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLifecycleComponent<T> |
Modifier and Type | Method and Description |
---|---|
static Releasable |
Releasables.wrap(Iterable<Releasable> releasables)
Wrap several releasables into a single one.
|
static Releasable |
Releasables.wrap(Releasable... releasables) |
Modifier and Type | Method and Description |
---|---|
static void |
Releasables.close(boolean success,
Releasable... releasables)
Release the provided
Releasable s, ignoring exceptions if success is false. |
static void |
Releasables.close(Releasable... releasables)
Release the provided
Releasable s. |
static void |
Releasables.closeWhileHandlingException(Releasable... releasables)
Release the provided
Releasable s, ignoring exceptions. |
static Releasable |
Releasables.wrap(Releasable... releasables) |
Modifier and Type | Method and Description |
---|---|
static void |
Releasables.close(boolean success,
Iterable<Releasable> releasables)
Release the provided
Releasable s, ignoring exceptions if success is false. |
static void |
Releasables.close(Iterable<? extends Releasable> releasables)
Release the provided
Releasable s. |
static void |
Releasables.closeWhileHandlingException(Iterable<Releasable> releasables)
Release the provided
Releasable s, ignoring exceptions. |
static Releasable |
Releasables.wrap(Iterable<Releasable> releasables)
Wrap several releasables into a single one.
|
Modifier and Type | Class and Description |
---|---|
class |
FreqTermsEnum
A frequency terms enum that maintains a cache of docFreq, totalTermFreq, or both for repeated term lookup.
|
Constructor and Description |
---|
ReleaseChannelFutureListener(Releasable releasable) |
Modifier and Type | Interface and Description |
---|---|
static interface |
Recycler.V<T> |
Modifier and Type | Class and Description |
---|---|
static class |
NoneRecycler.NV<T> |
Modifier and Type | Interface and Description |
---|---|
interface |
BigArray
Base abstraction of an array.
|
interface |
ByteArray
Abstraction of an array of byte values.
|
interface |
DoubleArray
Abstraction of an array of double values.
|
interface |
FloatArray
Abstraction of an array of double values.
|
interface |
IntArray
Abstraction of an array of integer values.
|
interface |
LongArray
Abstraction of an array of long values.
|
interface |
ObjectArray<T>
Abstraction of an array of object values.
|
Modifier and Type | Class and Description |
---|---|
class |
BytesRefHash
Specialized hash table implementation similar to Lucene's BytesRefHash that maps
BytesRef values to ids.
|
class |
LongHash
Specialized hash table implementation similar to BytesRefHash that maps
long values to ids.
|
class |
LongObjectPagedHashMap<T>
A hash table from native longs to objects.
|
Modifier and Type | Class and Description |
---|---|
class |
ReleasableLock
Releasable lock used inside of Engine implementations
|
Modifier and Type | Interface and Description |
---|---|
interface |
XContentParser
Interface for pull - parsing
XContent see XContentType for supported types. |
Modifier and Type | Class and Description |
---|---|
class |
XContentBuilder |
Modifier and Type | Class and Description |
---|---|
class |
CborXContentParser |
Modifier and Type | Class and Description |
---|---|
class |
JsonXContentParser |
Modifier and Type | Class and Description |
---|---|
class |
SmileXContentParser |
Modifier and Type | Class and Description |
---|---|
class |
AbstractXContentParser |
Modifier and Type | Class and Description |
---|---|
class |
YamlXContentParser |
Modifier and Type | Interface and Description |
---|---|
interface |
Discovery
A pluggable module allowing to implement discovery of other nodes, publishing of the cluster
state to all nodes, electing a master of the cluster that raises cluster state change
events.
|
Modifier and Type | Class and Description |
---|---|
class |
DiscoveryService |
Modifier and Type | Class and Description |
---|---|
class |
LocalDiscovery |
Modifier and Type | Class and Description |
---|---|
class |
ZenDiscovery |
Modifier and Type | Interface and Description |
---|---|
interface |
ZenPing |
Modifier and Type | Class and Description |
---|---|
class |
ZenPingService |
Modifier and Type | Class and Description |
---|---|
class |
MulticastZenPing |
Modifier and Type | Class and Description |
---|---|
class |
UnicastZenPing |
Modifier and Type | Interface and Description |
---|---|
interface |
Gateway |
Modifier and Type | Class and Description |
---|---|
class |
GatewayService |
Modifier and Type | Class and Description |
---|---|
class |
LocalGateway |
Modifier and Type | Class and Description |
---|---|
class |
NoneGateway |
Modifier and Type | Interface and Description |
---|---|
interface |
HttpServerTransport |
Modifier and Type | Class and Description |
---|---|
class |
HttpServer |
Modifier and Type | Class and Description |
---|---|
class |
NettyHttpServerTransport |
Modifier and Type | Class and Description |
---|---|
class |
SnapshotIndexCommit
A snapshot index commit point.
|
class |
SnapshotIndexCommits
Represents a snapshot view of several commits.
|
Modifier and Type | Class and Description |
---|---|
static class |
Engine.Searcher |
class |
EngineSearcher
Searcher for an Engine
|
class |
FlushingRecoveryCounter
A special
RecoveryCounter that flushes the engine when all
recoveries have completed |
class |
RecoveryCounter
RecoveryCounter keeps tracks of the number of ongoing recoveries for a
particular
Store |
Modifier and Type | Method and Description |
---|---|
Releasable |
Engine.IndexThrottle.acquireThrottle() |
Modifier and Type | Interface and Description |
---|---|
interface |
AtomicFieldData
The thread safe
AtomicReader level cache of the data. |
interface |
AtomicGeoPointFieldData
AtomicFieldData specialization for geo points. |
interface |
AtomicNumericFieldData
Specialization of
AtomicFieldData for numeric data. |
interface |
AtomicOrdinalsFieldData
Specialization of
AtomicFieldData for data that is indexed with
ordinals. |
interface |
AtomicParentChildFieldData
Specialization of
AtomicFieldData for parent/child mappings. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAtomicOrdinalsFieldData |
class |
BinaryDVAtomicFieldData
AtomicFieldData impl on top of Lucene's binary doc values. |
class |
FSTBytesAtomicFieldData |
class |
GeoPointCompressedAtomicFieldData
Field data atomic impl for geo points with lossy compression.
|
static class |
GeoPointCompressedAtomicFieldData.Single
Assumes unset values are marked in bitset, and docId is used as the index to the value array.
|
class |
GeoPointDoubleArrayAtomicFieldData |
static class |
GeoPointDoubleArrayAtomicFieldData.Single
Assumes unset values are marked in bitset, and docId is used as the index to the value array.
|
class |
PagedBytesAtomicFieldData |
class |
ParentChildAtomicFieldData |
class |
SortedSetDVBytesAtomicFieldData
An
AtomicFieldData implementation that uses Lucene SortedSetDocValues . |
Modifier and Type | Class and Description |
---|---|
protected static class |
ChildrenQuery.ParentCollector |
protected static class |
ChildrenQuery.ParentScoreCollector |
protected static class |
ChildrenQuery.ParentScoreCountCollector |
class |
CustomQueryWrappingFilter
Forked from
QueryWrapperFilter to make sure the weight is only created once. |
Modifier and Type | Interface and Description |
---|---|
static interface |
Translog.Snapshot
A snapshot of the transaction log, allows to iterate over all the transaction log operations.
|
Modifier and Type | Class and Description |
---|---|
class |
FsChannelSnapshot |
Modifier and Type | Class and Description |
---|---|
class |
IndicesService |
Modifier and Type | Class and Description |
---|---|
class |
CircuitBreakerService
Interface for Circuit Breaker services, which provide breakers to classes
that load field data.
|
class |
HierarchyCircuitBreakerService
CircuitBreakerService that attempts to redistribute space between breakers
if tripped
|
class |
NoneCircuitBreakerService
Class that returns a breaker that never breaks
|
Modifier and Type | Class and Description |
---|---|
class |
IndicesClusterStateService |
Modifier and Type | Class and Description |
---|---|
class |
IndexingMemoryController |
Modifier and Type | Class and Description |
---|---|
class |
IndicesTTLService
A node level service that delete expired docs on node primary shards.
|
Modifier and Type | Class and Description |
---|---|
class |
MonitorService |
Modifier and Type | Class and Description |
---|---|
class |
JvmMonitorService |
Modifier and Type | Interface and Description |
---|---|
interface |
Node
A node represent a node within a cluster (cluster.name).
|
Modifier and Type | Class and Description |
---|---|
class |
InternalNode |
Modifier and Type | Class and Description |
---|---|
class |
PercolateContext |
Modifier and Type | Interface and Description |
---|---|
interface |
Repository
Snapshot repository interface.
|
Modifier and Type | Class and Description |
---|---|
class |
BlobStoreRepository
BlobStore - based implementation of Snapshot Repository
This repository works with any
BlobStore implementation. |
Modifier and Type | Class and Description |
---|---|
class |
FsRepository
Shared file system implementation of the BlobStoreRepository
Shared file system repository supports the following settings
location Path to the root of repository. |
Modifier and Type | Class and Description |
---|---|
class |
URLRepository
Read-only URL-based implementation of the BlobStoreRepository
This repository supports the following settings
url URL to the root of repository. |
Modifier and Type | Class and Description |
---|---|
class |
RestController |
Modifier and Type | Class and Description |
---|---|
class |
RiversManager |
class |
RiversService |
Modifier and Type | Class and Description |
---|---|
class |
RiverClusterService |
Modifier and Type | Class and Description |
---|---|
class |
RiversRouter |
Modifier and Type | Class and Description |
---|---|
class |
SearchService |
Modifier and Type | Class and Description |
---|---|
class |
Aggregator |
class |
FilteringBucketCollector
Filters a collection stream of docIds and related buckets using a sorted
list of valid bucket ordinals.
|
class |
NonCollectingAggregator
An aggregator that is not collected, this can typically be used when running an aggregation over a field that doesn't have
a mapping.
|
class |
RecordingBucketCollector
Abstraction for implementations that record a "collect" stream for subsequent play-back
|
class |
RecordingPerReaderBucketCollector
Records a "collect" stream for subsequent play-back using a per-segment
object to collect matches.
|
Modifier and Type | Class and Description |
---|---|
class |
BucketsAggregator |
class |
DeferringBucketCollector
Buffers the matches in a collect stream and can replay a subset of the collected buckets
to a deferred set of collectors.
|
class |
SingleBucketAggregator
A bucket aggregator that doesn't create new buckets.
|
Modifier and Type | Class and Description |
---|---|
class |
ParentToChildrenAggregator |
Modifier and Type | Class and Description |
---|---|
class |
FilterAggregator
Aggregate all docs that match a filter.
|
Modifier and Type | Class and Description |
---|---|
class |
FiltersAggregator |
Modifier and Type | Class and Description |
---|---|
class |
GeoHashGridAggregator
Aggregates data expressed as GeoHash longs (for efficiency's sake) but formats results as Geohash strings.
|
Modifier and Type | Class and Description |
---|---|
class |
GlobalAggregator |
Modifier and Type | Class and Description |
---|---|
class |
HistogramAggregator |
Modifier and Type | Class and Description |
---|---|
class |
MissingAggregator |
Modifier and Type | Class and Description |
---|---|
class |
NestedAggregator |
class |
ReverseNestedAggregator |
Modifier and Type | Class and Description |
---|---|
class |
RangeAggregator |
static class |
RangeAggregator.Unmapped |
Modifier and Type | Class and Description |
---|---|
class |
GlobalOrdinalsSignificantTermsAggregator
An global ordinal based implementation of significant terms, based on
SignificantStringTermsAggregator . |
static class |
GlobalOrdinalsSignificantTermsAggregator.WithHash |
class |
SignificantLongTermsAggregator |
class |
SignificantStringTermsAggregator
An aggregator of significant string values.
|
class |
SignificantTermsAggregatorFactory |
Modifier and Type | Class and Description |
---|---|
class |
DoubleTermsAggregator |
class |
GlobalOrdinalsStringTermsAggregator
An aggregator of string values that relies on global ordinals in order to build buckets.
|
static class |
GlobalOrdinalsStringTermsAggregator.LowCardinality
Variant of
GlobalOrdinalsStringTermsAggregator that resolves global ordinals post segment collection
instead of on the fly for each match.This is beneficial for low cardinality fields, because it can reduce
the amount of look-ups significantly. |
static class |
GlobalOrdinalsStringTermsAggregator.WithHash
Variant of
GlobalOrdinalsStringTermsAggregator that rebases hashes in order to make them dense. |
class |
LongTermsAggregator |
class |
StringTermsAggregator
An aggregator of string values.
|
class |
TermsAggregator |
Modifier and Type | Class and Description |
---|---|
class |
MetricsAggregator |
class |
NumericMetricsAggregator |
static class |
NumericMetricsAggregator.MultiValue |
static class |
NumericMetricsAggregator.SingleValue |
Modifier and Type | Class and Description |
---|---|
class |
AvgAggregator |
Modifier and Type | Class and Description |
---|---|
class |
CardinalityAggregator
An aggregator that computes approximate counts of unique values.
|
class |
HyperLogLogPlusPlus
Hyperloglog++ counter, implemented based on pseudo code from
http://static.googleusercontent.com/media/research.google.com/fr//pubs/archive/40671.pdf
and its appendix
https://docs.google.com/document/d/1gyjfMHy43U9OWBXxfaeG-3MjGzejW1dlpyMwEYAAWEI/view?fullscreen
This implementation is different from the original implementation in that it
uses a hash table instead of a sorted list for linear counting.
|
Modifier and Type | Class and Description |
---|---|
class |
GeoBoundsAggregator |
Modifier and Type | Class and Description |
---|---|
class |
MaxAggregator |
Modifier and Type | Class and Description |
---|---|
class |
MinAggregator |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPercentilesAggregator |
class |
PercentileRanksAggregator |
class |
PercentilesAggregator |
Modifier and Type | Class and Description |
---|---|
class |
ScriptedMetricAggregator |
Modifier and Type | Class and Description |
---|---|
class |
StatsAggegator |
Modifier and Type | Class and Description |
---|---|
class |
ExtendedStatsAggregator |
Modifier and Type | Class and Description |
---|---|
class |
SumAggregator |
Modifier and Type | Class and Description |
---|---|
class |
TopHitsAggregator |
Modifier and Type | Class and Description |
---|---|
class |
ValueCountAggregator
A field data based aggregator that counts the number of values a specific field has within the aggregation context.
|
Modifier and Type | Class and Description |
---|---|
class |
TermsStringOrdinalsFacetExecutor.ReaderAggregator |
Modifier and Type | Class and Description |
---|---|
static class |
InnerHitsContext.BaseInnerHits |
static class |
InnerHitsContext.NestedInnerHits |
static class |
InnerHitsContext.ParentChildInnerHits |
Modifier and Type | Class and Description |
---|---|
class |
ContextIndexSearcher
Context-aware extension of
IndexSearcher . |
class |
DefaultSearchContext |
class |
DocIdSetCollector |
class |
FilteredSearchContext |
class |
SearchContext |
class |
SubSearchContext |
Modifier and Type | Method and Description |
---|---|
void |
SearchContext.addReleasable(Releasable releasable,
SearchContext.Lifetime lifetime)
Schedule the release of a resource.
|
Modifier and Type | Class and Description |
---|---|
class |
SnapshotsService
Service responsible for creating snapshots
A typical snapshot creating process looks like this:
On the master node the
SnapshotsService.createSnapshot(SnapshotRequest, CreateSnapshotListener) is called and makes sure that no snapshots is currently running
and registers the new snapshot in cluster state
When cluster state is updated the SnapshotsService.beginSnapshot(ClusterState, SnapshotMetaData.Entry, boolean, CreateSnapshotListener) method
kicks in and initializes the snapshot in the repository and then populates list of shards that needs to be snapshotted in cluster state
Each data node is watching for these shards and when new shards scheduled for snapshotting appear in the cluster state, data nodes
start processing them through SnapshotsService.processIndexShardSnapshots(SnapshotMetaData) method
Once shard snapshot is created data node updates state of the shard in the cluster state using the SnapshotsService.updateIndexShardSnapshotStatus(UpdateIndexShardSnapshotStatusRequest) method
When last shard is completed master node in SnapshotsService.innerUpdateSnapshotState(org.elasticsearch.snapshots.SnapshotsService.UpdateIndexShardSnapshotStatusRequest) method marks the snapshot as completed
After cluster state is updated, the SnapshotsService.endSnapshot(SnapshotMetaData.Entry) finalizes snapshot in the repository,
notifies all SnapshotsService.snapshotCompletionListeners that snapshot is completed, and finally calls SnapshotsService.removeSnapshotFromClusterState(SnapshotId, SnapshotInfo, Throwable) to remove snapshot from cluster state
|
Modifier and Type | Interface and Description |
---|---|
interface |
Transport |
Modifier and Type | Class and Description |
---|---|
class |
TransportService |
Modifier and Type | Class and Description |
---|---|
class |
LocalTransport |
Modifier and Type | Class and Description |
---|---|
class |
NettyTransport
There are 4 types of connections per node, low/med/high/ping.
|
Modifier and Type | Class and Description |
---|---|
class |
TribeService
The tribe service holds a list of node clients connected to a list of tribe members, and uses their
cluster state events to update this local node cluster state with the merged view of it.
|
Modifier and Type | Class and Description |
---|---|
class |
ResourceWatcherService
Generic resource watcher service
Other elasticsearch services can register their resource watchers with this service using
ResourceWatcherService.add(ResourceWatcher)
method. |
Copyright © 2009–2015. All rights reserved.