API Reference

edit

bulk

edit

Allows to perform multiple index/update/delete operations in a single request.

Endpoint documentation

client.bulk(...)

clear_scroll

edit

Explicitly clears the search context for a scroll.

Endpoint documentation

client.clearScroll(...)

close_point_in_time

edit

Close a point in time

Endpoint documentation

client.closePointInTime(...)

count

edit

Returns number of documents matching a query.

Endpoint documentation

client.count(...)

create

edit

Creates a new document in the index.

Returns a 409 response when a document with a same ID already exists in the index.

Endpoint documentation

client.create(...)

delete

edit

Removes a document from the index.

Endpoint documentation

client.delete(...)

delete_by_query

edit

Deletes documents matching the provided query.

Endpoint documentation

client.deleteByQuery(...)

delete_by_query_rethrottle

edit

Changes the number of requests per second for a particular Delete By Query operation.

Endpoint documentation

client.deleteByQueryRethrottle(...)

delete_script

edit

Deletes a script.

Endpoint documentation

client.deleteScript(...)

exists

edit

Returns information about whether a document exists in an index.

Endpoint documentation

client.exists(...)

exists_source

edit

Returns information about whether a document source exists in an index.

Endpoint documentation

client.existsSource(...)

explain

edit

Returns information about why a specific matches (or doesn’t match) a query.

Endpoint documentation

client.explain(...)

field_caps

edit

Returns the information about the capabilities of fields among multiple indices.

Endpoint documentation

client.fieldCaps(...)

get

edit

Returns a document.

Endpoint documentation

client.get(...)

get_script

edit

Returns a script.

Endpoint documentation

client.getScript(...)

get_script_context

edit

Returns all script contexts.

Endpoint documentation

client.getScriptContext(...)

get_script_languages

edit

Returns available script types, languages and contexts

Endpoint documentation

client.getScriptLanguages(...)

get_source

edit

Returns the source of a document.

Endpoint documentation

client.getSource(...)

index

edit

Creates or updates a document in an index.

Endpoint documentation

client.index(...)

info

edit

Returns basic information about the cluster.

Endpoint documentation

client.info(...)

knn_search

edit

Performs a kNN search.

Endpoint documentation

client.knnSearch(...)

mget

edit

Allows to get multiple documents in one request.

Endpoint documentation

client.mget(...)

msearch

edit

Allows to execute several search operations in one request.

Endpoint documentation

client.msearch(...)

msearch_template

edit

Allows to execute several search template operations in one request.

Endpoint documentation

client.msearchTemplate(...)

mtermvectors

edit

Returns multiple termvectors in one request.

Endpoint documentation

client.mtermvectors(...)

open_point_in_time

edit

Open a point in time that can be used in subsequent searches

Endpoint documentation

client.openPointInTime(...)

ping

edit

Returns whether the cluster is running.

Endpoint documentation

client.ping(...)

put_script

edit

Creates or updates a script.

Endpoint documentation

client.putScript(...)

rank_eval

edit

Allows to evaluate the quality of ranked search results over a set of typical search queries

Endpoint documentation

client.rankEval(...)

reindex

edit

Allows to copy documents from one index to another, optionally filtering the source documents by a query, changing the destination index settings, or fetching the documents from a remote cluster.

Endpoint documentation

client.reindex(...)

reindex_rethrottle

edit

Changes the number of requests per second for a particular Reindex operation.

Endpoint documentation

client.reindexRethrottle(...)

render_search_template

edit

Allows to use the Mustache language to pre-render a search definition.

Endpoint documentation

client.renderSearchTemplate(...)

scripts_painless_execute

edit

Allows an arbitrary script to be executed and a result to be returned

Endpoint documentation

client.scriptsPainlessExecute(...)

scroll

edit

Allows to retrieve a large numbers of results from a single search request.

Endpoint documentation

client.scroll(...)

search

edit

Returns results matching a query.

Endpoint documentation

client.search(...)

search_mvt

edit

Searches a vector tile for geospatial values. Returns results as a binary Mapbox vector tile.

Endpoint documentation

client.searchMvt(...)

search_shards

edit

Returns information about the indices and shards that a search request would be executed against.

Endpoint documentation

client.searchShards(...)

search_template

edit

Allows to use the Mustache language to pre-render a search definition.

Endpoint documentation

client.searchTemplate(...)

terms_enum

edit

The terms enum API can be used to discover terms in the index that begin with the provided string. It is designed for low-latency look-ups used in auto-complete scenarios.

Endpoint documentation

client.termsEnum(...)

termvectors

edit

Returns information and statistics about terms in the fields of a particular document.

Endpoint documentation

client.termvectors(...)

update

edit

Updates a document with a script or partial document.

Endpoint documentation

client.update(...)

update_by_query

edit

Performs an update on every document in the index without changing the source, for example to pick up a mapping change.

Endpoint documentation

client.updateByQuery(...)

update_by_query_rethrottle

edit

Changes the number of requests per second for a particular Update By Query operation.

Endpoint documentation

client.updateByQueryRethrottle(...)

async_search

edit

delete

edit

Deletes an async search by ID. If the search is still running, the search request will be cancelled. Otherwise, the saved search results are deleted.

Endpoint documentation

client.asyncSearch.delete(...)

get

edit

Retrieves the results of a previously submitted async search request given its ID.

Endpoint documentation

client.asyncSearch.get(...)

status

edit

Retrieves the status of a previously submitted async search request given its ID.

Endpoint documentation

client.asyncSearch.status(...)

submit

edit

Executes a search request asynchronously.

Endpoint documentation

client.asyncSearch.submit(...)

cat

edit

aliases

edit

Shows information about currently configured aliases to indices including filter and routing infos.

Endpoint documentation

client.cat.aliases(...)

allocation

edit

Provides a snapshot of how many shards are allocated to each data node and how much disk space they are using.

Endpoint documentation

client.cat.allocation(...)

count

edit

Provides quick access to the document count of the entire cluster, or individual indices.

Endpoint documentation

client.cat.count(...)

fielddata

edit

Shows how much heap memory is currently being used by fielddata on every data node in the cluster.

Endpoint documentation

client.cat.fielddata(...)

health

edit

Returns a concise representation of the cluster health.

Endpoint documentation

client.cat.health(...)

help

edit

Returns help for the Cat APIs.

Endpoint documentation

