API Referenceedit

bulkedit

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

Endpoint documentation

client.bulk(...)

clear_scrolledit

Explicitly clears the search context for a scroll.

Endpoint documentation

client.clearScroll(...)

close_point_in_timeedit

Close a point in time

Endpoint documentation

client.closePointInTime(...)

countedit

Returns number of documents matching a query.

Endpoint documentation

client.count(...)

createedit

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(...)

deleteedit

Removes a document from the index.

Endpoint documentation

client.delete(...)

delete_by_queryedit

Deletes documents matching the provided query.

Endpoint documentation

client.deleteByQuery(...)

delete_by_query_rethrottleedit

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

Endpoint documentation

client.deleteByQueryRethrottle(...)

delete_scriptedit

Deletes a script.

Endpoint documentation

client.deleteScript(...)

existsedit

Returns information about whether a document exists in an index.

Endpoint documentation

client.exists(...)

exists_sourceedit

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

Endpoint documentation

client.existsSource(...)

explainedit

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

Endpoint documentation

client.explain(...)

field_capsedit

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

Endpoint documentation

client.fieldCaps(...)

getedit

Returns a document.

Endpoint documentation

client.get(...)

get_scriptedit

Returns a script.

Endpoint documentation

client.getScript(...)

get_script_contextedit

Returns all script contexts.

Endpoint documentation

client.getScriptContext(...)

get_script_languagesedit

Returns available script types, languages and contexts

Endpoint documentation

client.getScriptLanguages(...)

get_sourceedit

Returns the source of a document.

Endpoint documentation

client.getSource(...)

indexedit

Creates or updates a document in an index.

Endpoint documentation

client.index(...)

infoedit

Returns basic information about the cluster.

Endpoint documentation

client.info(...)

knn_searchedit

Performs a kNN search.

Endpoint documentation

client.knnSearch(...)

mgetedit

Allows to get multiple documents in one request.

Endpoint documentation

client.mget(...)

msearchedit

Allows to execute several search operations in one request.

Endpoint documentation

client.msearch(...)

msearch_templateedit

Allows to execute several search template operations in one request.

Endpoint documentation

client.msearchTemplate(...)

mtermvectorsedit

Returns multiple termvectors in one request.

Endpoint documentation

client.mtermvectors(...)

open_point_in_timeedit

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

Endpoint documentation

client.openPointInTime(...)

pingedit

Returns whether the cluster is running.

Endpoint documentation

client.ping(...)

put_scriptedit

Creates or updates a script.

Endpoint documentation

client.putScript(...)

rank_evaledit

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

Endpoint documentation

client.rankEval(...)

reindexedit

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_rethrottleedit

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

Endpoint documentation

client.reindexRethrottle(...)

render_search_templateedit

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

Endpoint documentation

client.renderSearchTemplate(...)

scripts_painless_executeedit

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

Endpoint documentation

client.scriptsPainlessExecute(...)

scrolledit

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

Endpoint documentation

client.scroll(...)

searchedit

Returns results matching a query.

Endpoint documentation

client.search(...)

search_mvtedit

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

Endpoint documentation

client.searchMvt(...)

search_shardsedit

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

Endpoint documentation

client.searchShards(...)

search_templateedit

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

Endpoint documentation

client.searchTemplate(...)

terms_enumedit

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(...)

termvectorsedit

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

Endpoint documentation

client.termvectors(...)

updateedit

Updates a document with a script or partial document.

Endpoint documentation

client.update(...)

update_by_queryedit

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_rethrottleedit

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

Endpoint documentation

client.updateByQueryRethrottle(...)

async_searchedit

deleteedit

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(...)

getedit

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

Endpoint documentation

client.asyncSearch.get(...)

statusedit

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

Endpoint documentation

client.asyncSearch.status(...)

submitedit

Executes a search request asynchronously.

Endpoint documentation

client.asyncSearch.submit(...)

catedit

aliasesedit

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

Endpoint documentation

client.cat.aliases(...)

allocationedit

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(...)

component_templatesedit

Returns information about existing component_templates templates.

client.cat.componentTemplates(...)

countedit

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

Endpoint documentation

client.cat.count(...)

fielddataedit

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

Endpoint documentation

client.cat.fielddata(...)

healthedit

Returns a concise representation of the cluster health.

Endpoint documentation

client.cat.health(...)

helpedit

Returns help for the Cat APIs.

Endpoint documentation

client.cat.help(...)

indicesedit

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

Endpoint documentation

client.cat.indices(...)

masteredit

Returns information about the master node.

Endpoint documentation

client.cat.master(...)

ml_data_frame_analyticsedit

Gets configuration and usage information about data frame analytics jobs.

Endpoint documentation

client.cat.mlDataFrameAnalytics(...)

ml_datafeedsedit

Gets configuration and usage information about datafeeds.

Endpoint documentation

client.cat.mlDatafeeds(...)

ml_jobsedit

Gets configuration and usage information about anomaly detection jobs.

Endpoint documentation

client.cat.mlJobs(...)

ml_trained_modelsedit

Gets configuration and usage information about inference trained models.

Endpoint documentation

client.cat.mlTrainedModels(...)

nodeattrsedit

Returns information about custom node attributes.

Endpoint documentation

