All Classes

Class Description
AbstractIndicesPrivileges  
AbstractIndicesPrivileges.FieldSecurity  
AbstractResultResponse<T extends org.elasticsearch.common.xcontent.ToXContent>
Abstract class that provides a list of results and their count.
AccuracyMetric
AccuracyMetric is a metric that answers the following two questions: 1.
AccuracyMetric.Result  
AcknowledgedResponse  
AcknowledgedTasksResponse  
AckWatchRequest
A request to explicitly acknowledge a watch.
AckWatchResponse
The response from an 'ack watch' request.
ActionStatus  
ActionStatus.AckStatus  
ActionStatus.AckStatus.State  
ActionStatus.Execution  
ActionStatus.Throttle  
ActivateWatchRequest
A request to explicitly activate a watch.
ActivateWatchResponse
Response from an 'activate watch' request.
AggregationConfig  
AllocateAction  
AllRoleMapperExpression
An expression that evaluates to true if-and-only-if all its children evaluate to true.
AllRoleMapperExpression.Builder  
AnalysisConfig
Analysis configuration options that describe which fields are analyzed and which functions are used to detect anomalies.
AnalysisConfig.Builder  
AnalysisLimits
Analysis limits for autodetect.
AnalysisStats
Statistics for the data frame analysis
AnalysisStatsNamedXContentProvider  
AnalyzeRequest
A request to analyze text
AnalyzeRequest.CustomAnalyzerBuilder
Helper class to build custom analyzer definitions
AnalyzeResponse  
AnalyzeResponse.AnalyzeToken  
AnomalyCause
Anomaly Cause POJO.
AnomalyRecord
Anomaly Record POJO.
AnyRoleMapperExpression
An expression that evaluates to true if at least one of its children evaluate to true.
AnyRoleMapperExpression.Builder  
ApiKey
API key information
ApplicationPrivilege
Represents an application specific privilege.
ApplicationPrivilege.Builder  
ApplicationResourcePrivileges
Represents privileges over resources that are scoped under an application.
AsyncSearchClient  
AsyncSearchResponse
A response of an async search request.
AucRocMetric
Area under the curve (AUC) of the receiver operating characteristic (ROC).
AucRocMetric
Area under the curve (AUC) of the receiver operating characteristic (ROC).
AucRocPoint  
AucRocResult  
AuthenticateRequest
Empty request object required to make the authenticate call.
AuthenticateResponse
The response for the authenticate call.
AuthenticateResponse.RealmInfo  
AutoFollowStats  
AutoFollowStats.AutoFollowedCluster  
BroadcastResponse
Represents a response to a request that is broadcast to a collection of shards.
BroadcastResponse.Shards
Represents the results of a collection of shards on which a request was executed against.
Bucket
Bucket Result POJO
BucketInfluencer  
CachesStatsRequest  
CachesStatsResponse  
CachesStatsResponse.NodeCachesStats  
CachesStatsResponse.SharedCacheStats  
Calendar
A simple calendar object for scheduled (special) events.
CancelTasksRequest  
CancelTasksRequest.Builder  
CancelTasksResponse
cancel tasks response that contains - task failures - node failures - tasks
CategorizationAnalyzerConfig
Configuration for the categorization analyzer.
CategorizationAnalyzerConfig.Builder  
CategorizationAnalyzerConfig.NameOrDefinition
Simple store of either a name of a built-in analyzer element or a custom definition.
CategoryDefinition  
CcrClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Elastic ccr related methods
CcrStatsRequest  
CcrStatsResponse  
CertificateInfo
Simple model of an X.509 certificate
ChangePasswordRequest
Request object to change the password of a user of a native realm or a built-in user.
ChunkingConfig
The description of how searches should be chunked.
ChunkingConfig.Mode  
Classification  
Classification
Evaluation of classification results.
Classification.Builder  
Classification.ClassAssignmentObjective  
ClassificationConfig  
ClassificationStats  
ClearApiKeyCacheRequest
The request used to clear the API key cache.
ClearPrivilegesCacheRequest
The request used to clear the cache for native application privileges stored in an index.
ClearPrivilegesCacheResponse
The response object that will be returned when clearing the privileges cache
ClearRealmCacheRequest
Request for clearing the cache of one or more realms
ClearRealmCacheResponse
Response for a clear realm cache request.
ClearRolesCacheRequest
The request used to clear the cache for native roles stored in an index.
ClearRolesCacheResponse
The response object that will be returned when clearing the roles cache
ClearSecurityCacheResponse
The response object that will be returned when clearing a security cache
CloseIndexRequest
A request to close an index.
CloseIndexResponse  
CloseIndexResponse.IndexResult  
CloseIndexResponse.ShardResult  
CloseIndexResponse.ShardResult.Failure  
CloseJobRequest
Request to close Machine Learning Jobs
CloseJobResponse
Response indicating if the Job(s) closed or not
ClusterClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Cluster API.
ComponentTemplatesExistRequest
A request to check for the existence of component templates
ComposableIndexTemplateExistRequest
A request to check for the existence of index templates
CompositeRoleMapperExpression
Expression of role mapper expressions which can be combined by operators like AND, OR
CompositeType  
ConfusionMatrixMetric  
ConfusionMatrixMetric.ConfusionMatrix  
ConfusionMatrixMetric.Result  
Connection
A Connection links exactly two Vertex objects.
Connection.ConnectionId
An identifier (implements hashcode and equals) that represents a unique key for a Connection
CountRequest
Encapsulates a request to _count API against one, several or all indices.
CountResponse
A response to _count API request.
CountResponse.ShardStats
Encapsulates _shards section of count api response.
CreateApiKeyRequest
Request to create API key
CreateApiKeyResponse
Response for create API key
CreateDataStreamRequest  
CreateIndexRequest
A request to create an index.
CreateIndexResponse
A response for a create index action.
CreateTokenRequest
Request to create a new OAuth2 token from the Elasticsearch cluster.
CreateTokenResponse
Response when creating a new OAuth2 token in the Elasticsearch cluster.
CustomWordEmbedding
This is a pre-processor that embeds text into a numerical vector.
DataCounts  
DataCounts
Job processed record counts.
DataDescription
Describes the format of the data used in the job and how it should be interpreted by the ML job.
DataDescription.Builder  
DataDescription.DataFormat
Enum of the acceptable data formats.
DatafeedConfig
The datafeed configuration object.
DatafeedConfig.Builder  
DatafeedState
Datafeed State POJO
DatafeedStats
Datafeed Statistics POJO
DatafeedTimingStats  
DatafeedUpdate
A datafeed update contains partial properties to update a DatafeedConfig.
DatafeedUpdate.Builder  
DataFrameAnalysis  
DataFrameAnalyticsConfig  
DataFrameAnalyticsConfig.Builder  
DataFrameAnalyticsConfigUpdate  
DataFrameAnalyticsConfigUpdate.Builder  
DataFrameAnalyticsDest  
DataFrameAnalyticsDest.Builder  
DataFrameAnalyticsSource  
DataFrameAnalyticsSource.Builder  
DataFrameAnalyticsState  
DataFrameAnalyticsStats  
DataStream  
DataStreamsStatsRequest  
DataStreamsStatsResponse  
DataStreamsStatsResponse.DataStreamStats  
DateHistogramGroupConfig
The configuration object for the histograms in the rollup config { "groups": [ "date_histogram": { "field" : "foo", "interval" : "1d", "delay": "30d", "time_zone" : "EST" } ] }
DateHistogramGroupConfig.CalendarInterval
CalendarInterval is a DateHistogramGroupConfig that uses calendar-aware intervals for rolling up data.
DateHistogramGroupConfig.FixedInterval
FixedInterval is a DateHistogramGroupConfig that uses a fixed time interval for rolling up data.
DateHistogramGroupSource
A grouping via a date histogram aggregation referencing a timefield
DateHistogramGroupSource.Builder  
DateHistogramGroupSource.CalendarInterval  
DateHistogramGroupSource.FixedInterval  
DateHistogramGroupSource.Interval
Interval can be specified in 2 ways: fixed_interval fixed intervals like 1h, 1m, 1d calendar_interval calendar aware intervals like 1M, 1Y, ...
DeactivateWatchRequest  
DeactivateWatchResponse  
DefaultDetectorDescription  
DelayedDataCheckConfig
The configuration object containing the delayed data check settings.
DelegatePkiAuthenticationRequest  
DelegatePkiAuthenticationResponse  
DeleteAction  
DeleteAliasRequest  
DeleteAsyncSearchRequest  
DeleteAutoFollowPatternRequest  
DeleteCalendarEventRequest
Request class for removing an event from an existing calendar
DeleteCalendarJobRequest
Request class for removing Machine Learning Jobs from an existing calendar
DeleteCalendarRequest
Request to delete a Machine Learning Calendar
DeleteComponentTemplateRequest  
DeleteComposableIndexTemplateRequest  
DeleteDatafeedRequest
Request to delete a Machine Learning Datafeed via its ID
DeleteDataFrameAnalyticsRequest
Request to delete a data frame analytics config
DeleteDataStreamRequest  
DeleteExpiredDataRequest
Request to delete expired model snapshots and forecasts
DeleteExpiredDataResponse
A response acknowledging the deletion of expired data
DeleteFilterRequest
A request to delete a machine learning filter
DeleteForecastRequest
POJO for a delete forecast request
DeleteJobRequest
Request to delete a Machine Learning Job via its ID
DeleteJobResponse
Response object that contains the acknowledgement or the task id depending on whether the delete job action was requested to wait for completion.
DeleteLicenseRequest  
DeleteLifecyclePolicyRequest  
DeleteModelSnapshotRequest
Request to delete a Machine Learning Model Snapshot Job via its Job and Snapshot IDs
DeletePolicyRequest  
DeletePrivilegesRequest
A request to delete application privileges
DeletePrivilegesResponse
Response for application privileges deletion
DeleteRoleMappingRequest
Request object to delete a role mapping.
DeleteRoleMappingResponse
Response when deleting a role mapping.
DeleteRoleRequest
A request delete a role from the security index
DeleteRoleResponse
Response for a role being deleted from the native realm
DeleteRollupJobRequest  
DeleteSnapshotLifecyclePolicyRequest  
DeleteTrainedModelAliasRequest  
DeleteTrainedModelRequest
Request to delete a data frame analytics config
DeleteTransformRequest
Request to delete a transform
DeleteUserRequest
A request to delete a user from the native realm.
DeleteUserResponse
Response for a user being deleted from the native realm
DeleteWatchRequest
A delete watch request to delete an watch by name (id)
DeleteWatchResponse  
DeprecationInfoRequest  
DeprecationInfoResponse  
DeprecationInfoResponse.DeprecationIssue
Information about deprecated items
DeprecationInfoResponse.DeprecationIssue.Level  
DestConfig
Configuration containing the destination index for the TransformConfig
DestConfig.Builder  
DetailAnalyzeResponse  
DetailAnalyzeResponse.AnalyzeTokenList  
DetailAnalyzeResponse.CharFilteredText  
DetectionRule  
DetectionRule.Builder  
Detector
Defines the fields and functions used in the analysis.
Detector.Builder  
Detector.ExcludeFrequent  
DetectorFunction  
DisableUserRequest
Request object to disable a native realm or built-in user.
ElasticsearchException
client side counterpart of server side ElasticsearchException It wraps the same content but it is not throwable.
EnableUserRequest
Request object to enable a native realm or built-in user.
EnrichClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Elastic enrich related methods
Ensemble  
Ensemble.Builder  
EqlClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Elastic EQL related functions
EqlSearchRequest  
EqlSearchResponse  
EqlSearchResponse.Event  
EqlSearchResponse.Hits  
EqlSearchResponse.Sequence  
EqlStatsRequest  
EqlStatsResponse  
EqlStatsResponse.Node  
EstimateModelMemoryRequest
Request to estimate the model memory an analysis config is likely to need given supplied field cardinalities.
EstimateModelMemoryResponse  
EvaluateDataFrameRequest  
EvaluateDataFrameResponse  
Evaluation
Defines an evaluation
EvaluationMetric
Defines an evaluation metric
EvaluationMetric.Result
The result of an evaluation metric
ExceptRoleMapperExpression
A negating expression.
ExecutePolicyRequest  
ExecutePolicyResponse  
ExecutePolicyResponse.ExecutionStatus  
ExecuteSnapshotLifecyclePolicyRequest  
ExecuteSnapshotLifecyclePolicyResponse  
ExecuteSnapshotLifecycleRetentionRequest  
ExecuteWatchRequest
An execute watch request to execute a watch by id or inline
ExecuteWatchRequest.ActionExecutionMode  
ExecuteWatchResponse  
ExecutionPhase  
ExecutionState  
ExplainDataFrameAnalyticsRequest
Request to explain the following about a data frame analytics job: field selection: which fields are included or are not in the analysis memory estimation: how much memory the job is estimated to require
ExplainDataFrameAnalyticsResponse  
ExplainLifecycleRequest
The request object used by the Explain Lifecycle API.
ExplainLifecycleResponse
The response object returned by the Explain Lifecycle API.
Exponent  
ExpressionRoleMapping
A representation of a single role-mapping.
ExpressionRoleMapping.Fields  
FeatureImportance  
FeatureImportance.ClassImportance  
FeaturesClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Snapshot API.
FeaturesRequestConverters  
FieldRoleMapperExpression
An expression that evaluates to true if a field (map element) matches the provided values.
FieldSelection  
FieldSelection.FeatureType  
FieldStats  
FilterRef  
FilterRef.FilterType  
FindStructureRequest  
FindStructureResponse  
FlushJobRequest
Request object to flush a given Machine Learning job.
FlushJobResponse
Response object containing flush acknowledgement and additional data
FoldValues  
FollowConfig  
FollowInfoRequest  
FollowInfoResponse  
FollowInfoResponse.FollowerInfo  
FollowInfoResponse.Status  
FollowStatsRequest  
FollowStatsResponse  
ForceMergeAction  
ForecastJobRequest
Pojo for forecasting an existing and open Machine Learning Job
ForecastJobResponse
Forecast response object
ForecastStats
A class to hold statistics about forecasts.
ForgetFollowerRequest
Represents a forget follower request.
FreezeAction  
FreezeIndexRequest
Request for the _freeze index API
FrequencyEncoding
PreProcessor for frequency encoding a set of categorical values for a given field.
FrequencyEncoding.Builder  
GeoIpStatsResponse  
GeoIpStatsResponse.DatabaseInfo  
GeoIpStatsResponse.NodeInfo  
GeoTileGroupSource  
GeoTileGroupSource.Builder  
GetAliasesResponse
Response obtained from the get aliases API.
GetApiKeyRequest
Request for get API key
GetApiKeyResponse
Response for get API keys.
The result contains information about the API keys that were found.
GetAsyncSearchRequest  
GetAutoFollowPatternRequest
Request class for get auto follow pattern api.
GetAutoFollowPatternResponse  
GetAutoFollowPatternResponse.Pattern  
GetBasicStatusResponse
Response class for license get basic status API
GetBucketsRequest
A request to retrieve buckets of a given job
GetBucketsResponse
A response containing the requested buckets
GetBuiltinPrivilegesRequest
Request object to retrieve the privilege that are builtin to the Elasticsearch cluster.
GetBuiltinPrivilegesResponse
Get builtin privileges response
GetCalendarEventsRequest
Get the Scheduled Events for a Calendar
GetCalendarEventsResponse
Contains a List of the found ScheduledEvent objects and the total count found
GetCalendarsRequest  
GetCalendarsResponse  
GetCategoriesRequest
A request to retrieve categories of a given job
GetCategoriesResponse
A response containing the requested categories
GetComponentTemplatesRequest
A request to read the content of component templates
GetComponentTemplatesResponse  
GetComposableIndexTemplateRequest
A request to read the content of index templates
GetComposableIndexTemplatesResponse  
GetDatafeedRequest
Request object to get DatafeedConfig objects with the matching datafeedIds.
GetDatafeedResponse
Contains a List of the found DatafeedConfig objects and the total count found
GetDatafeedStatsRequest
Request object to get DatafeedStats by their respective datafeedIds _all explicitly gets all the datafeeds' statistics in the cluster An empty request (no datafeedIds) implicitly gets all the datafeeds' statistics in the cluster
GetDatafeedStatsResponse
Contains a List of the found DatafeedStats objects and the total count found
GetDataFrameAnalyticsRequest  
GetDataFrameAnalyticsResponse  
GetDataFrameAnalyticsStatsRequest
Request to get data frame analytics stats
GetDataFrameAnalyticsStatsResponse  
GetDataStreamRequest  
GetDataStreamResponse  
GetFeaturesRequest
A TimedRequest to get the list of features available to be included in snapshots in the cluster.
GetFeaturesResponse  
GetFeaturesResponse.SnapshottableFeature  
GetFieldMappingsRequest
Request the mappings of specific fields
GetFieldMappingsResponse
Response object for GetFieldMappingsRequest API
GetFieldMappingsResponse.FieldMappingMetadata  
GetFiltersRequest
A request to retrieve MlFilters
GetFiltersResponse
Contains a List of the found MlFilter objects and the total count found
GetIndexRequest
A request to retrieve information about an index.
GetIndexRequest.Feature  
GetIndexResponse
A client side response for a get index action.
GetIndexTemplatesRequest
A request to read the content of index templates
GetIndexTemplatesResponse  
GetInfluencersRequest
A request to retrieve influencers of a given job
GetInfluencersResponse
A response containing the requested influencers
GetJobRequest
Request object to get Job objects with the matching jobIds or groupNames.
GetJobResponse
Contains a List of the found Job objects and the total count found
GetJobStatsRequest
Request object to get JobStats by their respective jobIds _all explicitly gets all the jobs' statistics in the cluster An empty request (no jobIds) implicitly gets all the jobs' statistics in the cluster
GetJobStatsResponse
Contains a List of the found JobStats objects and the total count found
GetLicenseRequest  
GetLicenseResponse  
GetLifecyclePolicyRequest  
GetLifecyclePolicyResponse  
GetMappingsRequest  
GetMappingsResponse  
GetModelSnapshotsRequest
A request to retrieve information about model snapshots for a given job
GetModelSnapshotsResponse
A response containing the requested snapshots
GetOverallBucketsRequest
A request to retrieve overall buckets of set of jobs
GetOverallBucketsResponse
A response containing the requested overall buckets
GetPolicyRequest  
GetPolicyResponse  
GetPrivilegesRequest
Request object to get application privilege(s)
GetPrivilegesResponse
Get application privileges response
GetRecordsRequest
A request to retrieve records of a given job
GetRecordsResponse
A response containing the requested records
GetRoleMappingsRequest
Request object to get role mappings
GetRoleMappingsResponse
Get role mappings response
GetRolesRequest
Request object to retrieve roles from the native roles store
GetRolesResponse
Response when requesting one or more roles.
GetRollupCapsRequest  
GetRollupCapsResponse  
GetRollupIndexCapsRequest  
GetRollupIndexCapsResponse  
GetRollupJobRequest
Request to fetch rollup jobs.
GetRollupJobResponse
Response from rollup's get jobs api.
GetRollupJobResponse.JobWrapper  
GetRollupJobResponse.RollupIndexerJobStats
The Rollup specialization of stats for the AsyncTwoPhaseIndexer.
GetRollupJobResponse.RollupJobStatus
Status of the rollup job.
GetSnapshotLifecyclePolicyRequest  
GetSnapshotLifecyclePolicyResponse  
GetSnapshotLifecycleStatsRequest  
GetSnapshotLifecycleStatsResponse  
GetSourceRequest  
GetSourceResponse  
GetSslCertificatesRequest
Request object to retrieve the X.509 certificates that are used to encrypt communications in an Elasticsearch cluster.
GetSslCertificatesResponse
Response object when retrieving the X.509 certificates that are used to encrypt communications in an Elasticsearch cluster.
GetTaskRequest  
GetTaskResponse  
GetTrainedModelsRequest  
GetTrainedModelsResponse  
GetTrainedModelsStatsRequest  
GetTrainedModelsStatsResponse  
GetTransformRequest  
GetTransformResponse  
GetTransformStatsRequest  
GetTransformStatsResponse  
GetTrialStatusResponse
Response class for license get trial status API
GetUserPrivilegesRequest
GetUserPrivilegesResponse
GetUsersRequest
Request object to retrieve users from the native realm
GetUsersResponse
Response when requesting zero or more users.
GetUsersResponse.ParsedUser  
GetWatchRequest
The request to get the watch by name (id)
GetWatchResponse  
GlobalOperationPrivilege
Represents generic global cluster privileges that can be scoped by categories and then further by operations.
GlobalPrivileges
Represents global privileges.
GrantApiKeyRequest
Request to create a new API Key on behalf of another user.
GrantApiKeyRequest.Grant  
GraphClient  
GraphExploreRequest
Holds the criteria required to guide the exploration of connected terms which can be returned as a graph.
GraphExploreRequest.TermBoost  
GraphExploreResponse
Graph explore response holds a graph of Vertex and Connection objects (nodes and edges in common graph parlance).
GroupConfig
The configuration object for the groups section in the rollup config.
GroupConfig
Class describing how to group data
GroupConfig.Builder  
HasPrivilegesRequest
Request to determine whether the current user has a list of privileges.
HasPrivilegesResponse
Response when checking whether the current user has a defined set of privileges.
HistogramGroupConfig
The configuration object for the histograms in the rollup config { "groups": [ "histogram": { "fields" : [ "foo", "bar" ], "interval" : 123 } ] }
HistogramGroupSource
A grouping via a histogram aggregation referencing a numeric field
HistogramGroupSource.Builder  
Hop
A Hop represents one of potentially many stages in a graph exploration.
HuberMetric
Calculates the pseudo Huber loss function.
HuberMetric.Result  
Hyperparameters  
Hyperparameters  
IndexerJobStats  
IndexerState
IndexerState represents the internal state of the indexer.
IndexLifecycleClient  
IndexLifecycleExplainResponse  
IndexLifecycleNamedXContentProvider  
IndexTemplateMetadata  
IndexTemplateMetadata.Builder  
IndexTemplatesExistRequest
A request to check for the existence of index templates
IndicesClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Indices API.
IndicesFollowStats  
IndicesFollowStats.ShardFollowStats  
IndicesPrivileges
Represents privileges over indices.
IndicesPrivileges.Builder  
InferenceConfig  
InferencePipelineAggregationBuilder
For building inference pipeline aggregations NOTE: This extends AbstractPipelineAggregationBuilder for compatibility with SearchSourceBuilder.aggregation(PipelineAggregationBuilder) but it doesn't support any "server" side things like InferencePipelineAggregationBuilder.doWriteTo(StreamOutput) or InferencePipelineAggregationBuilder.createInternal(Map)
InferenceStats  
InferenceToXContentCompressor
Collection of helper methods.
Influence
Influence field name and list of influence field values/score pairs
Influencer  
IngestClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Ingest API.
InvalidateApiKeyRequest
Request for invalidating API key(s) so that it can no longer be used
InvalidateApiKeyResponse  
InvalidateTokenRequest
Request to invalidate a OAuth2 token within the Elasticsearch cluster.
InvalidateTokenResponse
Response when invalidating one or multiple OAuth2 access tokens and refresh tokens.
Job
This class represents a configured and created Job.
Job.Builder  
JobState
Jobs whether running or complete are in one of these states.
JobStats
Class containing the statistics for a Machine Learning job.
JobUpdate
POJO for updating an existing Machine Learning Job
JobUpdate.Builder  
JobUpdate.DetectorUpdate  
LangIdentNeuralNetwork
Shallow, fully connected, feed forward NN modeled after and ported from https://github.com/google/cld3
LangNetLayer
Represents a single layer in the compressed Lang Net
LatestConfig
Class describing how to compute latest doc for every unique key
LatestConfig.Builder  
LicenseClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Elastic License-related methods
LicensesStatus  
LicenseStatus
Status of an X-Pack license.
LifecycleAction
interface for index lifecycle management actions
LifecycleManagementStatusRequest
A TimedRequest to get the current status of index lifecycle management.
LifecycleManagementStatusResponse
The current status of index lifecycle management.
LifecyclePolicy
Represents the lifecycle of an index from creation to deletion.
LifecyclePolicyMetadata  
ListTasksResponse  
LogisticRegression  
MachineLearningClient
Machine Learning API client wrapper for the RestHighLevelClient
MainRequest  
MainResponse  
MainResponse.Version  
ManageApplicationPrivilege
Represents the privilege to "manage" certain applications.
MeanSquaredErrorMetric
Calculates the mean squared error between two known numerical fields.
MeanSquaredErrorMetric.Result  
MeanSquaredLogarithmicErrorMetric
Calculates the mean squared error between two known numerical fields.
MeanSquaredLogarithmicErrorMetric.Result  
MemoryEstimation  
MemoryUsage  
MemoryUsage.Status  
MetricConfig
The configuration object for the metrics portion of a rollup job config { "metrics": [ { "field": "foo", "metrics": [ "min", "max", "sum"] }, { "field": "bar", "metrics": [ "max" ] } ] }
MigrateAction  
MigrationClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Elastic License-related methods
MlDataFrameAnalysisNamedXContentProvider  
MlEvaluationNamedXContentProvider  
MlFilter
An MlFilter Object A filter contains a list of strings.
MlFilter.Builder  
MlInferenceNamedXContentProvider  
MlInfoRequest  
MlInfoResponse  
ModelPlotConfig  
ModelSizeStats
Provide access to the C++ model size stats for the Java process.
ModelSizeStats.AssignmentMemoryBasis
Where will we get the memory requirement from when assigning this job to a node? There are three possibilities: 1.
ModelSizeStats.Builder  
ModelSizeStats.CategorizationStatus
The status of categorization for a job.
ModelSizeStats.MemoryStatus
The status of the memory monitored by the ResourceMonitor.
ModelSnapshot
ModelSnapshot Result POJO
ModelSnapshot.Builder  
MountSnapshotRequest  
MountSnapshotRequest.Storage  
Multi
Multi-PreProcessor for chaining together multiple processors
Multi.Builder  
MulticlassConfusionMatrixMetric
Calculates the multiclass confusion matrix.
MulticlassConfusionMatrixMetric.ActualClass  
MulticlassConfusionMatrixMetric.PredictedClass  
MulticlassConfusionMatrixMetric.Result  
MultiTermVectorsRequest  
MultiTermVectorsResponse  
NamedPolicy  
NamedXContentObject
Simple interface for XContent Objects that are named.
NamedXContentObjectHelper  
NGram
PreProcessor for n-gram encoding a string
NGram.Builder  
NodeAttributes
A Pojo class containing an Elastic Node's attributes
NodeAttributes
A Pojo class containing an Elastic Node's attributes
NodesResponse
Base class for responses that are node responses.
NodesResponseHeader
A utility class to parse the Nodes Header returned by RestActions.buildNodesHeader(XContentBuilder, ToXContent.Params, BaseNodesResponse).
OneHotEncoding
PreProcessor for one hot encoding a set of categorical values for a given field.
OneHotEncoding.Builder  
OpenJobRequest
Request to open a Machine Learning Job
OpenJobResponse
Response indicating if the Machine Learning Job is now opened or not
OperationMode
Enum representing the different modes that Index Lifecycle Service can operate in.
Operator
Enum representing logical comparisons on doubles
OutlierDetection
Evaluation of outlier detection results.
OutlierDetection  
OutlierDetection.Builder  
OutlierDetection.Method  
OutlierDetectionStats  
OutputAggregator  
OverallBucket
Overall Bucket Result POJO
OverallBucket.JobInfo  
PageParams
Paging parameters for GET requests
Parameters  
ParsedInference  
ParsedStringStats
Results from the string_stats aggregation.
ParsedTopMetrics
Results of the top_metrics aggregation.
ParsedTopMetrics.TopMetrics
The metrics belonging to the document with the "top" sort key.
PauseAutoFollowPatternRequest
Request class for pause auto follow pattern api.
PauseFollowRequest  
PerClassSingleValue  
PerPartitionCategorizationConfig  
Phase
Represents set of LifecycleActions which should be executed at a particular point in the lifecycle of an index.
PhaseExecutionInfo
This class contains information about the current phase being executed by Index Lifecycle Management on the specific index.
PhaseProgress
A class that describes a phase and its progress as a percentage
PivotConfig
Class describing how to pivot data via GroupConfig and AggregationConfig objects
PivotConfig.Builder  
PostCalendarEventRequest
Request to add a ScheduledEvent to a Machine Learning calendar
PostCalendarEventResponse
Response to adding ScheduledEvent(s) to a Machine Learning calendar
PostDataRequest
Request to post data to a Machine Learning job
PostDataRequest.JsonBuilder
Class for incrementally building a bulk document request in XContentType.JSON format
PostDataResponse
Response object when posting data to a Machine Learning Job
PrecisionMetric
PrecisionMetric is a metric that answers the question: "What fraction of documents classified as X actually belongs to X?" for any given class X equation: precision(X) = TP(X) / (TP(X) + FP(X)) where: TP(X) - number of true positives wrt X FP(X) - number of false positives wrt X
PrecisionMetric  
PrecisionMetric.Result  
PrecisionMetric.Result  
PreProcessor
Describes a pre-processor for a defined machine learning model
PreviewDatafeedRequest
Request to preview a MachineLearning Datafeed
PreviewDatafeedResponse
Response containing a datafeed preview in JSON format
PreviewTransformRequest  
PreviewTransformResponse  
PreviewTransformResponse.GeneratedDestIndexSettings  
ProtocolUtils
Common utilities used for XPack protocol classes
ProxyModeInfo  
PutAutoFollowPatternRequest  
PutCalendarJobRequest
Request class for adding Machine Learning Jobs to an existing calendar
PutCalendarRequest
Request to create a new Machine Learning calendar
PutCalendarResponse  
PutComponentTemplateRequest
A request to create an component template.
PutComposableIndexTemplateRequest
A request to create an index template.
PutDatafeedRequest
Request to create a new Machine Learning Datafeed given a DatafeedConfig configuration
PutDatafeedResponse
Response containing the newly created DatafeedConfig
PutDataFrameAnalyticsRequest  
PutDataFrameAnalyticsResponse  
PutFilterRequest
Request to create a new Machine Learning MlFilter given a MlFilter configuration
PutFilterResponse
Response containing the newly created MlFilter
PutFollowRequest  
PutFollowResponse  
PutIndexTemplateRequest
A request to create an index template.
PutJobRequest
Request to create a new Machine Learning Job given a Job configuration
PutJobResponse
Response containing the newly created Job
PutLicenseRequest  
PutLicenseResponse  
PutLifecyclePolicyRequest  
PutMappingRequest
Put a mapping definition into one or more indices.
PutPolicyRequest  
PutPrivilegesRequest
Request object for creating/updating application privileges.
PutPrivilegesResponse
Response when creating/updating one or more application privileges to the security index.
PutRoleMappingRequest
Request object to create or update a role mapping.
PutRoleMappingResponse
Response when adding/updating a role mapping.
PutRoleRequest
Request object to create or update a role.
PutRoleResponse
Response when adding a role to the native roles store.
PutRollupJobRequest  
PutSnapshotLifecyclePolicyRequest  
PutTrainedModelAliasRequest  
PutTrainedModelRequest  
PutTrainedModelResponse  
PutTransformRequest  
PutUserRequest
Request object to create or update a user in the native realm.
PutUserResponse
Response when adding a user to the native realm.
PutWatchRequest
This request class contains the data needed to create a watch along with the name of the watch.
PutWatchResponse  
Quantiles
Quantiles Result POJO
QueryConfig
Object for encapsulating the desired Query for a DataFrameAnalysis
QueryConfig
Object for encapsulating the desired Query for a Transform
QueuedWatch  
ReadOnlyAction  
RecallMetric
RecallMetric is a metric that answers the question: "What fraction of documents belonging to X have been predicted as X by the classifier?" for any given class X equation: recall(X) = TP(X) / (TP(X) + FN(X)) where: TP(X) - number of true positives wrt X FN(X) - number of false negatives wrt X
RecallMetric  
RecallMetric.Result  
RecallMetric.Result  
RefreshPolicy
Enumeration of values that control the refresh policy for a request that supports specifying a refresh policy.
Regression
Evaluation of regression results.
Regression  
Regression.Builder  
Regression.LossFunction  
RegressionConfig  
RegressionStats  
ReloadAnalyzersRequest
Request for the _reload_search_analyzers API
ReloadAnalyzersResponse
The response object that will be returned when reloading analyzers
ReloadAnalyzersResponse.ReloadDetails  
RemoteConnectionInfo
This class encapsulates all remote cluster information to be rendered on _remote/info requests.
RemoteConnectionInfo.ModeInfo  
RemoteInfoRequest
The request object used by the Remote cluster info API.
RemoteInfoResponse
A response to _remote/info API request.
RemoveIndexLifecyclePolicyRequest  
RemoveIndexLifecyclePolicyResponse  
ResetFeaturesRequest  
ResetFeaturesResponse
This class represents the response of the Feature State Reset API.
ResetFeaturesResponse.ResetFeatureStateStatus
A class representing the status of an attempt to reset a feature's state.
ResizeRequest
Request class to resize an index
ResizeResponse
The response from a ResizeRequest call
RestHighLevelClient
High level REST client that wraps an instance of the low level RestClient and allows to build requests and read responses.
Result
Contains common attributes for results.
ResumeAutoFollowPatternRequest
Request class for resume auto follow pattern api.
ResumeFollowRequest  
RetentionPolicyConfig  
RethrottleRequest
A request changing throttling of a task.
RetryLifecyclePolicyRequest  
RevertModelSnapshotRequest
A request to revert to a specific model snapshot for a given job
RevertModelSnapshotResponse
A response containing the reverted model snapshot
Role
Represents an aggregation of privileges.
Role.Builder  
Role.ClusterPrivilegeName
Canonical cluster privilege names.
Role.IndexPrivilegeName
Canonical index privilege names.
RoleMapperExpression
Implementations of this interface represent an expression used for user role mapping that can later be resolved to a boolean value.
RoleMapperExpressionParser
Parses the JSON (XContent) based boolean expression DSL into a tree of RoleMapperExpression objects.
RollableIndexCaps
Represents the rollup capabilities of a non-rollup index.
RolloverAction  
RolloverRequest
Request class to swap index under an alias upon satisfying conditions
RolloverResponse
Response object for RolloverRequest API
RollupClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Elastic Rollup-related methods
RollupJobCaps
Represents the Rollup capabilities for a specific job on a single rollup index
RollupJobCaps.RollupFieldCaps  
RollupJobConfig
This class holds the configuration details of a rollup job, such as the groupings, metrics, what index to rollup and where to roll them to.
RSquaredMetric
Calculates R-Squared between two known numerical fields.
RSquaredMetric.Result  
RuleAction  
RuleCondition  
RuleCondition.AppliesTo  
RuleScope  
RuleScope.Builder  
ScheduledEvent  
SearchableSnapshotAction
A LifecycleAction that will convert the index into a searchable snapshot.
SearchableSnapshotsClient
A wrapper for the RestHighLevelClient that provides methods for accessing searchable snapshots APIs.
SecurityClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Security APIs.
SecurityNodesResponse
Base class for security responses that are node responses.
SecurityNodesResponse.Node  
SetPriorityAction
A LifecycleAction which sets the index's priority.
SettingsConfig  
SettingsConfig.Builder  
SetUpgradeModeRequest
Sets ML into upgrade_mode
SetUserEnabledRequest
Abstract request object to enable or disable a built-in or native user.
ShardsAcknowledgedResponse  
ShrinkAction  
SimpleStats
Helper class for min, max, avg and total statistics for a quantity
SimulateIndexTemplateRequest
A request to simulate matching a provided index name and an optional new index template against the existing index templates.
SimulateIndexTemplateResponse  
SingleGroupSource  
SingleGroupSource.Type  
SnapshotClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Snapshot API.
SnapshotInvocationRecord  
SnapshotLifecycleManagementStatusRequest  
SnapshotLifecyclePolicy  
SnapshotLifecyclePolicyMetadata  
SnapshotLifecyclePolicyMetadata.SnapshotInProgress  
SnapshotLifecycleStats  
SnapshotLifecycleStats.SnapshotPolicyStats  
SnapshotRetentionConfiguration  
SniffModeInfo  
SourceConfig
Class encapsulating all options for a TransformConfig gathering data
SourceConfig.Builder  
StartBasicRequest  
StartBasicResponse  
StartBasicResponse.Status  
StartDatafeedRequest
Request to start a Datafeed
StartDatafeedResponse
Response indicating if the Machine Learning Datafeed is now started or not
StartDataFrameAnalyticsRequest  
StartDataFrameAnalyticsResponse
Response indicating if the Machine Learning Datafeed is now started or not
StartILMRequest  
StartRollupJobRequest  
StartRollupJobResponse  
StartSLMRequest  
StartTransformRequest  
StartTransformResponse  
StartTrialRequest  
StartTrialResponse  
StartWatchServiceRequest  
StatsRequest  
StatsResponse  
StatsResponse.CoordinatorStats  
StatsResponse.ExecutingPolicy  
StopDatafeedRequest
Request to stop Machine Learning Datafeeds
StopDatafeedResponse
Response indicating if the Machine Learning Datafeed is now stopped or not
StopDataFrameAnalyticsRequest  
StopDataFrameAnalyticsResponse
Response indicating if the Machine Learning Data Frame Analytics is now stopped or not
StopILMRequest  
StopRollupJobRequest  
StopRollupJobResponse  
StopSLMRequest  
StopTransformRequest  
StopTransformResponse  
StopWatchServiceRequest  
StringStatsAggregationBuilder
Builds the string_stats aggregation request.
SubmitAsyncSearchRequest
A request to track asynchronously the progress of a search against one or more indices.
SyncConfig  
SyncedFlushResponse  
SyncedFlushResponse.IndexResult
Description for the flush/synced results for a particular index.
SyncedFlushResponse.ShardCounts
Encapsulates the number of total successful and failed shard copies
SyncedFlushResponse.ShardFailure
Description of a failed shard copy for an index.
TargetMeanEncoding
PreProcessor for target mean encoding a set of categorical values for a given field.
TargetMeanEncoding.Builder  
TargetType  
TaskGroup
Client side counterpart of server side version.
TaskGroup.Builder  
TaskId
client side version of a TaskId
TaskInfo
client side counterpart of server side
TaskOperationFailure
client side counterpart of server side TaskOperationFailure
TasksClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Tasks API.
TaskSubmissionResponse  
TemplateRoleName
A role name that uses a dynamic template.
TemplateRoleName.Fields  
TemplateRoleName.Format  
TermsGroupConfig
The configuration object for the histograms in the rollup config { "groups": [ "terms": { "fields" : [ "foo", "bar" ] } ] }
TermsGroupSource  
TermsGroupSource.Builder  
TermVectorsRequest  
TermVectorsResponse  
TermVectorsResponse.TermVector  
TermVectorsResponse.TermVector.FieldStatistics  
TermVectorsResponse.TermVector.Term  
TermVectorsResponse.TermVector.Token  
TextStructure
Stores the determined text format.
TextStructure.Builder  
TextStructure.Format  
TextStructureClient
Text Structure API client wrapper for the RestHighLevelClient
TimedRequest
A base request for any requests that supply timeouts.
TimeRetentionPolicyConfig  
TimeRetentionPolicyConfig.Builder  
TimeSyncConfig  
TimeSyncConfig.Builder  
TimeUtil  
TimingStats  
TimingStats  
TimingStats  
TimingStats
Stats that give more insight into timing of various operations performed as part of anomaly detection job.
TopClassEntry  
TopMetricsAggregationBuilder
Builds the Top Metrics aggregation request.
TrainedModel  
TrainedModelConfig  
TrainedModelConfig.Builder  
TrainedModelDefinition  
TrainedModelDefinition.Builder  
TrainedModelInput  
TrainedModelStats  
TransformCheckpointingInfo  
TransformCheckpointStats  
TransformClient  
TransformConfig  
TransformConfig.Builder  
TransformConfigUpdate
This class holds the mutable configuration items for a transform
TransformConfigUpdate.Builder  
TransformIndexerPosition
Holds state of the cursors: indexer_position: the position of the indexer querying the source bucket_position: the position used for identifying changes
TransformIndexerStats  
TransformNamedXContentProvider  
TransformProgress  
TransformStats  
TransformStats.State  
Tree  
Tree.Builder  
TreeNode  
TreeNode.Builder  
UnfollowAction  
UnfollowRequest  
UnfreezeIndexRequest
Request for the _unfreeze index API
UpdateDatafeedRequest
Requests an update to a DatafeedConfig with the passed DatafeedUpdate settings
UpdateDataFrameAnalyticsRequest  
UpdateFilterRequest
Updates an existing MlFilter configuration
UpdateJobRequest
Updates a Job with the passed JobUpdate settings
UpdateModelSnapshotRequest
A request to update information about an existing model snapshot for a given job
UpdateModelSnapshotResponse
A response acknowledging the update of information for an existing model snapshot for a given job
UpdateTransformRequest  
UpdateTransformResponse  
UpgradeJobModelSnapshotRequest  
UpgradeJobModelSnapshotResponse  
User
A user to be utilized with security APIs.
UserIndicesPrivileges
Represents an "index" privilege in the GetUserPrivilegesResponse.
Validatable
Defines a validation layer for Requests.
ValidationException
Encapsulates an accumulation of validation errors
ValidationLoss  
ValidationLoss  
Vertex
A vertex in a graph response represents a single term (a field and value pair) which appears in one or more documents found as part of the graph exploration.
Vertex.VertexId
An identifier (implements hashcode and equals) that represents a unique key for a Vertex
VertexRequest
A request to identify terms from a choice of field as part of a Hop.
WaitForSnapshotAction
A LifecycleAction which waits for snapshot to be taken (by configured SLM policy).
WatcherClient  
WatcherMetadata  
WatcherState  
WatcherStatsRequest
A request to explicitly acknowledge a watch.
WatcherStatsResponse
The response from an 'ack watch' request.
WatcherStatsResponse.Node  
WatchExecutionSnapshot  
WatchStatus  
WatchStatus.Field  
WatchStatus.State  
WatchStatusDateParser  
WeightedMode  
WeightedSum  
XContentSource
Encapsulates the xcontent source
XPackClient
A wrapper for the RestHighLevelClient that provides methods for accessing the Elastic Licensed X-Pack APIs that are shipped with the default distribution of Elasticsearch.
XPackInfoRequest
Fetch information about X-Pack from the cluster.
XPackInfoRequest.Category  
XPackInfoResponse  
XPackInfoResponse.BuildInfo  
XPackInfoResponse.FeatureSetsInfo  
XPackInfoResponse.FeatureSetsInfo.FeatureSet  
XPackInfoResponse.LicenseInfo  
XPackUsageRequest  
XPackUsageResponse
Response object from calling the xpack usage api.