client.cat.help(...)

indices

edit

Returns information about indices: number of primaries and replicas, document counts, disk size, …​

Endpoint documentation

client.cat.indices(...)

master

edit

Returns information about the master node.

Endpoint documentation

client.cat.master(...)

ml_data_frame_analytics

edit

Gets configuration and usage information about data frame analytics jobs.

Endpoint documentation

client.cat.mlDataFrameAnalytics(...)

ml_datafeeds

edit

Gets configuration and usage information about datafeeds.

Endpoint documentation

client.cat.mlDatafeeds(...)

ml_jobs

edit

Gets configuration and usage information about anomaly detection jobs.

Endpoint documentation

client.cat.mlJobs(...)

ml_trained_models

edit

Gets configuration and usage information about inference trained models.

Endpoint documentation

client.cat.mlTrainedModels(...)

nodeattrs

edit

Returns information about custom node attributes.

Endpoint documentation

client.cat.nodeattrs(...)

nodes

edit

Returns basic statistics about performance of cluster nodes.

Endpoint documentation

client.cat.nodes(...)

pending_tasks

edit

Returns a concise representation of the cluster pending tasks.

Endpoint documentation

client.cat.pendingTasks(...)

plugins

edit

Returns information about installed plugins across nodes node.

Endpoint documentation

client.cat.plugins(...)

recovery

edit

Returns information about index shard recoveries, both on-going completed.

Endpoint documentation

client.cat.recovery(...)

repositories

edit

Returns information about snapshot repositories registered in the cluster.

Endpoint documentation

client.cat.repositories(...)

segments

edit

Provides low-level information about the segments in the shards of an index.

Endpoint documentation

client.cat.segments(...)

shards

edit

Provides a detailed view of shard allocation on nodes.

Endpoint documentation

client.cat.shards(...)

snapshots

edit

Returns all snapshots in a specific repository.

Endpoint documentation

client.cat.snapshots(...)

tasks

edit

Returns information about the tasks currently executing on one or more nodes in the cluster.

Endpoint documentation

client.cat.tasks(...)

templates

edit

Returns information about existing templates.

Endpoint documentation

client.cat.templates(...)

thread_pool

edit

Returns cluster-wide thread pool statistics per node. By default the active, queue and rejected statistics are returned for all thread pools.

Endpoint documentation

client.cat.threadPool(...)

transforms

edit

Gets configuration and usage information about transforms.

Endpoint documentation

client.cat.transforms(...)

ccr

edit

delete_auto_follow_pattern

edit

Deletes auto-follow patterns.

Endpoint documentation

client.ccr.deleteAutoFollowPattern(...)

follow

edit

Creates a new follower index configured to follow the referenced leader index.

Endpoint documentation

client.ccr.follow(...)

follow_info

edit

Retrieves information about all follower indices, including parameters and status for each follower index

Endpoint documentation

client.ccr.followInfo(...)

follow_stats

edit

Retrieves follower stats. return shard-level stats about the following tasks associated with each shard for the specified indices.

Endpoint documentation

client.ccr.followStats(...)

forget_follower

edit

Removes the follower retention leases from the leader.

Endpoint documentation

client.ccr.forgetFollower(...)

get_auto_follow_pattern

edit

Gets configured auto-follow patterns. Returns the specified auto-follow pattern collection.

Endpoint documentation

client.ccr.getAutoFollowPattern(...)

pause_auto_follow_pattern

edit

Pauses an auto-follow pattern

Endpoint documentation

client.ccr.pauseAutoFollowPattern(...)

pause_follow

edit

Pauses a follower index. The follower index will not fetch any additional operations from the leader index.

Endpoint documentation

client.ccr.pauseFollow(...)

put_auto_follow_pattern

edit

Creates a new named collection of auto-follow patterns against a specified remote cluster. Newly created indices on the remote cluster matching any of the specified patterns will be automatically configured as follower indices.

Endpoint documentation

client.ccr.putAutoFollowPattern(...)

resume_auto_follow_pattern

edit

Resumes an auto-follow pattern that has been paused

Endpoint documentation

client.ccr.resumeAutoFollowPattern(...)

resume_follow

edit

Resumes a follower index that has been paused

Endpoint documentation

client.ccr.resumeFollow(...)

stats

edit

Gets all stats related to cross-cluster replication.

Endpoint documentation

client.ccr.stats(...)

unfollow

edit

Stops the following task associated with a follower index and removes index metadata and settings associated with cross-cluster replication.

Endpoint documentation

client.ccr.unfollow(...)

cluster

edit

allocation_explain

edit

Provides explanations for shard allocations in the cluster.

Endpoint documentation

client.cluster.allocationExplain(...)

delete_component_template

edit

Deletes a component template

Endpoint documentation

client.cluster.deleteComponentTemplate(...)

delete_voting_config_exclusions

edit

Clears cluster voting config exclusions.

Endpoint documentation

client.cluster.deleteVotingConfigExclusions(...)

exists_component_template

edit

Returns information about whether a particular component template exist

Endpoint documentation

client.cluster.existsComponentTemplate(...)

get_component_template

edit

Returns one or more component templates

Endpoint documentation

client.cluster.getComponentTemplate(...)

get_settings

edit

Returns cluster settings.

Endpoint documentation

client.cluster.getSettings(...)

health

edit

Returns basic information about the health of the cluster.

Endpoint documentation

client.cluster.health(...)

pending_tasks

edit

Returns a list of any cluster-level changes (e.g. create index, update mapping, allocate or fail shard) which have not yet been executed.

Endpoint documentation

client.cluster.pendingTasks(...)

post_voting_config_exclusions

edit

Updates the cluster voting config exclusions by node ids or node names.

Endpoint documentation

client.cluster.postVotingConfigExclusions(...)

put_component_template

edit

Creates or updates a component template

Endpoint documentation

client.cluster.putComponentTemplate(...)

put_settings

edit

Updates the cluster settings.

Endpoint documentation

client.cluster.putSettings(...)

remote_info

edit

Returns the information about configured remote clusters.

Endpoint documentation

client.cluster.remoteInfo(...)

reroute

edit

Allows to manually change the allocation of individual shards in the cluster.

Endpoint documentation

client.cluster.reroute(...)

state

edit

Returns a comprehensive information about the state of the cluster.

Endpoint documentation

client.cluster.state(...)

stats

edit