client.cat.nodeattrs(...)

nodesedit

Returns basic statistics about performance of cluster nodes.

Endpoint documentation

client.cat.nodes(...)

pending_tasksedit

Returns a concise representation of the cluster pending tasks.

Endpoint documentation

client.cat.pendingTasks(...)

pluginsedit

Returns information about installed plugins across nodes node.

Endpoint documentation

client.cat.plugins(...)

recoveryedit

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

Endpoint documentation

client.cat.recovery(...)

repositoriesedit

Returns information about snapshot repositories registered in the cluster.

Endpoint documentation

client.cat.repositories(...)

segmentsedit

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

Endpoint documentation

client.cat.segments(...)

shardsedit

Provides a detailed view of shard allocation on nodes.

Endpoint documentation

client.cat.shards(...)

snapshotsedit

Returns all snapshots in a specific repository.

Endpoint documentation

client.cat.snapshots(...)

tasksedit

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

Endpoint documentation

client.cat.tasks(...)

templatesedit

Returns information about existing templates.

Endpoint documentation

client.cat.templates(...)

thread_pooledit

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(...)

transformsedit

Gets configuration and usage information about transforms.

Endpoint documentation

client.cat.transforms(...)

ccredit

delete_auto_follow_patternedit

Deletes auto-follow patterns.

Endpoint documentation

client.ccr.deleteAutoFollowPattern(...)

followedit

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

Endpoint documentation

client.ccr.follow(...)

follow_infoedit

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

Endpoint documentation

client.ccr.followInfo(...)

follow_statsedit

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_followeredit

Removes the follower retention leases from the leader.

Endpoint documentation

client.ccr.forgetFollower(...)

get_auto_follow_patternedit

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

Endpoint documentation

client.ccr.getAutoFollowPattern(...)

pause_auto_follow_patternedit

Pauses an auto-follow pattern

Endpoint documentation

client.ccr.pauseAutoFollowPattern(...)

pause_followedit

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_patternedit

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_patternedit

Resumes an auto-follow pattern that has been paused

Endpoint documentation

client.ccr.resumeAutoFollowPattern(...)

resume_followedit

Resumes a follower index that has been paused

Endpoint documentation

client.ccr.resumeFollow(...)

statsedit

Gets all stats related to cross-cluster replication.

Endpoint documentation

client.ccr.stats(...)

unfollowedit

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(...)

clusteredit

allocation_explainedit

Provides explanations for shard allocations in the cluster.

Endpoint documentation

client.cluster.allocationExplain(...)

delete_component_templateedit

Deletes a component template

Endpoint documentation

client.cluster.deleteComponentTemplate(...)

delete_voting_config_exclusionsedit

Clears cluster voting config exclusions.

Endpoint documentation

client.cluster.deleteVotingConfigExclusions(...)

exists_component_templateedit

Returns information about whether a particular component template exist

Endpoint documentation

client.cluster.existsComponentTemplate(...)

get_component_templateedit

Returns one or more component templates

Endpoint documentation

client.cluster.getComponentTemplate(...)

get_settingsedit

Returns cluster settings.

Endpoint documentation

client.cluster.getSettings(...)

healthedit

Returns basic information about the health of the cluster.

Endpoint documentation

client.cluster.health(...)

pending_tasksedit

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_exclusionsedit

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

Endpoint documentation

client.cluster.postVotingConfigExclusions(...)

put_component_templateedit

Creates or updates a component template

Endpoint documentation

client.cluster.putComponentTemplate(...)

put_settingsedit

Updates the cluster settings.

Endpoint documentation

client.cluster.putSettings(...)

remote_infoedit

Returns the information about configured remote clusters.

Endpoint documentation

client.cluster.remoteInfo(...)

rerouteedit

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

Endpoint documentation

client.cluster.reroute(...)

stateedit

Returns a comprehensive information about the state of the cluster.

Endpoint documentation

client.cluster.state(...)

statsedit

Returns high-level overview of cluster statistics.

Endpoint documentation

client.cluster.stats(...)

dangling_indicesedit

delete_dangling_indexedit

Deletes the specified dangling index

Endpoint documentation

client.danglingIndices.deleteDanglingIndex(...)

import_dangling_indexedit

Imports the specified dangling index

Endpoint documentation

client.danglingIndices.importDanglingIndex(...)

list_dangling_indicesedit

Returns all dangling indices.

Endpoint documentation

client.danglingIndices.listDanglingIndices(...)

enrichedit

delete_policyedit

Deletes an existing enrich policy and its enrich index.

Endpoint documentation

client.enrich.deletePolicy(...)

execute_policyedit

Creates the enrich index for an existing enrich policy.

Endpoint documentation

client.enrich.executePolicy(...)

get_policyedit

Gets information about an enrich policy.

Endpoint documentation

client.enrich.getPolicy(...)

put_policyedit

Creates a new enrich policy.

Endpoint documentation

client.enrich.putPolicy(...)

statsedit

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

Endpoint documentation

client.enrich.stats(...)

eqledit

deleteedit

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(...)

getedit

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

Endpoint documentation

client.eql.get(...)

get_statusedit

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

Endpoint documentation

client.eql.getStatus(...)

searchedit

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

Endpoint documentation

