API Reference
editAPI Reference
editbulk
editAllows to perform multiple index/update/delete operations in a single request.
client.bulk(...)
clear_scroll
editExplicitly clears the search context for a scroll.
client.clearScroll(...)
close_point_in_time
editClose a point in time
client.closePointInTime(...)
count
editReturns number of documents matching a query.
client.count(...)
create
editCreates a new document in the index.
Returns a 409 response when a document with a same ID already exists in the index.
client.create(...)
delete
editRemoves a document from the index.
client.delete(...)
delete_by_query
editDeletes documents matching the provided query.
client.deleteByQuery(...)
delete_by_query_rethrottle
editChanges the number of requests per second for a particular Delete By Query operation.
client.deleteByQueryRethrottle(...)
delete_script
editDeletes a script.
client.deleteScript(...)
exists
editReturns information about whether a document exists in an index.
client.exists(...)
exists_source
editReturns information about whether a document source exists in an index.
client.existsSource(...)
explain
editReturns information about why a specific matches (or doesn’t match) a query.
client.explain(...)
field_caps
editReturns the information about the capabilities of fields among multiple indices.
client.fieldCaps(...)
get
editReturns a document.
client.get(...)
get_script
editReturns a script.
client.getScript(...)
get_script_context
editReturns all script contexts.
client.getScriptContext(...)
get_script_languages
editReturns available script types, languages and contexts
client.getScriptLanguages(...)
get_source
editReturns the source of a document.
client.getSource(...)
index
editCreates or updates a document in an index.
client.index(...)
info
editReturns basic information about the cluster.
client.info(...)
knn_search
editPerforms a kNN search.
client.knnSearch(...)
mget
editAllows to get multiple documents in one request.
client.mget(...)
msearch
editAllows to execute several search operations in one request.
client.msearch(...)
msearch_template
editAllows to execute several search template operations in one request.
client.msearchTemplate(...)
mtermvectors
editReturns multiple termvectors in one request.
client.mtermvectors(...)
open_point_in_time
editOpen a point in time that can be used in subsequent searches
client.openPointInTime(...)
ping
editReturns whether the cluster is running.
client.ping(...)
put_script
editCreates or updates a script.
client.putScript(...)
rank_eval
editAllows to evaluate the quality of ranked search results over a set of typical search queries
client.rankEval(...)
reindex
editAllows 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.
client.reindex(...)
reindex_rethrottle
editChanges the number of requests per second for a particular Reindex operation.
client.reindexRethrottle(...)
render_search_template
editAllows to use the Mustache language to pre-render a search definition.
client.renderSearchTemplate(...)
scripts_painless_execute
editAllows an arbitrary script to be executed and a result to be returned
client.scriptsPainlessExecute(...)
scroll
editAllows to retrieve a large numbers of results from a single search request.
client.scroll(...)
search
editReturns results matching a query.
client.search(...)
search_mvt
editSearches a vector tile for geospatial values. Returns results as a binary Mapbox vector tile.
client.searchMvt(...)
search_shards
editReturns information about the indices and shards that a search request would be executed against.
client.searchShards(...)
search_template
editAllows to use the Mustache language to pre-render a search definition.
client.searchTemplate(...)
terms_enum
editThe 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.
client.termsEnum(...)
termvectors
editReturns information and statistics about terms in the fields of a particular document.
client.termvectors(...)
update
editUpdates a document with a script or partial document.
client.update(...)
update_by_query
editPerforms an update on every document in the index without changing the source, for example to pick up a mapping change.
client.updateByQuery(...)
update_by_query_rethrottle
editChanges the number of requests per second for a particular Update By Query operation.
client.updateByQueryRethrottle(...)
async_search
editdelete
editDeletes an async search by ID. If the search is still running, the search request will be cancelled. Otherwise, the saved search results are deleted.
client.asyncSearch.delete(...)
get
editRetrieves the results of a previously submitted async search request given its ID.
client.asyncSearch.get(...)
status
editRetrieves the status of a previously submitted async search request given its ID.
client.asyncSearch.status(...)
submit
editExecutes a search request asynchronously.
client.asyncSearch.submit(...)
cat
editaliases
editShows information about currently configured aliases to indices including filter and routing infos.
client.cat.aliases(...)
allocation
editProvides a snapshot of how many shards are allocated to each data node and how much disk space they are using.
client.cat.allocation(...)
component_templates
editReturns information about existing component_templates templates.
client.cat.componentTemplates(...)
count
editProvides quick access to the document count of the entire cluster, or individual indices.
client.cat.count(...)
fielddata
editShows how much heap memory is currently being used by fielddata on every data node in the cluster.
client.cat.fielddata(...)
health
editReturns a concise representation of the cluster health.
client.cat.health(...)
help
editReturns help for the Cat APIs.
client.cat.help(...)
indices
editReturns information about indices: number of primaries and replicas, document counts, disk size, …
client.cat.indices(...)
master
editReturns information about the master node.
client.cat.master(...)
ml_data_frame_analytics
editGets configuration and usage information about data frame analytics jobs.
client.cat.mlDataFrameAnalytics(...)
ml_datafeeds
editGets configuration and usage information about datafeeds.
client.cat.mlDatafeeds(...)
ml_jobs
editGets configuration and usage information about anomaly detection jobs.
client.cat.mlJobs(...)
ml_trained_models
editGets configuration and usage information about inference trained models.
client.cat.mlTrainedModels(...)
nodeattrs
editReturns information about custom node attributes.
client.cat.nodeattrs(...)
nodes
editReturns basic statistics about performance of cluster nodes.
client.cat.nodes(...)
pending_tasks
editReturns a concise representation of the cluster pending tasks.
client.cat.pendingTasks(...)
plugins
editReturns information about installed plugins across nodes node.
client.cat.plugins(...)
recovery
editReturns information about index shard recoveries, both on-going completed.
client.cat.recovery(...)
repositories
editReturns information about snapshot repositories registered in the cluster.
client.cat.repositories(...)
segments
editProvides low-level information about the segments in the shards of an index.
client.cat.segments(...)
shards
editProvides a detailed view of shard allocation on nodes.
client.cat.shards(...)
snapshots
editReturns all snapshots in a specific repository.
client.cat.snapshots(...)
tasks
editReturns information about the tasks currently executing on one or more nodes in the cluster.
client.cat.tasks(...)
templates
editReturns information about existing templates.
client.cat.templates(...)
thread_pool
editReturns cluster-wide thread pool statistics per node. By default the active, queue and rejected statistics are returned for all thread pools.
client.cat.threadPool(...)
transforms
editGets configuration and usage information about transforms.
client.cat.transforms(...)
ccr
editdelete_auto_follow_pattern
editDeletes auto-follow patterns.
client.ccr.deleteAutoFollowPattern(...)
follow
editCreates a new follower index configured to follow the referenced leader index.
client.ccr.follow(...)
follow_info
editRetrieves information about all follower indices, including parameters and status for each follower index
client.ccr.followInfo(...)
follow_stats
editRetrieves follower stats. return shard-level stats about the following tasks associated with each shard for the specified indices.
client.ccr.followStats(...)
forget_follower
editRemoves the follower retention leases from the leader.
client.ccr.forgetFollower(...)
get_auto_follow_pattern
editGets configured auto-follow patterns. Returns the specified auto-follow pattern collection.
client.ccr.getAutoFollowPattern(...)
pause_auto_follow_pattern
editPauses an auto-follow pattern
client.ccr.pauseAutoFollowPattern(...)
pause_follow
editPauses a follower index. The follower index will not fetch any additional operations from the leader index.
client.ccr.pauseFollow(...)
put_auto_follow_pattern
editCreates 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.
client.ccr.putAutoFollowPattern(...)
resume_auto_follow_pattern
editResumes an auto-follow pattern that has been paused
client.ccr.resumeAutoFollowPattern(...)
resume_follow
editResumes a follower index that has been paused
client.ccr.resumeFollow(...)
stats
editGets all stats related to cross-cluster replication.
client.ccr.stats(...)
unfollow
editStops the following task associated with a follower index and removes index metadata and settings associated with cross-cluster replication.
client.ccr.unfollow(...)
cluster
editallocation_explain
editProvides explanations for shard allocations in the cluster.
client.cluster.allocationExplain(...)
delete_component_template
editDeletes a component template
client.cluster.deleteComponentTemplate(...)
delete_voting_config_exclusions
editClears cluster voting config exclusions.
client.cluster.deleteVotingConfigExclusions(...)
exists_component_template
editReturns information about whether a particular component template exist
client.cluster.existsComponentTemplate(...)
get_component_template
editReturns one or more component templates
client.cluster.getComponentTemplate(...)
get_settings
editReturns cluster settings.
client.cluster.getSettings(...)
health
editReturns basic information about the health of the cluster.
client.cluster.health(...)
pending_tasks
editReturns a list of any cluster-level changes (e.g. create index, update mapping, allocate or fail shard) which have not yet been executed.
client.cluster.pendingTasks(...)
post_voting_config_exclusions
editUpdates the cluster voting config exclusions by node ids or node names.
client.cluster.postVotingConfigExclusions(...)
put_component_template
editCreates or updates a component template
client.cluster.putComponentTemplate(...)
put_settings
editUpdates the cluster settings.
client.cluster.putSettings(...)
remote_info
editReturns the information about configured remote clusters.
client.cluster.remoteInfo(...)
reroute
editAllows to manually change the allocation of individual shards in the cluster.
client.cluster.reroute(...)
state
editReturns a comprehensive information about the state of the cluster.
client.cluster.state(...)
stats
editReturns high-level overview of cluster statistics.
client.cluster.stats(...)
dangling_indices
editdelete_dangling_index
editDeletes the specified dangling index
client.danglingIndices.deleteDanglingIndex(...)
import_dangling_index
editImports the specified dangling index
client.danglingIndices.importDanglingIndex(...)
list_dangling_indices
editReturns all dangling indices.
client.danglingIndices.listDanglingIndices(...)
enrich
editdelete_policy
editDeletes an existing enrich policy and its enrich index.
client.enrich.deletePolicy(...)
execute_policy
editCreates the enrich index for an existing enrich policy.
client.enrich.executePolicy(...)
get_policy
editGets information about an enrich policy.
client.enrich.getPolicy(...)
put_policy
editCreates a new enrich policy.
client.enrich.putPolicy(...)
stats
editGets enrich coordinator statistics and information about enrich policies that are currently executing.
client.enrich.stats(...)
eql
editdelete
editDeletes 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.
client.eql.delete(...)
get
editReturns async results from previously executed Event Query Language (EQL) search
client.eql.get(...)
get_status
editReturns the status of a previously submitted async or stored Event Query Language (EQL) search
client.eql.getStatus(...)
search
editReturns results matching a query expressed in Event Query Language (EQL)
client.eql.search(...)
features
editget_features
editGets a list of features which can be included in snapshots using the feature_states field when creating a snapshot
client.features.getFeatures(...)
reset_features
editResets the internal state of features, usually by deleting system indices
client.features.resetFeatures(...)
fleet
editglobal_checkpoints
editReturns the current global checkpoints for an index. This API is design for internal use by the fleet server project.
client.fleet.globalCheckpoints(...)
msearch
editMulti 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
editSearch 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
editexplore
editExplore extracted and summarized information about the documents and terms in an index.
client.graph.explore(...)
ilm
editdelete_lifecycle
editDeletes the specified lifecycle policy definition. A currently used policy cannot be deleted.
client.ilm.deleteLifecycle(...)
explain_lifecycle
editRetrieves information about the index’s current lifecycle state, such as the currently executing phase, action, and step.
client.ilm.explainLifecycle(...)
get_lifecycle
editReturns the specified policy definition. Includes the policy version and last modified date.
client.ilm.getLifecycle(...)
get_status
editRetrieves the current index lifecycle management (ILM) status.
client.ilm.getStatus(...)
migrate_to_data_tiers
editMigrates the indices and ILM policies away from custom node attribute allocation routing to data tiers routing
client.ilm.migrateToDataTiers(...)
move_to_step
editManually moves an index into the specified step and executes that step.
client.ilm.moveToStep(...)
put_lifecycle
editCreates a lifecycle policy
client.ilm.putLifecycle(...)
remove_policy
editRemoves the assigned lifecycle policy and stops managing the specified index
client.ilm.removePolicy(...)
retry
editRetries executing the policy for an index that is in the ERROR step.
client.ilm.retry(...)
start
editStart the index lifecycle management (ILM) plugin.
client.ilm.start(...)
stop
editHalts all lifecycle management operations and stops the index lifecycle management (ILM) plugin
client.ilm.stop(...)
indices
editadd_block
editAdds a block to an index.
client.indices.addBlock(...)
analyze
editPerforms the analysis process on a text and return the tokens breakdown of the text.
client.indices.analyze(...)
clear_cache
editClears all or specific caches for one or more indices.
client.indices.clearCache(...)
clone
editClones an index
client.indices.clone(...)
close
editCloses an index.
client.indices.close(...)
create
editCreates an index with optional settings and mappings.
client.indices.create(...)
create_data_stream
editCreates a data stream
client.indices.createDataStream(...)
data_streams_stats
editProvides statistics on operations happening in a data stream.
client.indices.dataStreamsStats(...)
delete
editDeletes an index.
client.indices.delete(...)
delete_alias
editDeletes an alias.
client.indices.deleteAlias(...)
delete_data_stream
editDeletes a data stream.
client.indices.deleteDataStream(...)
delete_index_template
editDeletes an index template.
client.indices.deleteIndexTemplate(...)
delete_template
editDeletes an index template.
client.indices.deleteTemplate(...)
disk_usage
editAnalyzes the disk usage of each field of an index or data stream
client.indices.diskUsage(...)
exists
editReturns information about whether a particular index exists.
client.indices.exists(...)
exists_alias
editReturns information about whether a particular alias exists.
client.indices.existsAlias(...)
exists_index_template
editReturns information about whether a particular index template exists.
client.indices.existsIndexTemplate(...)
exists_template
editReturns information about whether a particular index template exists.
client.indices.existsTemplate(...)
field_usage_stats
editReturns the field usage stats for each field of an index
client.indices.fieldUsageStats(...)
flush
editPerforms the flush operation on one or more indices.
client.indices.flush(...)
forcemerge
editPerforms the force merge operation on one or more indices.
client.indices.forcemerge(...)
get
editReturns information about one or more indices.
client.indices.get(...)
get_alias
editReturns an alias.
client.indices.getAlias(...)
get_data_stream
editReturns data streams.
client.indices.getDataStream(...)
get_field_mapping
editReturns mapping for one or more fields.
client.indices.getFieldMapping(...)
get_index_template
editReturns an index template.
client.indices.getIndexTemplate(...)
get_mapping
editReturns mappings for one or more indices.
client.indices.getMapping(...)
get_settings
editReturns settings for one or more indices.
client.indices.getSettings(...)
get_template
editReturns an index template.
client.indices.getTemplate(...)
migrate_to_data_stream
editMigrates an alias to a data stream
client.indices.migrateToDataStream(...)
modify_data_stream
editModifies a data stream
client.indices.modifyDataStream(...)
open
editOpens an index.
client.indices.open(...)
promote_data_stream
editPromotes a data stream from a replicated data stream managed by CCR to a regular data stream
client.indices.promoteDataStream(...)
put_alias
editCreates or updates an alias.
client.indices.putAlias(...)
put_index_template
editCreates or updates an index template.
client.indices.putIndexTemplate(...)
put_mapping
editUpdates the index mappings.
client.indices.putMapping(...)
put_settings
editUpdates the index settings.
client.indices.putSettings(...)
put_template
editCreates or updates an index template.
client.indices.putTemplate(...)
recovery
editReturns information about ongoing index shard recoveries.
client.indices.recovery(...)
refresh
editPerforms the refresh operation in one or more indices.
client.indices.refresh(...)
reload_search_analyzers
editReloads an index’s search analyzers and their resources.
client.indices.reloadSearchAnalyzers(...)
resolve_index
editReturns information about any matching indices, aliases, and data streams
client.indices.resolveIndex(...)
rollover
editUpdates an alias to point to a new index when the existing index is considered to be too large or too old.
client.indices.rollover(...)
segments
editProvides low-level information about segments in a Lucene index.
client.indices.segments(...)
shard_stores
editProvides store information for shard copies of indices.
client.indices.shardStores(...)
shrink
editAllow to shrink an existing index into a new index with fewer primary shards.
client.indices.shrink(...)
simulate_index_template
editSimulate matching the given index name against the index templates in the system
client.indices.simulateIndexTemplate(...)
simulate_template
editSimulate resolving the given template name or body
client.indices.simulateTemplate(...)
split
editAllows you to split an existing index into a new index with more primary shards.
client.indices.split(...)
stats
editProvides statistics on operations happening in an index.
client.indices.stats(...)
unfreeze
editUnfreezes an index. When a frozen index is unfrozen, the index goes through the normal recovery process and becomes writeable again.
client.indices.unfreeze(...)
update_aliases
editUpdates index aliases.
client.indices.updateAliases(...)
validate_query
editAllows a user to validate a potentially expensive query without executing it.
client.indices.validateQuery(...)
ingest
editdelete_pipeline
editDeletes a pipeline.
client.ingest.deletePipeline(...)
geo_ip_stats
editReturns statistical information about geoip databases
client.ingest.geoIpStats(...)
get_pipeline
editReturns a pipeline.
client.ingest.getPipeline(...)
processor_grok
editReturns a list of the built-in patterns.
client.ingest.processorGrok(...)
put_pipeline
editCreates or updates a pipeline.
client.ingest.putPipeline(...)
simulate
editAllows to simulate a pipeline with example documents.
client.ingest.simulate(...)
license
editdelete
editDeletes licensing information for the cluster
client.license.delete(...)
get
editRetrieves licensing information for the cluster
client.license.get(...)
get_basic_status
editRetrieves information about the status of the basic license.
client.license.getBasicStatus(...)
get_trial_status
editRetrieves information about the status of the trial license.
client.license.getTrialStatus(...)
post
editUpdates the license for the cluster.
client.license.post(...)
post_start_basic
editStarts an indefinite basic license.
client.license.postStartBasic(...)
post_start_trial
editstarts a limited time trial license.
client.license.postStartTrial(...)
logstash
editdelete_pipeline
editDeletes Logstash Pipelines used by Central Management
client.logstash.deletePipeline(...)
get_pipeline
editRetrieves Logstash Pipelines used by Central Management
client.logstash.getPipeline(...)
put_pipeline
editAdds and updates Logstash Pipelines used for Central Management
client.logstash.putPipeline(...)
migration
editdeprecations
editRetrieves information about different cluster, node, and index level settings that use deprecated features that will be removed or changed in the next major version.
client.migration.deprecations(...)
get_feature_upgrade_status
editFind out whether system features need to be upgraded or not
client.migration.getFeatureUpgradeStatus(...)
post_feature_upgrade
editBegin upgrades for system features
client.migration.postFeatureUpgrade(...)
ml
editclose_job
editCloses one or more anomaly detection jobs. A job can be opened and closed multiple times throughout its lifecycle.
client.ml.closeJob(...)
delete_calendar
editDeletes a calendar.
client.ml.deleteCalendar(...)
delete_calendar_event
editDeletes scheduled events from a calendar.
client.ml.deleteCalendarEvent(...)
delete_calendar_job
editDeletes anomaly detection jobs from a calendar.
client.ml.deleteCalendarJob(...)
delete_data_frame_analytics
editDeletes an existing data frame analytics job.
client.ml.deleteDataFrameAnalytics(...)
delete_datafeed
editDeletes an existing datafeed.
client.ml.deleteDatafeed(...)
delete_expired_data
editDeletes expired and unused machine learning data.
client.ml.deleteExpiredData(...)
delete_filter
editDeletes a filter.
client.ml.deleteFilter(...)
delete_forecast
editDeletes forecasts from a machine learning job.
client.ml.deleteForecast(...)
delete_job
editDeletes an existing anomaly detection job.
client.ml.deleteJob(...)
delete_model_snapshot
editDeletes an existing model snapshot.
client.ml.deleteModelSnapshot(...)
delete_trained_model
editDeletes an existing trained inference model that is currently not referenced by an ingest pipeline.
client.ml.deleteTrainedModel(...)
delete_trained_model_alias
editDeletes a model alias that refers to the trained model
client.ml.deleteTrainedModelAlias(...)
estimate_model_memory
editEstimates the model memory
client.ml.estimateModelMemory(...)
evaluate_data_frame
editEvaluates the data frame analytics for an annotated index.
client.ml.evaluateDataFrame(...)
explain_data_frame_analytics
editExplains a data frame analytics config.
client.ml.explainDataFrameAnalytics(...)
flush_job
editForces any buffered data to be processed by the job.
client.ml.flushJob(...)
forecast
editPredicts the future behavior of a time series by using its historical behavior.
client.ml.forecast(...)
get_buckets
editRetrieves anomaly detection job results for one or more buckets.
client.ml.getBuckets(...)
get_calendar_events
editRetrieves information about the scheduled events in calendars.
client.ml.getCalendarEvents(...)
get_calendars
editRetrieves configuration information for calendars.
client.ml.getCalendars(...)
get_categories
editRetrieves anomaly detection job results for one or more categories.
client.ml.getCategories(...)
get_data_frame_analytics
editRetrieves configuration information for data frame analytics jobs.
client.ml.getDataFrameAnalytics(...)
get_data_frame_analytics_stats
editRetrieves usage information for data frame analytics jobs.
client.ml.getDataFrameAnalyticsStats(...)
get_datafeed_stats
editRetrieves usage information for datafeeds.
client.ml.getDatafeedStats(...)
get_datafeeds
editRetrieves configuration information for datafeeds.
client.ml.getDatafeeds(...)
get_filters
editRetrieves filters.
client.ml.getFilters(...)
get_influencers
editRetrieves anomaly detection job results for one or more influencers.
client.ml.getInfluencers(...)
get_job_stats
editRetrieves usage information for anomaly detection jobs.
client.ml.getJobStats(...)
get_jobs
editRetrieves configuration information for anomaly detection jobs.
client.ml.getJobs(...)
get_memory_stats
editReturns information on how ML is using memory.
client.ml.getMemoryStats(...)
get_model_snapshot_upgrade_stats
editGets stats for anomaly detection job model snapshot upgrades that are in progress.
client.ml.getModelSnapshotUpgradeStats(...)
get_model_snapshots
editRetrieves information about model snapshots.
client.ml.getModelSnapshots(...)
get_overall_buckets
editRetrieves overall bucket results that summarize the bucket results of multiple anomaly detection jobs.
client.ml.getOverallBuckets(...)
get_records
editRetrieves anomaly records for an anomaly detection job.
client.ml.getRecords(...)
get_trained_models
editRetrieves configuration information for a trained inference model.
client.ml.getTrainedModels(...)
get_trained_models_stats
editRetrieves usage information for trained inference models.
client.ml.getTrainedModelsStats(...)
infer_trained_model
editEvaluate a trained model.
client.ml.inferTrainedModel(...)
info
editReturns defaults and limits used by machine learning.
client.ml.info(...)
open_job
editOpens one or more anomaly detection jobs.
client.ml.openJob(...)
post_calendar_events
editPosts scheduled events in a calendar.
client.ml.postCalendarEvents(...)
post_data
editSends data to an anomaly detection job for analysis.
client.ml.postData(...)
preview_data_frame_analytics
editPreviews that will be analyzed given a data frame analytics config.
client.ml.previewDataFrameAnalytics(...)
preview_datafeed
editPreviews a datafeed.
client.ml.previewDatafeed(...)
put_calendar
editInstantiates a calendar.
client.ml.putCalendar(...)
put_calendar_job
editAdds an anomaly detection job to a calendar.
client.ml.putCalendarJob(...)
put_data_frame_analytics
editInstantiates a data frame analytics job.
client.ml.putDataFrameAnalytics(...)
put_datafeed
editInstantiates a datafeed.
client.ml.putDatafeed(...)
put_filter
editInstantiates a filter.
client.ml.putFilter(...)
put_job
editInstantiates an anomaly detection job.
client.ml.putJob(...)
put_trained_model
editCreates an inference trained model.
client.ml.putTrainedModel(...)
put_trained_model_alias
editCreates a new model alias (or reassigns an existing one) to refer to the trained model
client.ml.putTrainedModelAlias(...)
put_trained_model_definition_part
editCreates part of a trained model definition
client.ml.putTrainedModelDefinitionPart(...)
put_trained_model_vocabulary
editCreates a trained model vocabulary
client.ml.putTrainedModelVocabulary(...)
reset_job
editResets an existing anomaly detection job.
client.ml.resetJob(...)
revert_model_snapshot
editReverts to a specific snapshot.
client.ml.revertModelSnapshot(...)
set_upgrade_mode
editSets a cluster wide upgrade_mode setting that prepares machine learning indices for an upgrade.
client.ml.setUpgradeMode(...)
start_data_frame_analytics
editStarts a data frame analytics job.
client.ml.startDataFrameAnalytics(...)
start_datafeed
editStarts one or more datafeeds.
client.ml.startDatafeed(...)
start_trained_model_deployment
editStart a trained model deployment.
client.ml.startTrainedModelDeployment(...)
stop_data_frame_analytics
editStops one or more data frame analytics jobs.
client.ml.stopDataFrameAnalytics(...)
stop_datafeed
editStops one or more datafeeds.
client.ml.stopDatafeed(...)
stop_trained_model_deployment
editStop a trained model deployment.
client.ml.stopTrainedModelDeployment(...)
update_data_frame_analytics
editUpdates certain properties of a data frame analytics job.
client.ml.updateDataFrameAnalytics(...)
update_datafeed
editUpdates certain properties of a datafeed.
client.ml.updateDatafeed(...)
update_filter
editUpdates the description of a filter, adds items, or removes items.
client.ml.updateFilter(...)
update_job
editUpdates certain properties of an anomaly detection job.
client.ml.updateJob(...)
update_model_snapshot
editUpdates certain properties of a snapshot.
client.ml.updateModelSnapshot(...)
upgrade_job_snapshot
editUpgrades a given job snapshot to the current major version.
client.ml.upgradeJobSnapshot(...)
nodes
editclear_repositories_metering_archive
editRemoves the archived repositories metering information present in the cluster.
client.nodes.clearRepositoriesMeteringArchive(...)
get_repositories_metering_info
editReturns cluster repositories metering information.
client.nodes.getRepositoriesMeteringInfo(...)
hot_threads
editReturns information about hot threads on each node in the cluster.
client.nodes.hotThreads(...)
info
editReturns information about nodes in the cluster.
client.nodes.info(...)
reload_secure_settings
editReloads secure settings.
client.nodes.reloadSecureSettings(...)
stats
editReturns statistical information about nodes in the cluster.
client.nodes.stats(...)
usage
editReturns low-level information about REST actions usage on nodes.
client.nodes.usage(...)
rollup
editdelete_job
editDeletes an existing rollup job.
client.rollup.deleteJob(...)
get_jobs
editRetrieves the configuration, stats, and status of rollup jobs.
client.rollup.getJobs(...)
get_rollup_caps
editReturns the capabilities of any rollup jobs that have been configured for a specific index or index pattern.
client.rollup.getRollupCaps(...)
get_rollup_index_caps
editReturns the rollup capabilities of all jobs inside of a rollup index (e.g. the index where rollup data is stored).
client.rollup.getRollupIndexCaps(...)
put_job
editCreates a rollup job.
client.rollup.putJob(...)
rollup
editRollup an index
client.rollup.rollup(...)
rollup_search
editEnables searching rolled-up data using the standard query DSL.
client.rollup.rollupSearch(...)
start_job
editStarts an existing, stopped rollup job.
client.rollup.startJob(...)
stop_job
editStops an existing, started rollup job.
client.rollup.stopJob(...)
searchable_snapshots
editcache_stats
editRetrieve node-level cache statistics about searchable snapshots.
client.searchableSnapshots.cacheStats(...)
clear_cache
editClear the cache of searchable snapshots.
client.searchableSnapshots.clearCache(...)
mount
editMount a snapshot as a searchable index.
client.searchableSnapshots.mount(...)
stats
editRetrieve shard-level statistics about searchable snapshots.
client.searchableSnapshots.stats(...)
security
editauthenticate
editEnables authentication as a user and retrieve information about the authenticated user.
client.security.authenticate(...)
change_password
editChanges the passwords of users in the native realm and built-in users.
client.security.changePassword(...)
clear_api_key_cache
editClear a subset or all entries from the API key cache.
client.security.clearApiKeyCache(...)
clear_cached_privileges
editEvicts application privileges from the native application privileges cache.
client.security.clearCachedPrivileges(...)
clear_cached_realms
editEvicts users from the user cache. Can completely clear the cache or evict specific users.
client.security.clearCachedRealms(...)
clear_cached_roles
editEvicts roles from the native role cache.
client.security.clearCachedRoles(...)
clear_cached_service_tokens
editEvicts tokens from the service account token caches.
client.security.clearCachedServiceTokens(...)
create_api_key
editCreates an API key for access without requiring basic authentication.
client.security.createApiKey(...)
create_service_token
editCreates a service account token for access without requiring basic authentication.
client.security.createServiceToken(...)
delete_privileges
editRemoves application privileges.
client.security.deletePrivileges(...)
delete_role
editRemoves roles in the native realm.
client.security.deleteRole(...)
delete_role_mapping
editRemoves role mappings.
client.security.deleteRoleMapping(...)
delete_service_token
editDeletes a service account token.
client.security.deleteServiceToken(...)
delete_user
editDeletes users from the native realm.
client.security.deleteUser(...)
disable_user
editDisables users in the native realm.
client.security.disableUser(...)
enable_user
editEnables users in the native realm.
client.security.enableUser(...)
enroll_kibana
editAllows a kibana instance to configure itself to communicate with a secured elasticsearch cluster.
client.security.enrollKibana(...)
enroll_node
editAllows a new node to enroll to an existing cluster with security enabled.
client.security.enrollNode(...)
get_api_key
editRetrieves information for one or more API keys.
client.security.getApiKey(...)
get_builtin_privileges
editRetrieves the list of cluster privileges and index privileges that are available in this version of Elasticsearch.
client.security.getBuiltinPrivileges(...)
get_privileges
editRetrieves application privileges.
client.security.getPrivileges(...)
get_role
editRetrieves roles in the native realm.
client.security.getRole(...)
get_role_mapping
editRetrieves role mappings.
client.security.getRoleMapping(...)
get_service_accounts
editRetrieves information about service accounts.
client.security.getServiceAccounts(...)
get_service_credentials
editRetrieves information of all service credentials for a service account.
client.security.getServiceCredentials(...)
get_token
editCreates a bearer token for access without requiring basic authentication.
client.security.getToken(...)
get_user
editRetrieves information about users in the native realm and built-in users.
client.security.getUser(...)
get_user_privileges
editRetrieves security privileges for the logged in user.
client.security.getUserPrivileges(...)
grant_api_key
editCreates an API key on behalf of another user.
client.security.grantApiKey(...)
has_privileges
editDetermines whether the specified user has a specified list of privileges.
client.security.hasPrivileges(...)
invalidate_api_key
editInvalidates one or more API keys.
client.security.invalidateApiKey(...)
invalidate_token
editInvalidates one or more access tokens or refresh tokens.
client.security.invalidateToken(...)
oidc_authenticate
editExchanges an OpenID Connection authentication response message for an Elasticsearch access token and refresh token pair
client.security.oidcAuthenticate(...)
oidc_logout
editInvalidates a refresh token and access token that was generated from the OpenID Connect Authenticate API
client.security.oidcLogout(...)
oidc_prepare_authentication
editCreates an OAuth 2.0 authentication request as a URL string
client.security.oidcPrepareAuthentication(...)
put_privileges
editAdds or updates application privileges.
client.security.putPrivileges(...)
put_role
editAdds and updates roles in the native realm.
client.security.putRole(...)
put_role_mapping
editCreates and updates role mappings.
client.security.putRoleMapping(...)
put_user
editAdds and updates users in the native realm. These users are commonly referred to as native users.
client.security.putUser(...)
query_api_keys
editRetrieves information for API keys using a subset of query DSL
client.security.queryApiKeys(...)
saml_authenticate
editExchanges a SAML Response message for an Elasticsearch access token and refresh token pair
client.security.samlAuthenticate(...)
saml_complete_logout
editVerifies the logout response sent from the SAML IdP
client.security.samlCompleteLogout(...)
saml_invalidate
editConsumes a SAML LogoutRequest
client.security.samlInvalidate(...)
saml_logout
editInvalidates an access token and a refresh token that were generated via the SAML Authenticate API
client.security.samlLogout(...)
saml_prepare_authentication
editCreates a SAML authentication request
client.security.samlPrepareAuthentication(...)
saml_service_provider_metadata
editGenerates SAML metadata for the Elastic stack SAML 2.0 Service Provider
client.security.samlServiceProviderMetadata(...)
update_api_key
editUpdates attributes of an existing API key.
client.security.updateApiKey(...)
slm
editdelete_lifecycle
editDeletes an existing snapshot lifecycle policy.
client.slm.deleteLifecycle(...)
execute_lifecycle
editImmediately creates a snapshot according to the lifecycle policy, without waiting for the scheduled time.
client.slm.executeLifecycle(...)
execute_retention
editDeletes any snapshots that are expired according to the policy’s retention rules.
client.slm.executeRetention(...)
get_lifecycle
editRetrieves one or more snapshot lifecycle policy definitions and information about the latest snapshot attempts.
client.slm.getLifecycle(...)
get_stats
editReturns global and policy-level statistics about actions taken by snapshot lifecycle management.
client.slm.getStats(...)
get_status
editRetrieves the status of snapshot lifecycle management (SLM).
client.slm.getStatus(...)
put_lifecycle
editCreates or updates a snapshot lifecycle policy.
client.slm.putLifecycle(...)
start
editTurns on snapshot lifecycle management (SLM).
client.slm.start(...)
stop
editTurns off snapshot lifecycle management (SLM).
client.slm.stop(...)
snapshot
editcleanup_repository
editRemoves stale data from repository.
client.snapshot.cleanupRepository(...)
clone
editClones indices from one snapshot into another snapshot in the same repository.
client.snapshot.clone(...)
create
editCreates a snapshot in a repository.
client.snapshot.create(...)
create_repository
editCreates a repository.
client.snapshot.createRepository(...)
delete
editDeletes one or more snapshots.
client.snapshot.delete(...)
delete_repository
editDeletes a repository.
client.snapshot.deleteRepository(...)
get
editReturns information about a snapshot.
client.snapshot.get(...)
get_repository
editReturns information about a repository.
client.snapshot.getRepository(...)
repository_analyze
editAnalyzes a repository for correctness and performance
client.snapshot.repositoryAnalyze(...)
restore
editRestores a snapshot.
client.snapshot.restore(...)
status
editReturns information about the status of a snapshot.
client.snapshot.status(...)
verify_repository
editVerifies a repository.
client.snapshot.verifyRepository(...)
sql
editclear_cursor
editClears the SQL cursor
client.sql.clearCursor(...)
delete_async
editDeletes an async SQL search or a stored synchronous SQL search. If the search is still running, the API cancels it.
client.sql.deleteAsync(...)
get_async
editReturns the current status and available results for an async SQL search or stored synchronous SQL search
client.sql.getAsync(...)
get_async_status
editReturns the current status of an async SQL search or a stored synchronous SQL search
client.sql.getAsyncStatus(...)
query
editExecutes a SQL request
client.sql.query(...)
translate
editTranslates SQL into Elasticsearch queries
client.sql.translate(...)
ssl
editcertificates
editRetrieves information about the X.509 certificates used to encrypt communications in the cluster.
client.ssl.certificates(...)
tasks
editcancel
editCancels a task, if it can be cancelled through an API.
client.tasks.cancel(...)
get
editReturns information about a task.
client.tasks.get(...)
list
editReturns a list of tasks.
client.tasks.list(...)
text_structure
editfind_structure
editFinds the structure of a text file. The text file must contain data that is suitable to be ingested into Elasticsearch.
client.textStructure.findStructure(...)
transform
editdelete_transform
editDeletes an existing transform.
client.transform.deleteTransform(...)
get_transform
editRetrieves configuration information for transforms.
client.transform.getTransform(...)
get_transform_stats
editRetrieves usage information for transforms.
client.transform.getTransformStats(...)
preview_transform
editPreviews a transform.
client.transform.previewTransform(...)
put_transform
editInstantiates a transform.
client.transform.putTransform(...)
reset_transform
editResets an existing transform.
client.transform.resetTransform(...)
start_transform
editStarts one or more transforms.
client.transform.startTransform(...)
stop_transform
editStops one or more transforms.
client.transform.stopTransform(...)
update_transform
editUpdates certain properties of a transform.
client.transform.updateTransform(...)
upgrade_transforms
editUpgrades all transforms.
client.transform.upgradeTransforms(...)
watcher
editack_watch
editAcknowledges a watch, manually throttling the execution of the watch’s actions.
client.watcher.ackWatch(...)
activate_watch
editActivates a currently inactive watch.
client.watcher.activateWatch(...)
deactivate_watch
editDeactivates a currently active watch.
client.watcher.deactivateWatch(...)
delete_watch
editRemoves a watch from Watcher.
client.watcher.deleteWatch(...)
execute_watch
editForces the execution of a stored watch.
client.watcher.executeWatch(...)
get_watch
editRetrieves a watch by its ID.
client.watcher.getWatch(...)
put_watch
editCreates a new watch, or updates an existing one.
client.watcher.putWatch(...)
query_watches
editRetrieves stored watches.
client.watcher.queryWatches(...)
start
editStarts Watcher if it is not already running.
client.watcher.start(...)
stats
editRetrieves the current Watcher metrics.
client.watcher.stats(...)
stop
editStops Watcher if it is running.
client.watcher.stop(...)
xpack
editinfo
editRetrieves information about the installed X-Pack features.
client.xpack.info(...)
usage
editRetrieves usage information about the installed X-Pack features.
client.xpack.usage(...)