Returns high-level overview of cluster statistics.

Endpoint documentation

client.cluster.stats(...)

dangling_indices

edit

delete_dangling_index

edit

Deletes the specified dangling index

Endpoint documentation

client.danglingIndices.deleteDanglingIndex(...)

import_dangling_index

edit

Imports the specified dangling index

Endpoint documentation

client.danglingIndices.importDanglingIndex(...)

list_dangling_indices

edit

Returns all dangling indices.

Endpoint documentation

client.danglingIndices.listDanglingIndices(...)

enrich

edit

delete_policy

edit

Deletes an existing enrich policy and its enrich index.

Endpoint documentation

client.enrich.deletePolicy(...)

execute_policy

edit

Creates the enrich index for an existing enrich policy.

Endpoint documentation

client.enrich.executePolicy(...)

get_policy

edit

Gets information about an enrich policy.

Endpoint documentation

client.enrich.getPolicy(...)

put_policy

edit

Creates a new enrich policy.

Endpoint documentation

client.enrich.putPolicy(...)

stats

edit

Gets enrich coordinator statistics and information about enrich policies that are currently executing.

Endpoint documentation

client.enrich.stats(...)

eql

edit

delete

edit

Deletes an async EQL search by ID. If the search is still running, the search request will be cancelled. Otherwise, the saved search results are deleted.

Endpoint documentation

client.eql.delete(...)

get

edit

Returns async results from previously executed Event Query Language (EQL) search

Endpoint documentation

client.eql.get(...)

get_status

edit

Returns the status of a previously submitted async or stored Event Query Language (EQL) search

Endpoint documentation

client.eql.getStatus(...)

search

edit

Returns results matching a query expressed in Event Query Language (EQL)

Endpoint documentation

client.eql.search(...)

features

edit

get_features

edit

Gets a list of features which can be included in snapshots using the feature_states field when creating a snapshot

Endpoint documentation

client.features.getFeatures(...)

reset_features

edit

Resets the internal state of features, usually by deleting system indices

Endpoint documentation

client.features.resetFeatures(...)

fleet

edit

global_checkpoints

edit

Returns the current global checkpoints for an index. This API is design for internal use by the fleet server project.

Endpoint documentation

client.fleet.globalCheckpoints(...)

msearch

edit

Multi Search API where the search will only be executed after specified checkpoints are available due to a refresh. This API is designed for internal use by the fleet server project.

client.fleet.msearch(...)

search

edit

Search API where the search will only be executed after specified checkpoints are available due to a refresh. This API is designed for internal use by the fleet server project.

client.fleet.search(...)

graph

edit

explore

edit

Explore extracted and summarized information about the documents and terms in an index.

Endpoint documentation

client.graph.explore(...)

ilm

edit

delete_lifecycle

edit

Deletes the specified lifecycle policy definition. A currently used policy cannot be deleted.

Endpoint documentation

client.ilm.deleteLifecycle(...)

explain_lifecycle

edit

Retrieves information about the index’s current lifecycle state, such as the currently executing phase, action, and step.

Endpoint documentation

client.ilm.explainLifecycle(...)

get_lifecycle

edit

Returns the specified policy definition. Includes the policy version and last modified date.

Endpoint documentation

client.ilm.getLifecycle(...)

get_status

edit

Retrieves the current index lifecycle management (ILM) status.

Endpoint documentation

client.ilm.getStatus(...)

migrate_to_data_tiers

edit

Migrates the indices and ILM policies away from custom node attribute allocation routing to data tiers routing

Endpoint documentation

client.ilm.migrateToDataTiers(...)

move_to_step

edit

Manually moves an index into the specified step and executes that step.

Endpoint documentation

client.ilm.moveToStep(...)

put_lifecycle

edit

Creates a lifecycle policy

Endpoint documentation

client.ilm.putLifecycle(...)

remove_policy

edit

Removes the assigned lifecycle policy and stops managing the specified index

Endpoint documentation

client.ilm.removePolicy(...)

retry

edit

Retries executing the policy for an index that is in the ERROR step.

Endpoint documentation

client.ilm.retry(...)

start

edit

Start the index lifecycle management (ILM) plugin.

Endpoint documentation

client.ilm.start(...)

stop

edit

Halts all lifecycle management operations and stops the index lifecycle management (ILM) plugin

Endpoint documentation

client.ilm.stop(...)

indices

edit

add_block

edit

Adds a block to an index.

Endpoint documentation

client.indices.addBlock(...)

analyze

edit

Performs the analysis process on a text and return the tokens breakdown of the text.

Endpoint documentation

client.indices.analyze(...)

clear_cache

edit

Clears all or specific caches for one or more indices.

Endpoint documentation

client.indices.clearCache(...)

clone

edit

Clones an index

Endpoint documentation

client.indices.clone(...)

close

edit

Closes an index.

Endpoint documentation

client.indices.close(...)

create

edit

Creates an index with optional settings and mappings.

Endpoint documentation

client.indices.create(...)

create_data_stream

edit

Creates a data stream

Endpoint documentation

client.indices.createDataStream(...)

data_streams_stats

edit

Provides statistics on operations happening in a data stream.

Endpoint documentation

client.indices.dataStreamsStats(...)

delete

edit

Deletes an index.

Endpoint documentation

client.indices.delete(...)

delete_alias

edit

Deletes an alias.

Endpoint documentation

client.indices.deleteAlias(...)

delete_data_stream

edit

Deletes a data stream.

Endpoint documentation

client.indices.deleteDataStream(...)

delete_index_template

edit

Deletes an index template.

Endpoint documentation

client.indices.deleteIndexTemplate(...)

delete_template

edit

Deletes an index template.

Endpoint documentation

client.indices.deleteTemplate(...)

disk_usage

edit

Analyzes the disk usage of each field of an index or data stream

Endpoint documentation

client.indices.diskUsage(...)

exists

edit

Returns information about whether a particular index exists.

Endpoint documentation

client.indices.exists(...)

exists_alias

edit

Returns information about whether a particular alias exists.

Endpoint documentation

client.indices.existsAlias(...)

exists_index_template

edit

Returns information about whether a particular index template exists.

Endpoint documentation

client.indices.existsIndexTemplate(...)

exists_template

edit

Returns information about whether a particular index template exists.

Endpoint documentation

client.indices.existsTemplate(...)

field_usage_stats