client.eql.search(...)

featuresedit

get_featuresedit

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_featuresedit

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

Endpoint documentation

client.features.resetFeatures(...)

fleetedit

global_checkpointsedit

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(...)

msearchedit

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(...)

searchedit

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(...)

graphedit

exploreedit

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

Endpoint documentation

client.graph.explore(...)

ilmedit

delete_lifecycleedit

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

Endpoint documentation

client.ilm.deleteLifecycle(...)

explain_lifecycleedit

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

Endpoint documentation

client.ilm.explainLifecycle(...)

get_lifecycleedit

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

Endpoint documentation

client.ilm.getLifecycle(...)

get_statusedit

Retrieves the current index lifecycle management (ILM) status.

Endpoint documentation

client.ilm.getStatus(...)

migrate_to_data_tiersedit

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

Endpoint documentation

client.ilm.migrateToDataTiers(...)

move_to_stepedit

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

Endpoint documentation

client.ilm.moveToStep(...)

put_lifecycleedit

Creates a lifecycle policy

Endpoint documentation

client.ilm.putLifecycle(...)

remove_policyedit

Removes the assigned lifecycle policy and stops managing the specified index

Endpoint documentation

client.ilm.removePolicy(...)

retryedit

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

Endpoint documentation

client.ilm.retry(...)

startedit

Start the index lifecycle management (ILM) plugin.

Endpoint documentation

client.ilm.start(...)

stopedit

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

Endpoint documentation

client.ilm.stop(...)

indicesedit

add_blockedit

Adds a block to an index.

Endpoint documentation

client.indices.addBlock(...)

analyzeedit

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

Endpoint documentation

client.indices.analyze(...)

clear_cacheedit

Clears all or specific caches for one or more indices.

Endpoint documentation

client.indices.clearCache(...)

cloneedit

Clones an index

Endpoint documentation

client.indices.clone(...)

closeedit

Closes an index.

Endpoint documentation

client.indices.close(...)

createedit

Creates an index with optional settings and mappings.

Endpoint documentation

client.indices.create(...)

create_data_streamedit

Creates a data stream

Endpoint documentation

client.indices.createDataStream(...)

data_streams_statsedit

Provides statistics on operations happening in a data stream.

Endpoint documentation

client.indices.dataStreamsStats(...)

deleteedit

Deletes an index.

Endpoint documentation

client.indices.delete(...)

delete_aliasedit

Deletes an alias.

Endpoint documentation

client.indices.deleteAlias(...)

delete_data_streamedit

Deletes a data stream.

Endpoint documentation

client.indices.deleteDataStream(...)

delete_index_templateedit

Deletes an index template.

Endpoint documentation

client.indices.deleteIndexTemplate(...)

delete_templateedit

Deletes an index template.

Endpoint documentation

client.indices.deleteTemplate(...)

disk_usageedit

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

Endpoint documentation

client.indices.diskUsage(...)

existsedit

Returns information about whether a particular index exists.

Endpoint documentation

client.indices.exists(...)

exists_aliasedit

Returns information about whether a particular alias exists.

Endpoint documentation

client.indices.existsAlias(...)

exists_index_templateedit

Returns information about whether a particular index template exists.

Endpoint documentation

client.indices.existsIndexTemplate(...)

exists_templateedit

Returns information about whether a particular index template exists.

Endpoint documentation

client.indices.existsTemplate(...)

field_usage_statsedit

Returns the field usage stats for each field of an index

Endpoint documentation

client.indices.fieldUsageStats(...)

flushedit

Performs the flush operation on one or more indices.

Endpoint documentation

client.indices.flush(...)

forcemergeedit

Performs the force merge operation on one or more indices.

Endpoint documentation

client.indices.forcemerge(...)

getedit

Returns information about one or more indices.

Endpoint documentation

client.indices.get(...)

get_aliasedit

Returns an alias.

Endpoint documentation

client.indices.getAlias(...)

get_data_streamedit

Returns data streams.

Endpoint documentation

client.indices.getDataStream(...)

get_field_mappingedit

Returns mapping for one or more fields.

Endpoint documentation

client.indices.getFieldMapping(...)

get_index_templateedit

Returns an index template.

Endpoint documentation

client.indices.getIndexTemplate(...)

get_mappingedit

Returns mappings for one or more indices.

Endpoint documentation

client.indices.getMapping(...)

get_settingsedit

Returns settings for one or more indices.

Endpoint documentation

client.indices.getSettings(...)

get_templateedit

Returns an index template.

Endpoint documentation

client.indices.getTemplate(...)

migrate_to_data_streamedit

Migrates an alias to a data stream

Endpoint documentation

client.indices.migrateToDataStream(...)

modify_data_streamedit

Modifies a data stream

Endpoint documentation

client.indices.modifyDataStream(...)

openedit

Opens an index.

Endpoint documentation

client.indices.open(...)

promote_data_streamedit

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

Endpoint documentation

client.indices.promoteDataStream(...)

put_aliasedit

Creates or updates an alias.

Endpoint documentation

client.indices.putAlias(...)

put_index_templateedit

Creates or updates an index template.

Endpoint documentation

client.indices.putIndexTemplate(...)

put_mappingedit

Updates the index mappings.

Endpoint documentation