edit

Returns the field usage stats for each field of an index

Endpoint documentation

client.indices.fieldUsageStats(...)

flush

edit

Performs the flush operation on one or more indices.

Endpoint documentation

client.indices.flush(...)

forcemerge

edit

Performs the force merge operation on one or more indices.

Endpoint documentation

client.indices.forcemerge(...)

get

edit

Returns information about one or more indices.

Endpoint documentation

client.indices.get(...)

get_alias

edit

Returns an alias.

Endpoint documentation

client.indices.getAlias(...)

get_data_stream

edit

Returns data streams.

Endpoint documentation

client.indices.getDataStream(...)

get_field_mapping

edit

Returns mapping for one or more fields.

Endpoint documentation

client.indices.getFieldMapping(...)

get_index_template

edit

Returns an index template.

Endpoint documentation

client.indices.getIndexTemplate(...)

get_mapping

edit

Returns mappings for one or more indices.

Endpoint documentation

client.indices.getMapping(...)

get_settings

edit

Returns settings for one or more indices.

Endpoint documentation

client.indices.getSettings(...)

get_template

edit

Returns an index template.

Endpoint documentation

client.indices.getTemplate(...)

migrate_to_data_stream

edit

Migrates an alias to a data stream

Endpoint documentation

client.indices.migrateToDataStream(...)

modify_data_stream

edit

Modifies a data stream

Endpoint documentation

client.indices.modifyDataStream(...)

open

edit

Opens an index.

Endpoint documentation

client.indices.open(...)

promote_data_stream

edit

Promotes a data stream from a replicated data stream managed by CCR to a regular data stream

Endpoint documentation

client.indices.promoteDataStream(...)

put_alias

edit

Creates or updates an alias.

Endpoint documentation

client.indices.putAlias(...)

put_index_template

edit

Creates or updates an index template.

Endpoint documentation

client.indices.putIndexTemplate(...)

put_mapping

edit

Updates the index mappings.

Endpoint documentation

client.indices.putMapping(...)

put_settings

edit

Updates the index settings.

Endpoint documentation

client.indices.putSettings(...)

put_template

edit

Creates or updates an index template.

Endpoint documentation

client.indices.putTemplate(...)

recovery

edit

Returns information about ongoing index shard recoveries.

Endpoint documentation

client.indices.recovery(...)

refresh

edit

Performs the refresh operation in one or more indices.

Endpoint documentation

client.indices.refresh(...)

reload_search_analyzers

edit

Reloads an index’s search analyzers and their resources.

Endpoint documentation

client.indices.reloadSearchAnalyzers(...)

resolve_index

edit

Returns information about any matching indices, aliases, and data streams

Endpoint documentation

client.indices.resolveIndex(...)

rollover

edit

Updates an alias to point to a new index when the existing index is considered to be too large or too old.

Endpoint documentation

client.indices.rollover(...)

segments

edit

Provides low-level information about segments in a Lucene index.

Endpoint documentation

client.indices.segments(...)

shard_stores

edit

Provides store information for shard copies of indices.

Endpoint documentation

client.indices.shardStores(...)

shrink

edit

Allow to shrink an existing index into a new index with fewer primary shards.

Endpoint documentation

client.indices.shrink(...)

simulate_index_template

edit

Simulate matching the given index name against the index templates in the system

Endpoint documentation

client.indices.simulateIndexTemplate(...)

simulate_template

edit

Simulate resolving the given template name or body

Endpoint documentation

client.indices.simulateTemplate(...)

split

edit

Allows you to split an existing index into a new index with more primary shards.

Endpoint documentation

client.indices.split(...)

stats

edit

Provides statistics on operations happening in an index.

Endpoint documentation

client.indices.stats(...)

unfreeze

edit

Unfreezes an index. When a frozen index is unfrozen, the index goes through the normal recovery process and becomes writeable again.

Endpoint documentation

client.indices.unfreeze(...)

update_aliases

edit

Updates index aliases.

Endpoint documentation

client.indices.updateAliases(...)

validate_query

edit

Allows a user to validate a potentially expensive query without executing it.

Endpoint documentation

client.indices.validateQuery(...)

ingest

edit

delete_pipeline

edit

Deletes a pipeline.

Endpoint documentation

client.ingest.deletePipeline(...)

geo_ip_stats

edit

Returns statistical information about geoip databases

Endpoint documentation

client.ingest.geoIpStats(...)

get_pipeline

edit

Returns a pipeline.

Endpoint documentation

client.ingest.getPipeline(...)

processor_grok

edit

Returns a list of the built-in patterns.

Endpoint documentation

client.ingest.processorGrok(...)

put_pipeline

edit

Creates or updates a pipeline.

Endpoint documentation

client.ingest.putPipeline(...)

simulate

edit

Allows to simulate a pipeline with example documents.

Endpoint documentation

client.ingest.simulate(...)

license

edit

delete

edit

Deletes licensing information for the cluster

Endpoint documentation

client.license.delete(...)

get

edit

Retrieves licensing information for the cluster

Endpoint documentation

client.license.get(...)

get_basic_status

edit

Retrieves information about the status of the basic license.

Endpoint documentation

client.license.getBasicStatus(...)

get_trial_status

edit

Retrieves information about the status of the trial license.

Endpoint documentation

client.license.getTrialStatus(...)

post

edit

Updates the license for the cluster.

Endpoint documentation

client.license.post(...)

post_start_basic

edit

Starts an indefinite basic license.

Endpoint documentation

client.license.postStartBasic(...)

post_start_trial

edit

starts a limited time trial license.

Endpoint documentation

client.license.postStartTrial(...)

logstash

edit

delete_pipeline

edit

Deletes Logstash Pipelines used by Central Management

Endpoint documentation

client.logstash.deletePipeline(...)

get_pipeline

edit

Retrieves Logstash Pipelines used by Central Management

Endpoint documentation

client.logstash.getPipeline(...)

put_pipeline

edit

Adds and updates Logstash Pipelines used for Central Management

Endpoint documentation

client.logstash.putPipeline(...)

migration

edit

deprecations

edit

Retrieves information about different cluster, node, and index level settings that use deprecated features that will be removed or changed in the next major version.

Endpoint documentation

client.migration.deprecations(...)

get_feature_upgrade_status

edit

Find out whether system features need to be upgraded or not

Endpoint documentation

client.migration.getFeatureUpgradeStatus(...)

post_feature_upgrade

edit

Begin upgrades for system features

Endpoint documentation

client.migration.postFeatureUpgrade(...)

close_job

edit

Closes one or more anomaly detection jobs. A job can be opened and closed multiple times throughout its lifecycle.

Endpoint documentation

client.ml.closeJob(...)

delete_calendar

edit

Deletes a calendar.

Endpoint documentation

client.ml.deleteCalendar(...)

delete_calendar_event

edit

Deletes scheduled events from a calendar.

Endpoint documentation

client.ml.deleteCalendarEvent(...)

delete_calendar_job

edit

Deletes anomaly detection jobs from a calendar.

Endpoint documentation

client.ml.deleteCalendarJob(...)

delete_data_frame_analytics

edit

Deletes an existing data frame analytics job.

Endpoint documentation

client.ml.deleteDataFrameAnalytics(...)

delete_datafeed

edit

Deletes an existing datafeed.

Endpoint documentation

client.ml.deleteDatafeed(...)

delete_expired_data

edit

Deletes expired and unused machine learning data.

Endpoint documentation

client.ml.deleteExpiredData(...)

delete_filter

edit

Deletes a filter.

Endpoint documentation

client.ml.deleteFilter(...)

delete_forecast

edit

Deletes forecasts from a machine learning job.

Endpoint documentation

client.ml.deleteForecast(...)

delete_job

edit

Deletes an existing anomaly detection job.

Endpoint documentation

client.ml.deleteJob(...)

delete_model_snapshot

edit

Deletes an existing model snapshot.

Endpoint documentation

client.ml.deleteModelSnapshot(...)

delete_trained_model

edit

Deletes an existing trained inference model that is currently not referenced by an ingest pipeline.

Endpoint documentation

client.ml.deleteTrainedModel(...)

delete_trained_model_alias

edit

Deletes a model alias that refers to the trained model

Endpoint documentation

client.ml.deleteTrainedModelAlias(...)

estimate_model_memory

edit

Estimates the model memory

Endpoint documentation

client.ml.estimateModelMemory(...)

evaluate_data_frame

edit

Evaluates the data frame analytics for an annotated index.

Endpoint documentation

client.ml.evaluateDataFrame(...)

explain_data_frame_analytics

edit

Explains a data frame analytics config.

Endpoint documentation

client.ml.explainDataFrameAnalytics(...)

flush_job

edit

Forces any buffered data to be processed by the job.

Endpoint documentation

client.ml.flushJob(...)

forecast

edit

Predicts the future behavior of a time series by using its historical behavior.

Endpoint documentation

client.ml.forecast(...)

get_buckets

edit

Retrieves anomaly detection job results for one or more buckets.

Endpoint documentation

client.ml.getBuckets(...)

get_calendar_events

edit

Retrieves information about the scheduled events in calendars.

Endpoint documentation

client.ml.getCalendarEvents(...)

get_calendars

edit

Retrieves configuration information for calendars.

Endpoint documentation

client.ml.getCalendars(...)

get_categories

edit

Retrieves anomaly detection job results for one or more categories.

Endpoint documentation

client.ml.getCategories(...)

get_data_frame_analytics

edit

Retrieves configuration information for data frame analytics jobs.

Endpoint documentation

client.ml.getDataFrameAnalytics(...)

get_data_frame_analytics_stats

edit

Retrieves usage information for data frame analytics jobs.

Endpoint documentation

client.ml.getDataFrameAnalyticsStats(...)

get_datafeed_stats

edit

Retrieves usage information for datafeeds.

Endpoint documentation

client.ml.getDatafeedStats(...)

get_datafeeds

edit

Retrieves configuration information for datafeeds.

Endpoint documentation

client.ml.getDatafeeds(...)

get_filters

edit

Retrieves filters.

Endpoint documentation

client.ml.getFilters(...)

get_influencers

edit

Retrieves anomaly detection job results for one or more influencers.

Endpoint documentation

client.ml.getInfluencers(...)

get_job_stats

edit

Retrieves usage information for anomaly detection jobs.

Endpoint documentation

client.ml.getJobStats(...)

get_jobs

edit

Retrieves configuration information for anomaly detection jobs.

Endpoint documentation

client.ml.getJobs(...)

get_memory_stats

edit

Returns information on how ML is using memory.

client.ml.getMemoryStats(...)

get_model_snapshot_upgrade_stats

edit

Gets stats for anomaly detection job model snapshot upgrades that are in progress.

Endpoint documentation

client.ml.getModelSnapshotUpgradeStats(...)

get_model_snapshots

edit

Retrieves information about model snapshots.

Endpoint documentation

client.ml.getModelSnapshots(...)

get_overall_buckets

edit

Retrieves overall bucket results that summarize the bucket results of multiple anomaly detection jobs.

Endpoint documentation

client.ml.getOverallBuckets(...)

get_records

edit

Retrieves anomaly records for an anomaly detection job.

Endpoint documentation

client.ml.getRecords(...)

get_trained_models

edit

Retrieves configuration information for a trained inference model.

Endpoint documentation

client.ml.getTrainedModels(...)

get_trained_models_stats

edit

Retrieves usage information for trained inference models.

Endpoint documentation

client.ml.getTrainedModelsStats(...)

infer_trained_model_deployment

edit

Evaluate a trained model.

Endpoint documentation

client.ml.inferTrainedModelDeployment(...)

info

edit

Returns defaults and limits used by machine learning.

Endpoint documentation

client.ml.info(...)

open_job

edit

Opens one or more anomaly detection jobs.

Endpoint documentation

client.ml.openJob(...)

post_calendar_events

edit

Posts scheduled events in a calendar.

Endpoint documentation

client.ml.postCalendarEvents(...)

post_data

edit

Sends data to an anomaly detection job for analysis.

Endpoint documentation

client.ml.postData(...)

preview_data_frame_analytics

edit

Previews that will be analyzed given a data frame analytics config.

Endpoint documentation

client.ml.previewDataFrameAnalytics(...)

preview_datafeed

edit

Previews a datafeed.

Endpoint documentation

client.ml.previewDatafeed(...)

put_calendar

edit

Instantiates a calendar.

Endpoint documentation

client.ml.putCalendar(...)

put_calendar_job

edit

Adds an anomaly detection job to a calendar.

Endpoint documentation