client.indices.putMapping(...)

put_settingsedit

Updates the index settings.

Endpoint documentation

client.indices.putSettings(...)

put_templateedit

Creates or updates an index template.

Endpoint documentation

client.indices.putTemplate(...)

recoveryedit

Returns information about ongoing index shard recoveries.

Endpoint documentation

client.indices.recovery(...)

refreshedit

Performs the refresh operation in one or more indices.

Endpoint documentation

client.indices.refresh(...)

reload_search_analyzersedit

Reloads an index’s search analyzers and their resources.

Endpoint documentation

client.indices.reloadSearchAnalyzers(...)

resolve_indexedit

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

Endpoint documentation

client.indices.resolveIndex(...)

rolloveredit

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(...)

segmentsedit

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

Endpoint documentation

client.indices.segments(...)

shard_storesedit

Provides store information for shard copies of indices.

Endpoint documentation

client.indices.shardStores(...)

shrinkedit

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

Endpoint documentation

client.indices.shrink(...)

simulate_index_templateedit

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

Endpoint documentation

client.indices.simulateIndexTemplate(...)

simulate_templateedit

Simulate resolving the given template name or body

Endpoint documentation

client.indices.simulateTemplate(...)

splitedit

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

Endpoint documentation

client.indices.split(...)

statsedit

Provides statistics on operations happening in an index.

Endpoint documentation

client.indices.stats(...)

unfreezeedit

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_aliasesedit

Updates index aliases.

Endpoint documentation

client.indices.updateAliases(...)

validate_queryedit

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

Endpoint documentation

client.indices.validateQuery(...)

ingestedit

delete_pipelineedit

Deletes a pipeline.

Endpoint documentation

client.ingest.deletePipeline(...)

geo_ip_statsedit

Returns statistical information about geoip databases

Endpoint documentation

client.ingest.geoIpStats(...)

get_pipelineedit

Returns a pipeline.

Endpoint documentation

client.ingest.getPipeline(...)

processor_grokedit

Returns a list of the built-in patterns.

Endpoint documentation

client.ingest.processorGrok(...)

put_pipelineedit

Creates or updates a pipeline.

Endpoint documentation

client.ingest.putPipeline(...)

simulateedit

Allows to simulate a pipeline with example documents.

Endpoint documentation

client.ingest.simulate(...)

licenseedit

deleteedit

Deletes licensing information for the cluster

Endpoint documentation

client.license.delete(...)

getedit

Retrieves licensing information for the cluster

Endpoint documentation

client.license.get(...)

get_basic_statusedit

Retrieves information about the status of the basic license.

Endpoint documentation

client.license.getBasicStatus(...)

get_trial_statusedit

Retrieves information about the status of the trial license.

Endpoint documentation

client.license.getTrialStatus(...)

postedit

Updates the license for the cluster.

Endpoint documentation

client.license.post(...)

post_start_basicedit

Starts an indefinite basic license.

Endpoint documentation

client.license.postStartBasic(...)

post_start_trialedit

starts a limited time trial license.

Endpoint documentation

client.license.postStartTrial(...)

logstashedit

delete_pipelineedit

Deletes Logstash Pipelines used by Central Management

Endpoint documentation

client.logstash.deletePipeline(...)

get_pipelineedit

Retrieves Logstash Pipelines used by Central Management

Endpoint documentation

client.logstash.getPipeline(...)

put_pipelineedit

Adds and updates Logstash Pipelines used for Central Management

Endpoint documentation

client.logstash.putPipeline(...)

migrationedit

deprecationsedit

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_statusedit

Find out whether system features need to be upgraded or not

Endpoint documentation

client.migration.getFeatureUpgradeStatus(...)

post_feature_upgradeedit

Begin upgrades for system features

Endpoint documentation

client.migration.postFeatureUpgrade(...)

mledit

close_jobedit

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_calendaredit

Deletes a calendar.

Endpoint documentation

client.ml.deleteCalendar(...)

delete_calendar_eventedit

Deletes scheduled events from a calendar.

Endpoint documentation

client.ml.deleteCalendarEvent(...)

delete_calendar_jobedit

Deletes anomaly detection jobs from a calendar.

Endpoint documentation

client.ml.deleteCalendarJob(...)

delete_data_frame_analyticsedit

Deletes an existing data frame analytics job.

Endpoint documentation

client.ml.deleteDataFrameAnalytics(...)

delete_datafeededit

Deletes an existing datafeed.

Endpoint documentation

client.ml.deleteDatafeed(...)

delete_expired_dataedit

Deletes expired and unused machine learning data.

Endpoint documentation

client.ml.deleteExpiredData(...)

delete_filteredit

Deletes a filter.

Endpoint documentation

client.ml.deleteFilter(...)

delete_forecastedit

Deletes forecasts from a machine learning job.

Endpoint documentation

client.ml.deleteForecast(...)

delete_jobedit

Deletes an existing anomaly detection job.

Endpoint documentation

client.ml.deleteJob(...)

delete_model_snapshotedit

Deletes an existing model snapshot.

Endpoint documentation

client.ml.deleteModelSnapshot(...)

delete_trained_modeledit

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

Endpoint documentation

client.ml.deleteTrainedModel(...)