client.ml.putCalendarJob(...)

put_data_frame_analytics

edit

Instantiates a data frame analytics job.

Endpoint documentation

client.ml.putDataFrameAnalytics(...)

put_datafeed

edit

Instantiates a datafeed.

Endpoint documentation

client.ml.putDatafeed(...)

put_filter

edit

Instantiates a filter.

Endpoint documentation

client.ml.putFilter(...)

put_job

edit

Instantiates an anomaly detection job.

Endpoint documentation

client.ml.putJob(...)

put_trained_model

edit

Creates an inference trained model.

Endpoint documentation

client.ml.putTrainedModel(...)

put_trained_model_alias

edit

Creates a new model alias (or reassigns an existing one) to refer to the trained model

Endpoint documentation

client.ml.putTrainedModelAlias(...)

put_trained_model_definition_part

edit

Creates part of a trained model definition

Endpoint documentation

client.ml.putTrainedModelDefinitionPart(...)

put_trained_model_vocabulary

edit

Creates a trained model vocabulary

Endpoint documentation

client.ml.putTrainedModelVocabulary(...)

reset_job

edit

Resets an existing anomaly detection job.

Endpoint documentation

client.ml.resetJob(...)

revert_model_snapshot

edit

Reverts to a specific snapshot.

Endpoint documentation

client.ml.revertModelSnapshot(...)

set_upgrade_mode

edit

Sets a cluster wide upgrade_mode setting that prepares machine learning indices for an upgrade.

Endpoint documentation

client.ml.setUpgradeMode(...)

start_data_frame_analytics

edit

Starts a data frame analytics job.

Endpoint documentation

client.ml.startDataFrameAnalytics(...)

start_datafeed

edit

Starts one or more datafeeds.

Endpoint documentation

client.ml.startDatafeed(...)

start_trained_model_deployment

edit

Start a trained model deployment.

Endpoint documentation

client.ml.startTrainedModelDeployment(...)

stop_data_frame_analytics

edit

Stops one or more data frame analytics jobs.

Endpoint documentation

client.ml.stopDataFrameAnalytics(...)

stop_datafeed

edit

Stops one or more datafeeds.

Endpoint documentation

client.ml.stopDatafeed(...)

stop_trained_model_deployment

edit

Stop a trained model deployment.

Endpoint documentation

client.ml.stopTrainedModelDeployment(...)

update_data_frame_analytics

edit

Updates certain properties of a data frame analytics job.

Endpoint documentation

client.ml.updateDataFrameAnalytics(...)

update_datafeed

edit

Updates certain properties of a datafeed.

Endpoint documentation

client.ml.updateDatafeed(...)

update_filter

edit

Updates the description of a filter, adds items, or removes items.

Endpoint documentation

client.ml.updateFilter(...)

update_job

edit

Updates certain properties of an anomaly detection job.

Endpoint documentation

client.ml.updateJob(...)

update_model_snapshot

edit

Updates certain properties of a snapshot.

Endpoint documentation

client.ml.updateModelSnapshot(...)

upgrade_job_snapshot

edit

Upgrades a given job snapshot to the current major version.

Endpoint documentation

client.ml.upgradeJobSnapshot(...)

nodes

edit

clear_repositories_metering_archive

edit

Removes the archived repositories metering information present in the cluster.

Endpoint documentation

client.nodes.clearRepositoriesMeteringArchive(...)

get_repositories_metering_info

edit

Returns cluster repositories metering information.

Endpoint documentation

client.nodes.getRepositoriesMeteringInfo(...)

hot_threads

edit

Returns information about hot threads on each node in the cluster.

Endpoint documentation

client.nodes.hotThreads(...)

info

edit

Returns information about nodes in the cluster.

Endpoint documentation

client.nodes.info(...)

reload_secure_settings

edit

Reloads secure settings.

Endpoint documentation

client.nodes.reloadSecureSettings(...)

stats

edit

Returns statistical information about nodes in the cluster.

Endpoint documentation

client.nodes.stats(...)

usage

edit

Returns low-level information about REST actions usage on nodes.

Endpoint documentation

client.nodes.usage(...)

rollup

edit

delete_job

edit

Deletes an existing rollup job.

Endpoint documentation

client.rollup.deleteJob(...)

get_jobs

edit

Retrieves the configuration, stats, and status of rollup jobs.

Endpoint documentation

client.rollup.getJobs(...)

get_rollup_caps

edit

Returns the capabilities of any rollup jobs that have been configured for a specific index or index pattern.

Endpoint documentation

client.rollup.getRollupCaps(...)

get_rollup_index_caps

edit

Returns the rollup capabilities of all jobs inside of a rollup index (e.g. the index where rollup data is stored).

Endpoint documentation

client.rollup.getRollupIndexCaps(...)

put_job

edit

Creates a rollup job.

Endpoint documentation

client.rollup.putJob(...)

rollup

edit

Rollup an index

Endpoint documentation

client.rollup.rollup(...)

rollup_search

edit

Enables searching rolled-up data using the standard query DSL.

Endpoint documentation

client.rollup.rollupSearch(...)

start_job

edit

Starts an existing, stopped rollup job.

Endpoint documentation

client.rollup.startJob(...)

stop_job

edit

Stops an existing, started rollup job.

Endpoint documentation

client.rollup.stopJob(...)

searchable_snapshots

edit

cache_stats

edit

Retrieve node-level cache statistics about searchable snapshots.

Endpoint documentation

client.searchableSnapshots.cacheStats(...)

clear_cache

edit

Clear the cache of searchable snapshots.

Endpoint documentation

client.searchableSnapshots.clearCache(...)

mount

edit

Mount a snapshot as a searchable index.

Endpoint documentation

client.searchableSnapshots.mount(...)

stats

edit

Retrieve shard-level statistics about searchable snapshots.

Endpoint documentation

client.searchableSnapshots.stats(...)

security

edit

activate_user_profile

edit

Creates or updates the user profile on behalf of another user.

client.security.activateUserProfile(...)

authenticate

edit

Enables authentication as a user and retrieve information about the authenticated user.

Endpoint documentation

client.security.authenticate(...)

change_password

edit

Changes the passwords of users in the native realm and built-in users.

Endpoint documentation

client.security.changePassword(...)

clear_api_key_cache

edit

Clear a subset or all entries from the API key cache.

Endpoint documentation