delete_trained_model_aliasedit

Deletes a model alias that refers to the trained model

Endpoint documentation

client.ml.deleteTrainedModelAlias(...)

estimate_model_memoryedit

Estimates the model memory

Endpoint documentation

client.ml.estimateModelMemory(...)

evaluate_data_frameedit

Evaluates the data frame analytics for an annotated index.

Endpoint documentation

client.ml.evaluateDataFrame(...)

explain_data_frame_analyticsedit

Explains a data frame analytics config.

Endpoint documentation

client.ml.explainDataFrameAnalytics(...)

flush_jobedit

Forces any buffered data to be processed by the job.

Endpoint documentation

client.ml.flushJob(...)

forecastedit

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

Endpoint documentation

client.ml.forecast(...)

get_bucketsedit

Retrieves anomaly detection job results for one or more buckets.

Endpoint documentation

client.ml.getBuckets(...)

get_calendar_eventsedit

Retrieves information about the scheduled events in calendars.

Endpoint documentation

client.ml.getCalendarEvents(...)

get_calendarsedit

Retrieves configuration information for calendars.

Endpoint documentation

client.ml.getCalendars(...)

get_categoriesedit

Retrieves anomaly detection job results for one or more categories.

Endpoint documentation

client.ml.getCategories(...)

get_data_frame_analyticsedit

Retrieves configuration information for data frame analytics jobs.

Endpoint documentation

client.ml.getDataFrameAnalytics(...)

get_data_frame_analytics_statsedit

Retrieves usage information for data frame analytics jobs.

Endpoint documentation

client.ml.getDataFrameAnalyticsStats(...)

get_datafeed_statsedit

Retrieves usage information for datafeeds.

Endpoint documentation

client.ml.getDatafeedStats(...)

get_datafeedsedit

Retrieves configuration information for datafeeds.

Endpoint documentation

client.ml.getDatafeeds(...)

get_filtersedit

Retrieves filters.

Endpoint documentation

client.ml.getFilters(...)

get_influencersedit

Retrieves anomaly detection job results for one or more influencers.

Endpoint documentation

client.ml.getInfluencers(...)

get_job_statsedit

Retrieves usage information for anomaly detection jobs.

Endpoint documentation

client.ml.getJobStats(...)

get_jobsedit

Retrieves configuration information for anomaly detection jobs.

Endpoint documentation

client.ml.getJobs(...)

get_memory_statsedit

Returns information on how ML is using memory.

Endpoint documentation

client.ml.getMemoryStats(...)

get_model_snapshot_upgrade_statsedit

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

Endpoint documentation

client.ml.getModelSnapshotUpgradeStats(...)

get_model_snapshotsedit

Retrieves information about model snapshots.

Endpoint documentation

client.ml.getModelSnapshots(...)

get_overall_bucketsedit

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

Endpoint documentation

client.ml.getOverallBuckets(...)

get_recordsedit

Retrieves anomaly records for an anomaly detection job.

Endpoint documentation

client.ml.getRecords(...)

get_trained_modelsedit

Retrieves configuration information for a trained inference model.

Endpoint documentation

client.ml.getTrainedModels(...)

get_trained_models_statsedit

Retrieves usage information for trained inference models.

Endpoint documentation

client.ml.getTrainedModelsStats(...)

infer_trained_model_deploymentedit

Evaluate a trained model.

Endpoint documentation

client.ml.inferTrainedModelDeployment(...)

infoedit

Returns defaults and limits used by machine learning.

Endpoint documentation

client.ml.info(...)

open_jobedit

Opens one or more anomaly detection jobs.

Endpoint documentation

client.ml.openJob(...)

post_calendar_eventsedit

Posts scheduled events in a calendar.

Endpoint documentation

client.ml.postCalendarEvents(...)

post_dataedit

Sends data to an anomaly detection job for analysis.

Endpoint documentation

client.ml.postData(...)

preview_data_frame_analyticsedit

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

Endpoint documentation

client.ml.previewDataFrameAnalytics(...)

preview_datafeededit

Previews a datafeed.

Endpoint documentation

client.ml.previewDatafeed(...)

put_calendaredit

Instantiates a calendar.

Endpoint documentation

client.ml.putCalendar(...)

put_calendar_jobedit

Adds an anomaly detection job to a calendar.

Endpoint documentation

client.ml.putCalendarJob(...)

put_data_frame_analyticsedit

Instantiates a data frame analytics job.

Endpoint documentation

client.ml.putDataFrameAnalytics(...)

put_datafeededit

Instantiates a datafeed.

Endpoint documentation

client.ml.putDatafeed(...)

put_filteredit

Instantiates a filter.

Endpoint documentation

client.ml.putFilter(...)

put_jobedit

Instantiates an anomaly detection job.

Endpoint documentation

client.ml.putJob(...)

put_trained_modeledit

Creates an inference trained model.

Endpoint documentation

client.ml.putTrainedModel(...)

put_trained_model_aliasedit

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_partedit

Creates part of a trained model definition

Endpoint documentation

client.ml.putTrainedModelDefinitionPart(...)

put_trained_model_vocabularyedit

Creates a trained model vocabulary

Endpoint documentation

client.ml.putTrainedModelVocabulary(...)

reset_jobedit

Resets an existing anomaly detection job.

Endpoint documentation

client.ml.resetJob(...)

revert_model_snapshotedit

Reverts to a specific snapshot.

Endpoint documentation

client.ml.revertModelSnapshot(...)

set_upgrade_modeedit

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

Endpoint documentation

client.ml.setUpgradeMode(...)

start_data_frame_analyticsedit

Starts a data frame analytics job.

Endpoint documentation

client.ml.startDataFrameAnalytics(...)

start_datafeededit

Starts one or more datafeeds.

Endpoint documentation

client.ml.startDatafeed(...)

start_trained_model_deploymentedit

Start a trained model deployment.

Endpoint documentation

client.ml.startTrainedModelDeployment(...)

stop_data_frame_analyticsedit

Stops one or more data frame analytics jobs.

Endpoint documentation

client.ml.stopDataFrameAnalytics(...)

stop_datafeededit

Stops one or more datafeeds.

Endpoint documentation

client.ml.stopDatafeed(...)

stop_trained_model_deploymentedit

Stop a trained model deployment.

Endpoint documentation

client.ml.stopTrainedModelDeployment(...)

update_data_frame_analyticsedit

Updates certain properties of a data frame analytics job.

Endpoint documentation

client.ml.updateDataFrameAnalytics(...)

update_datafeededit

Updates certain properties of a datafeed.

Endpoint documentation

client.ml.updateDatafeed(...)

update_filteredit

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

Endpoint documentation

client.ml.updateFilter(...)

update_jobedit

Updates certain properties of an anomaly detection job.

Endpoint documentation

client.ml.updateJob(...)

update_model_snapshotedit

Updates certain properties of a snapshot.

Endpoint documentation

client.ml.updateModelSnapshot(...)

upgrade_job_snapshotedit

Upgrades a given job snapshot to the current major version.

Endpoint documentation

client.ml.upgradeJobSnapshot(...)

nodesedit

clear_repositories_metering_archiveedit

Removes the archived repositories metering information present in the cluster.

Endpoint documentation

client.nodes.clearRepositoriesMeteringArchive(...)

get_repositories_metering_infoedit

Returns cluster repositories metering information.

Endpoint documentation

client.nodes.getRepositoriesMeteringInfo(...)

hot_threadsedit

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

Endpoint documentation

client.nodes.hotThreads(...)

infoedit

Returns information about nodes in the cluster.

Endpoint documentation

client.nodes.info(...)

reload_secure_settingsedit

Reloads secure settings.

Endpoint documentation

client.nodes.reloadSecureSettings(...)

statsedit

Returns statistical information about nodes in the cluster.

Endpoint documentation

client.nodes.stats(...)

usageedit

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

Endpoint documentation

client.nodes.usage(...)

rollupedit

delete_jobedit

Deletes an existing rollup job.

Endpoint documentation

client.rollup.deleteJob(...)

get_jobsedit

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

Endpoint documentation

client.rollup.getJobs(...)

get_rollup_capsedit

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_capsedit

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_jobedit

Creates a rollup job.

Endpoint documentation

client.rollup.putJob(...)

rollupedit

Rollup an index

Endpoint documentation

client.rollup.rollup(...)

rollup_searchedit

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

Endpoint documentation

client.rollup.rollupSearch(...)

start_jobedit

Starts an existing, stopped rollup job.

Endpoint documentation

client.rollup.startJob(...)

stop_jobedit

Stops an existing, started rollup job.

Endpoint documentation

client.rollup.stopJob(...)

searchable_snapshotsedit

cache_statsedit

Retrieve node-level cache statistics about searchable snapshots.

Endpoint documentation

client.searchableSnapshots.cacheStats(...)

clear_cacheedit

Clear the cache of searchable snapshots.

Endpoint documentation

client.searchableSnapshots.clearCache(...)

mountedit

Mount a snapshot as a searchable index.

Endpoint documentation

client.searchableSnapshots.mount(...)

statsedit

Retrieve shard-level statistics about searchable snapshots.

Endpoint documentation

client.searchableSnapshots.stats(...)

securityedit

activate_user_profileedit

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

Endpoint documentation

client.security.activateUserProfile(...)

authenticateedit

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

Endpoint documentation

client.security.authenticate(...)

change_passwordedit

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

Endpoint documentation

client.security.changePassword(...)

clear_api_key_cacheedit

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

Endpoint documentation

client.security.clearApiKeyCache(...)

clear_cached_privilegesedit

Evicts application privileges from the native application privileges cache.

Endpoint documentation

client.security.clearCachedPrivileges(...)

clear_cached_realmsedit

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

Endpoint documentation

client.security.clearCachedRealms(...)

clear_cached_rolesedit

Evicts roles from the native role cache.

Endpoint documentation

client.security.clearCachedRoles(...)

clear_cached_service_tokensedit

Evicts tokens from the service account token caches.

Endpoint documentation

client.security.clearCachedServiceTokens(...)

create_api_keyedit

Creates an API key for access without requiring basic authentication.

Endpoint documentation

client.security.createApiKey(...)

create_service_tokenedit

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

Endpoint documentation

client.security.createServiceToken(...)

delete_privilegesedit

Removes application privileges.

Endpoint documentation