client.security.clearApiKeyCache(...)

clear_cached_privileges

edit

Evicts application privileges from the native application privileges cache.

Endpoint documentation

client.security.clearCachedPrivileges(...)

clear_cached_realms

edit

Evicts users from the user cache. Can completely clear the cache or evict specific users.

Endpoint documentation

client.security.clearCachedRealms(...)

clear_cached_roles

edit

Evicts roles from the native role cache.

Endpoint documentation

client.security.clearCachedRoles(...)

clear_cached_service_tokens

edit

Evicts tokens from the service account token caches.

Endpoint documentation

client.security.clearCachedServiceTokens(...)

create_api_key

edit

Creates an API key for access without requiring basic authentication.

Endpoint documentation

client.security.createApiKey(...)

create_service_token

edit

Creates a service account token for access without requiring basic authentication.

Endpoint documentation

client.security.createServiceToken(...)

delete_privileges

edit

Removes application privileges.

Endpoint documentation

client.security.deletePrivileges(...)

delete_role

edit

Removes roles in the native realm.

Endpoint documentation

client.security.deleteRole(...)

delete_role_mapping

edit

Removes role mappings.

Endpoint documentation

client.security.deleteRoleMapping(...)

delete_service_token

edit

Deletes a service account token.

Endpoint documentation

client.security.deleteServiceToken(...)

delete_user

edit

Deletes users from the native realm.

Endpoint documentation

client.security.deleteUser(...)

disable_user

edit

Disables users in the native realm.

Endpoint documentation

client.security.disableUser(...)

enable_user

edit

Enables users in the native realm.

Endpoint documentation

client.security.enableUser(...)

enroll_kibana

edit

Allows a kibana instance to configure itself to communicate with a secured elasticsearch cluster.

Endpoint documentation

client.security.enrollKibana(...)

enroll_node

edit

Allows a new node to enroll to an existing cluster with security enabled.

Endpoint documentation

client.security.enrollNode(...)

get_api_key

edit

Retrieves information for one or more API keys.

Endpoint documentation

client.security.getApiKey(...)

get_builtin_privileges

edit

Retrieves the list of cluster privileges and index privileges that are available in this version of Elasticsearch.

Endpoint documentation

client.security.getBuiltinPrivileges(...)

get_privileges

edit

Retrieves application privileges.

Endpoint documentation

client.security.getPrivileges(...)

get_role

edit

Retrieves roles in the native realm.

Endpoint documentation

client.security.getRole(...)

get_role_mapping

edit

Retrieves role mappings.

Endpoint documentation

client.security.getRoleMapping(...)

get_service_accounts

edit

Retrieves information about service accounts.

Endpoint documentation

client.security.getServiceAccounts(...)

get_service_credentials

edit

Retrieves information of all service credentials for a service account.

Endpoint documentation

client.security.getServiceCredentials(...)

get_token

edit

Creates a bearer token for access without requiring basic authentication.

Endpoint documentation

client.security.getToken(...)

get_user

edit

Retrieves information about users in the native realm and built-in users.

Endpoint documentation

client.security.getUser(...)

get_user_privileges

edit

Retrieves security privileges for the logged in user.

Endpoint documentation

client.security.getUserPrivileges(...)

get_user_profile

edit

Retrieves user profile for the given unique ID.

client.security.getUserProfile(...)

grant_api_key

edit

Creates an API key on behalf of another user.

Endpoint documentation

client.security.grantApiKey(...)

has_privileges

edit

Determines whether the specified user has a specified list of privileges.

Endpoint documentation

client.security.hasPrivileges(...)

invalidate_api_key

edit

Invalidates one or more API keys.

Endpoint documentation

client.security.invalidateApiKey(...)

invalidate_token

edit

Invalidates one or more access tokens or refresh tokens.

Endpoint documentation

client.security.invalidateToken(...)

oidc_authenticate

edit

Exchanges an OpenID Connection authentication response message for an Elasticsearch access token and refresh token pair

Endpoint documentation

client.security.oidcAuthenticate(...)

oidc_logout

edit

Invalidates a refresh token and access token that was generated from the OpenID Connect Authenticate API

Endpoint documentation

client.security.oidcLogout(...)

oidc_prepare_authentication

edit

Creates an OAuth 2.0 authentication request as a URL string

Endpoint documentation

client.security.oidcPrepareAuthentication(...)

put_privileges

edit

Adds or updates application privileges.

Endpoint documentation

client.security.putPrivileges(...)

put_role

edit

Adds and updates roles in the native realm.

Endpoint documentation

client.security.putRole(...)

put_role_mapping

edit

Creates and updates role mappings.

Endpoint documentation

client.security.putRoleMapping(...)

put_user

edit

Adds and updates users in the native realm. These users are commonly referred to as native users.

Endpoint documentation

client.security.putUser(...)

query_api_keys

edit

Retrieves information for API keys using a subset of query DSL

Endpoint documentation

client.security.queryApiKeys(...)

saml_authenticate

edit

Exchanges a SAML Response message for an Elasticsearch access token and refresh token pair

Endpoint documentation

client.security.samlAuthenticate(...)

saml_complete_logout

edit

Verifies the logout response sent from the SAML IdP

Endpoint documentation

client.security.samlCompleteLogout(...)

saml_invalidate

edit

Consumes a SAML LogoutRequest

Endpoint documentation

client.security.samlInvalidate(...)

saml_logout

edit

Invalidates an access token and a refresh token that were generated via the SAML Authenticate API

Endpoint documentation

client.security.samlLogout(...)

saml_prepare_authentication

edit

Creates a SAML authentication request

Endpoint documentation

client.security.samlPrepareAuthentication(...)

saml_service_provider_metadata

edit

Generates SAML metadata for the Elastic stack SAML 2.0 Service Provider

Endpoint documentation

client.security.samlServiceProviderMetadata(...)

update_user_profile_data

edit

Update application specific data for the user profile of the given unique ID.

client.security.updateUserProfileData(...)

slm

edit

delete_lifecycle

edit

Deletes an existing snapshot lifecycle policy.

Endpoint documentation

client.slm.deleteLifecycle(...)

execute_lifecycle

edit

Immediately creates a snapshot according to the lifecycle policy, without waiting for the scheduled time.

Endpoint documentation

client.slm.executeLifecycle(...)

execute_retention

edit