client.security.deletePrivileges(...)

delete_roleedit

Removes roles in the native realm.

Endpoint documentation

client.security.deleteRole(...)

delete_role_mappingedit

Removes role mappings.

Endpoint documentation

client.security.deleteRoleMapping(...)

delete_service_tokenedit

Deletes a service account token.

Endpoint documentation

client.security.deleteServiceToken(...)

delete_useredit

Deletes users from the native realm.

Endpoint documentation

client.security.deleteUser(...)

disable_useredit

Disables users in the native realm.

Endpoint documentation

client.security.disableUser(...)

disable_user_profileedit

Disables a user profile so it’s not visible in user profile searches.

Endpoint documentation

client.security.disableUserProfile(...)

enable_useredit

Enables users in the native realm.

Endpoint documentation

client.security.enableUser(...)

enable_user_profileedit

Enables a user profile so it’s visible in user profile searches.

Endpoint documentation

client.security.enableUserProfile(...)

enroll_kibanaedit

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

Endpoint documentation

client.security.enrollKibana(...)

enroll_nodeedit

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

Endpoint documentation

client.security.enrollNode(...)

get_api_keyedit

Retrieves information for one or more API keys.

Endpoint documentation

client.security.getApiKey(...)

get_builtin_privilegesedit

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

Endpoint documentation

client.security.getBuiltinPrivileges(...)

get_privilegesedit

Retrieves application privileges.

Endpoint documentation

client.security.getPrivileges(...)

get_roleedit

Retrieves roles in the native realm.

Endpoint documentation

client.security.getRole(...)

get_role_mappingedit

Retrieves role mappings.

Endpoint documentation

client.security.getRoleMapping(...)

get_service_accountsedit

Retrieves information about service accounts.

Endpoint documentation

client.security.getServiceAccounts(...)

get_service_credentialsedit

Retrieves information of all service credentials for a service account.

Endpoint documentation

client.security.getServiceCredentials(...)

get_tokenedit

Creates a bearer token for access without requiring basic authentication.

Endpoint documentation

client.security.getToken(...)

get_useredit

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

Endpoint documentation

client.security.getUser(...)

get_user_privilegesedit

Retrieves security privileges for the logged in user.

Endpoint documentation

client.security.getUserPrivileges(...)

get_user_profileedit

Retrieves user profile for the given unique ID.

Endpoint documentation

client.security.getUserProfile(...)

grant_api_keyedit

Creates an API key on behalf of another user.

Endpoint documentation

client.security.grantApiKey(...)

has_privilegesedit

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

Endpoint documentation

client.security.hasPrivileges(...)

invalidate_api_keyedit

Invalidates one or more API keys.

Endpoint documentation

client.security.invalidateApiKey(...)

invalidate_tokenedit

Invalidates one or more access tokens or refresh tokens.

Endpoint documentation

client.security.invalidateToken(...)

oidc_authenticateedit

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

Endpoint documentation

client.security.oidcAuthenticate(...)

oidc_logoutedit

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

Endpoint documentation

client.security.oidcLogout(...)

oidc_prepare_authenticationedit

Creates an OAuth 2.0 authentication request as a URL string

Endpoint documentation

client.security.oidcPrepareAuthentication(...)

put_privilegesedit

Adds or updates application privileges.

Endpoint documentation

client.security.putPrivileges(...)

put_roleedit

Adds and updates roles in the native realm.

Endpoint documentation

client.security.putRole(...)

put_role_mappingedit

Creates and updates role mappings.

Endpoint documentation

client.security.putRoleMapping(...)

put_useredit

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

Endpoint documentation

client.security.putUser(...)

query_api_keysedit

Retrieves information for API keys using a subset of query DSL

Endpoint documentation

client.security.queryApiKeys(...)

saml_authenticateedit

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

Endpoint documentation

client.security.samlAuthenticate(...)

saml_complete_logoutedit

Verifies the logout response sent from the SAML IdP

Endpoint documentation

client.security.samlCompleteLogout(...)

saml_invalidateedit

Consumes a SAML LogoutRequest

Endpoint documentation

client.security.samlInvalidate(...)

saml_logoutedit

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

Endpoint documentation

client.security.samlLogout(...)

saml_prepare_authenticationedit

Creates a SAML authentication request

Endpoint documentation

client.security.samlPrepareAuthentication(...)

saml_service_provider_metadataedit

Generates SAML metadata for the Elastic stack SAML 2.0 Service Provider

Endpoint documentation

client.security.samlServiceProviderMetadata(...)

suggest_user_profilesedit

Get suggestions for user profiles that match specified search criteria.

Endpoint documentation

client.security.suggestUserProfiles(...)

update_user_profile_dataedit

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

Endpoint documentation

client.security.updateUserProfileData(...)

slmedit

delete_lifecycleedit

Deletes an existing snapshot lifecycle policy.

Endpoint documentation

client.slm.deleteLifecycle(...)

execute_lifecycleedit

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

Endpoint documentation

client.slm.executeLifecycle(...)

execute_retentionedit

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

Endpoint documentation

client.slm.executeRetention(...)

get_lifecycleedit

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

Endpoint documentation

client.slm.getLifecycle(...)

get_statsedit

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

Endpoint documentation

client.slm.getStats(...)

get_statusedit

Retrieves the status of snapshot lifecycle management (SLM).

Endpoint documentation

client.slm.getStatus(...)

put_lifecycleedit

Creates or updates a snapshot lifecycle policy.

Endpoint documentation

client.slm.putLifecycle(...)

startedit

Turns on snapshot lifecycle management (SLM).

Endpoint documentation

client.slm.start(...)

stopedit

Turns off snapshot lifecycle management (SLM).

Endpoint documentation

client.slm.stop(...)

snapshotedit

cleanup_repositoryedit

Removes stale data from repository.

Endpoint documentation

client.snapshot.cleanupRepository(...)

cloneedit

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

Endpoint documentation

client.snapshot.clone(...)

createedit

Creates a snapshot in a repository.

Endpoint documentation

client.snapshot.create(...)

create_repositoryedit

Creates a repository.

Endpoint documentation

client.snapshot.createRepository(...)

deleteedit

Deletes one or more snapshots.

Endpoint documentation

client.snapshot.delete(...)

delete_repositoryedit

Deletes a repository.

Endpoint documentation

client.snapshot.deleteRepository(...)

getedit

Returns information about a snapshot.

Endpoint documentation

client.snapshot.get(...)

get_repositoryedit

Returns information about a repository.

Endpoint documentation

client.snapshot.getRepository(...)

repository_analyzeedit

Analyzes a repository for correctness and performance

Endpoint documentation

client.snapshot.repositoryAnalyze(...)

restoreedit

Restores a snapshot.

Endpoint documentation

client.snapshot.restore(...)

statusedit

Returns information about the status of a snapshot.

Endpoint documentation

client.snapshot.status(...)

verify_repositoryedit

Verifies a repository.

Endpoint documentation

client.snapshot.verifyRepository(...)

sqledit

clear_cursoredit

Clears the SQL cursor

Endpoint documentation

client.sql.clearCursor(...)

delete_asyncedit

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_asyncedit

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

Endpoint documentation

client.sql.getAsync(...)

get_async_statusedit

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

Endpoint documentation

client.sql.getAsyncStatus(...)

queryedit

Executes a SQL request

Endpoint documentation

client.sql.query(...)

translateedit

Translates SQL into Elasticsearch queries

Endpoint documentation

client.sql.translate(...)

ssledit

certificatesedit

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

Endpoint documentation

client.ssl.certificates(...)

tasksedit

canceledit

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

Endpoint documentation

client.tasks.cancel(...)

getedit

Returns information about a task.

Endpoint documentation

client.tasks.get(...)

listedit

Returns a list of tasks.

Endpoint documentation

client.tasks.list(...)

text_structureedit

find_structureedit

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(...)

transformedit

delete_transformedit

Deletes an existing transform.

Endpoint documentation

client.transform.deleteTransform(...)

get_transformedit

Retrieves configuration information for transforms.

Endpoint documentation

client.transform.getTransform(...)

get_transform_statsedit

Retrieves usage information for transforms.

Endpoint documentation

client.transform.getTransformStats(...)

preview_transformedit

Previews a transform.

Endpoint documentation

client.transform.previewTransform(...)

put_transformedit

Instantiates a transform.

Endpoint documentation

client.transform.putTransform(...)

reset_transformedit

Resets an existing transform.

Endpoint documentation

client.transform.resetTransform(...)

start_transformedit

Starts one or more transforms.

Endpoint documentation

client.transform.startTransform(...)

stop_transformedit

Stops one or more transforms.

Endpoint documentation

client.transform.stopTransform(...)

update_transformedit

Updates certain properties of a transform.

Endpoint documentation

client.transform.updateTransform(...)

upgrade_transformsedit

Upgrades all transforms.

Endpoint documentation

client.transform.upgradeTransforms(...)

watcheredit

ack_watchedit

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

Endpoint documentation

client.watcher.ackWatch(...)

activate_watchedit

Activates a currently inactive watch.

Endpoint documentation

client.watcher.activateWatch(...)

deactivate_watchedit

Deactivates a currently active watch.

Endpoint documentation

client.watcher.deactivateWatch(...)

delete_watchedit

Removes a watch from Watcher.

Endpoint documentation

client.watcher.deleteWatch(...)

execute_watchedit

Forces the execution of a stored watch.

Endpoint documentation

client.watcher.executeWatch(...)

get_watchedit

Retrieves a watch by its ID.

Endpoint documentation

client.watcher.getWatch(...)

put_watchedit

Creates a new watch, or updates an existing one.

Endpoint documentation

client.watcher.putWatch(...)

query_watchesedit

Retrieves stored watches.

Endpoint documentation

client.watcher.queryWatches(...)

startedit

Starts Watcher if it is not already running.

Endpoint documentation

client.watcher.start(...)

statsedit

Retrieves the current Watcher metrics.

Endpoint documentation

client.watcher.stats(...)

stopedit

Stops Watcher if it is running.

Endpoint documentation

client.watcher.stop(...)

xpackedit

infoedit

Retrieves information about the installed X-Pack features.

Endpoint documentation

client.xpack.info(...)

usageedit

Retrieves usage information about the installed X-Pack features.

Endpoint documentation

client.xpack.usage(...)