Deletes any snapshots that are expired according to the policy’s retention rules.

Endpoint documentation

client.slm.executeRetention(...)

get_lifecycle

edit

Retrieves one or more snapshot lifecycle policy definitions and information about the latest snapshot attempts.

Endpoint documentation

client.slm.getLifecycle(...)

get_stats

edit

Returns global and policy-level statistics about actions taken by snapshot lifecycle management.

Endpoint documentation

client.slm.getStats(...)

get_status

edit

Retrieves the status of snapshot lifecycle management (SLM).

Endpoint documentation

client.slm.getStatus(...)

put_lifecycle

edit

Creates or updates a snapshot lifecycle policy.

Endpoint documentation

client.slm.putLifecycle(...)

start

edit

Turns on snapshot lifecycle management (SLM).

Endpoint documentation

client.slm.start(...)

stop

edit

Turns off snapshot lifecycle management (SLM).

Endpoint documentation

client.slm.stop(...)

snapshot

edit

cleanup_repository

edit

Removes stale data from repository.

Endpoint documentation

client.snapshot.cleanupRepository(...)

clone

edit

Clones indices from one snapshot into another snapshot in the same repository.

Endpoint documentation

client.snapshot.clone(...)

create

edit

Creates a snapshot in a repository.

Endpoint documentation

client.snapshot.create(...)

create_repository

edit

Creates a repository.

Endpoint documentation

client.snapshot.createRepository(...)

delete

edit

Deletes one or more snapshots.

Endpoint documentation

client.snapshot.delete(...)

delete_repository

edit

Deletes a repository.

Endpoint documentation

client.snapshot.deleteRepository(...)

get

edit

Returns information about a snapshot.

Endpoint documentation

client.snapshot.get(...)

get_repository

edit

Returns information about a repository.

Endpoint documentation

client.snapshot.getRepository(...)

repository_analyze

edit

Analyzes a repository for correctness and performance

Endpoint documentation

client.snapshot.repositoryAnalyze(...)

restore

edit

Restores a snapshot.

Endpoint documentation

client.snapshot.restore(...)

status

edit

Returns information about the status of a snapshot.

Endpoint documentation

client.snapshot.status(...)

verify_repository

edit

Verifies a repository.

Endpoint documentation

client.snapshot.verifyRepository(...)

sql

edit

clear_cursor

edit

Clears the SQL cursor

Endpoint documentation

client.sql.clearCursor(...)

delete_async

edit

Deletes an async SQL search or a stored synchronous SQL search. If the search is still running, the API cancels it.

Endpoint documentation

client.sql.deleteAsync(...)

get_async

edit

Returns the current status and available results for an async SQL search or stored synchronous SQL search

Endpoint documentation

client.sql.getAsync(...)

get_async_status

edit

Returns the current status of an async SQL search or a stored synchronous SQL search

Endpoint documentation

client.sql.getAsyncStatus(...)

query

edit

Executes a SQL request

Endpoint documentation

client.sql.query(...)

translate

edit

Translates SQL into Elasticsearch queries

Endpoint documentation

client.sql.translate(...)

ssl

edit

certificates

edit

Retrieves information about the X.509 certificates used to encrypt communications in the cluster.

Endpoint documentation

client.ssl.certificates(...)

tasks

edit

cancel

edit

Cancels a task, if it can be cancelled through an API.

Endpoint documentation

client.tasks.cancel(...)

get

edit

Returns information about a task.

Endpoint documentation

client.tasks.get(...)

list

edit

Returns a list of tasks.

Endpoint documentation

client.tasks.list(...)

text_structure

edit

find_structure

edit

Finds the structure of a text file. The text file must contain data that is suitable to be ingested into Elasticsearch.

Endpoint documentation

client.textStructure.findStructure(...)

transform

edit

delete_transform

edit

Deletes an existing transform.

Endpoint documentation

client.transform.deleteTransform(...)

get_transform

edit

Retrieves configuration information for transforms.

Endpoint documentation

client.transform.getTransform(...)

get_transform_stats

edit

Retrieves usage information for transforms.

Endpoint documentation

client.transform.getTransformStats(...)

preview_transform

edit

Previews a transform.

Endpoint documentation

client.transform.previewTransform(...)

put_transform

edit

Instantiates a transform.

Endpoint documentation

client.transform.putTransform(...)

reset_transform

edit

Resets an existing transform.

client.transform.resetTransform(...)

start_transform

edit

Starts one or more transforms.

Endpoint documentation

client.transform.startTransform(...)

stop_transform

edit

Stops one or more transforms.

Endpoint documentation

client.transform.stopTransform(...)

update_transform

edit

Updates certain properties of a transform.

Endpoint documentation

client.transform.updateTransform(...)

upgrade_transforms

edit

Upgrades all transforms.

Endpoint documentation

client.transform.upgradeTransforms(...)

watcher

edit

ack_watch

edit

Acknowledges a watch, manually throttling the execution of the watch’s actions.

Endpoint documentation

client.watcher.ackWatch(...)

activate_watch

edit

Activates a currently inactive watch.

Endpoint documentation

client.watcher.activateWatch(...)

deactivate_watch

edit

Deactivates a currently active watch.

Endpoint documentation

client.watcher.deactivateWatch(...)

delete_watch

edit

Removes a watch from Watcher.

Endpoint documentation

client.watcher.deleteWatch(...)

execute_watch

edit

Forces the execution of a stored watch.

Endpoint documentation

client.watcher.executeWatch(...)

get_watch

edit

Retrieves a watch by its ID.

Endpoint documentation

client.watcher.getWatch(...)

put_watch

edit

Creates a new watch, or updates an existing one.

Endpoint documentation

client.watcher.putWatch(...)

query_watches

edit

Retrieves stored watches.

Endpoint documentation

client.watcher.queryWatches(...)

start

edit

Starts Watcher if it is not already running.

Endpoint documentation

client.watcher.start(...)

stats

edit

Retrieves the current Watcher metrics.

Endpoint documentation

client.watcher.stats(...)

stop

edit

Stops Watcher if it is running.

Endpoint documentation

client.watcher.stop(...)

xpack

edit

info

edit

Retrieves information about the installed X-Pack features.

Endpoint documentation

client.xpack.info(...)

usage

edit

Retrieves usage information about the installed X-Pack features.

Endpoint documentation

client.xpack.usage(...)