API Referenceedit
bulkedit
Allows to perform multiple index/update/delete operations in a single request.
client.bulk(...)
clear_scrolledit
Explicitly clears the search context for a scroll.
client.clearScroll(...)
close_point_in_timeedit
Close a point in time
client.closePointInTime(...)
countedit
Returns number of documents matching a query.
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.
client.create(...)
deleteedit
Removes a document from the index.
client.delete(...)
delete_by_queryedit
Deletes documents matching the provided query.
client.deleteByQuery(...)
delete_by_query_rethrottleedit
Changes the number of requests per second for a particular Delete By Query operation.
client.deleteByQueryRethrottle(...)
delete_scriptedit
Deletes a script.
client.deleteScript(...)
existsedit
Returns information about whether a document exists in an index.
client.exists(...)
exists_sourceedit
Returns information about whether a document source exists in an index.
client.existsSource(...)
explainedit
Returns information about why a specific matches (or doesn’t match) a query.
client.explain(...)
field_capsedit
Returns the information about the capabilities of fields among multiple indices.
client.fieldCaps(...)
getedit
Returns a document.
client.get(...)
get_scriptedit
Returns a script.
client.getScript(...)
get_script_contextedit
Returns all script contexts.
client.getScriptContext(...)
get_script_languagesedit
Returns available script types, languages and contexts
client.getScriptLanguages(...)
get_sourceedit
Returns the source of a document.
client.getSource(...)
health_reportedit
Returns the health of the cluster.
client.healthReport(...)
indexedit
Creates or updates a document in an index.
client.index(...)
infoedit
Returns basic information about the cluster.
client.info(...)
knn_searchedit
Performs a kNN search.
client.knnSearch(...)
mgetedit
Allows to get multiple documents in one request.
client.mget(...)
msearchedit
Allows to execute several search operations in one request.
client.msearch(...)
msearch_templateedit
Allows to execute several search template operations in one request.
client.msearchTemplate(...)
mtermvectorsedit
Returns multiple termvectors in one request.
client.mtermvectors(...)
open_point_in_timeedit
Open a point in time that can be used in subsequent searches
client.openPointInTime(...)
pingedit
Returns whether the cluster is running.
client.ping(...)
put_scriptedit
Creates or updates a script.
client.putScript(...)
rank_evaledit
Allows to evaluate the quality of ranked search results over a set of typical search queries
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.
client.reindex(...)
reindex_rethrottleedit
Changes the number of requests per second for a particular Reindex operation.
client.reindexRethrottle(...)
render_search_templateedit
Allows to use the Mustache language to pre-render a search definition.
client.renderSearchTemplate(...)
scripts_painless_executeedit
Allows an arbitrary script to be executed and a result to be returned
client.scriptsPainlessExecute(...)
scrolledit
Allows to retrieve a large numbers of results from a single search request.
client.scroll(...)
searchedit
Returns results matching a query.
client.search(...)
search_mvtedit
Searches a vector tile for geospatial values. Returns results as a binary Mapbox vector tile.
client.searchMvt(...)
search_shardsedit
Returns information about the indices and shards that a search request would be executed against.
client.searchShards(...)
search_templateedit
Allows to use the Mustache language to pre-render a search definition.
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.
client.termsEnum(...)
termvectorsedit
Returns information and statistics about terms in the fields of a particular document.
client.termvectors(...)
updateedit
Updates a document with a script or partial document.
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.
client.updateByQuery(...)
update_by_query_rethrottleedit
Changes the number of requests per second for a particular Update By Query operation.
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.
client.asyncSearch.delete(...)
getedit
Retrieves the results of a previously submitted async search request given its ID.
client.asyncSearch.get(...)
statusedit
Retrieves the status of a previously submitted async search request given its ID.
client.asyncSearch.status(...)
submitedit
Executes a search request asynchronously.
client.asyncSearch.submit(...)
catedit
aliasesedit
Shows information about currently configured aliases to indices including filter and routing infos.
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.
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.
client.cat.count(...)
fielddataedit
Shows how much heap memory is currently being used by fielddata on every data node in the cluster.
client.cat.fielddata(...)
healthedit
Returns a concise representation of the cluster health.
client.cat.health(...)
helpedit
Returns help for the Cat APIs.
client.cat.help(...)
indicesedit
Returns information about indices: number of primaries and replicas, document counts, disk size, …
client.cat.indices(...)
masteredit
Returns information about the master node.
client.cat.master(...)
ml_data_frame_analyticsedit
Gets configuration and usage information about data frame analytics jobs.
client.cat.mlDataFrameAnalytics(...)
ml_datafeedsedit
Gets configuration and usage information about datafeeds.
client.cat.mlDatafeeds(...)
ml_jobsedit
Gets configuration and usage information about anomaly detection jobs.
client.cat.mlJobs(...)
ml_trained_modelsedit
Gets configuration and usage information about inference trained models.
client.cat.mlTrainedModels(...)
nodeattrsedit
Returns information about custom node attributes.
client.cat.nodeattrs(...)
nodesedit
Returns basic statistics about performance of cluster nodes.
client.cat.nodes(...)
pending_tasksedit
Returns a concise representation of the cluster pending tasks.
client.cat.pendingTasks(...)
pluginsedit
Returns information about installed plugins across nodes node.
client.cat.plugins(...)
recoveryedit
Returns information about index shard recoveries, both on-going completed.
client.cat.recovery(...)
repositoriesedit
Returns information about snapshot repositories registered in the cluster.
client.cat.repositories(...)
segmentsedit
Provides low-level information about the segments in the shards of an index.
client.cat.segments(...)
shardsedit
Provides a detailed view of shard allocation on nodes.
client.cat.shards(...)
snapshotsedit
Returns all snapshots in a specific repository.
client.cat.snapshots(...)
tasksedit
Returns information about the tasks currently executing on one or more nodes in the cluster.
client.cat.tasks(...)
templatesedit
Returns information about existing templates.
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.
client.cat.threadPool(...)
transformsedit
Gets configuration and usage information about transforms.
client.cat.transforms(...)
ccredit
delete_auto_follow_patternedit
Deletes auto-follow patterns.
client.ccr.deleteAutoFollowPattern(...)
followedit
Creates a new follower index configured to follow the referenced leader index.
client.ccr.follow(...)
follow_infoedit
Retrieves information about all follower indices, including parameters and status for each follower index
client.ccr.followInfo(...)
follow_statsedit
Retrieves follower stats. return shard-level stats about the following tasks associated with each shard for the specified indices.
client.ccr.followStats(...)
forget_followeredit
Removes the follower retention leases from the leader.
client.ccr.forgetFollower(...)
get_auto_follow_patternedit
Gets configured auto-follow patterns. Returns the specified auto-follow pattern collection.
client.ccr.getAutoFollowPattern(...)
pause_auto_follow_patternedit
Pauses an auto-follow pattern
client.ccr.pauseAutoFollowPattern(...)
pause_followedit
Pauses a follower index. The follower index will not fetch any additional operations from the leader index.
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.
client.ccr.putAutoFollowPattern(...)
resume_auto_follow_patternedit
Resumes an auto-follow pattern that has been paused
client.ccr.resumeAutoFollowPattern(...)
resume_followedit
Resumes a follower index that has been paused
client.ccr.resumeFollow(...)
statsedit
Gets all stats related to cross-cluster replication.
client.ccr.stats(...)
unfollowedit
Stops the following task associated with a follower index and removes index metadata and settings associated with cross-cluster replication.
client.ccr.unfollow(...)
clusteredit
allocation_explainedit
Provides explanations for shard allocations in the cluster.
client.cluster.allocationExplain(...)
delete_component_templateedit
Deletes a component template
client.cluster.deleteComponentTemplate(...)
delete_voting_config_exclusionsedit
Clears cluster voting config exclusions.
client.cluster.deleteVotingConfigExclusions(...)
exists_component_templateedit
Returns information about whether a particular component template exist
client.cluster.existsComponentTemplate(...)
get_component_templateedit
Returns one or more component templates
client.cluster.getComponentTemplate(...)
get_settingsedit
Returns cluster settings.
client.cluster.getSettings(...)
healthedit
Returns basic information about the health of the cluster.
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.
client.cluster.pendingTasks(...)
post_voting_config_exclusionsedit
Updates the cluster voting config exclusions by node ids or node names.
client.cluster.postVotingConfigExclusions(...)
put_component_templateedit
Creates or updates a component template
client.cluster.putComponentTemplate(...)
put_settingsedit
Updates the cluster settings.
client.cluster.putSettings(...)
remote_infoedit
Returns the information about configured remote clusters.
client.cluster.remoteInfo(...)
rerouteedit
Allows to manually change the allocation of individual shards in the cluster.
client.cluster.reroute(...)
stateedit
Returns a comprehensive information about the state of the cluster.
client.cluster.state(...)
statsedit
Returns high-level overview of cluster statistics.
client.cluster.stats(...)
dangling_indicesedit
delete_dangling_indexedit
Deletes the specified dangling index
client.danglingIndices.deleteDanglingIndex(...)
import_dangling_indexedit
Imports the specified dangling index
client.danglingIndices.importDanglingIndex(...)
list_dangling_indicesedit
Returns all dangling indices.
client.danglingIndices.listDanglingIndices(...)
enrichedit
delete_policyedit
Deletes an existing enrich policy and its enrich index.
client.enrich.deletePolicy(...)
execute_policyedit
Creates the enrich index for an existing enrich policy.
client.enrich.executePolicy(...)
get_policyedit
Gets information about an enrich policy.
client.enrich.getPolicy(...)
put_policyedit
Creates a new enrich policy.
client.enrich.putPolicy(...)
statsedit
Gets enrich coordinator statistics and information about enrich policies that are currently executing.
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.
client.eql.delete(...)
getedit
Returns async results from previously executed Event Query Language (EQL) search
client.eql.get(...)
get_statusedit
Returns the status of a previously submitted async or stored Event Query Language (EQL) search
client.eql.getStatus(...)
searchedit
Returns results matching a query expressed in Event Query Language (EQL)
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
client.features.getFeatures(...)
reset_featuresedit
Resets the internal state of features, usually by deleting system indices
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.
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.
client.graph.explore(...)
ilmedit
delete_lifecycleedit
Deletes the specified lifecycle policy definition. A currently used policy cannot be deleted.
client.ilm.deleteLifecycle(...)
explain_lifecycleedit
Retrieves information about the index’s current lifecycle state, such as the currently executing phase, action, and step.
client.ilm.explainLifecycle(...)
get_lifecycleedit
Returns the specified policy definition. Includes the policy version and last modified date.
client.ilm.getLifecycle(...)
get_statusedit
Retrieves the current index lifecycle management (ILM) status.
client.ilm.getStatus(...)
migrate_to_data_tiersedit
Migrates the indices and ILM policies away from custom node attribute allocation routing to data tiers routing
client.ilm.migrateToDataTiers(...)
move_to_stepedit
Manually moves an index into the specified step and executes that step.
client.ilm.moveToStep(...)
put_lifecycleedit
Creates a lifecycle policy
client.ilm.putLifecycle(...)
remove_policyedit
Removes the assigned lifecycle policy and stops managing the specified index
client.ilm.removePolicy(...)
retryedit
Retries executing the policy for an index that is in the ERROR step.
client.ilm.retry(...)
startedit
Start the index lifecycle management (ILM) plugin.
client.ilm.start(...)
stopedit
Halts all lifecycle management operations and stops the index lifecycle management (ILM) plugin
client.ilm.stop(...)
indicesedit
add_blockedit
Adds a block to an index.
client.indices.addBlock(...)
analyzeedit
Performs the analysis process on a text and return the tokens breakdown of the text.
client.indices.analyze(...)
clear_cacheedit
Clears all or specific caches for one or more indices.
client.indices.clearCache(...)
cloneedit
Clones an index
client.indices.clone(...)
closeedit
Closes an index.
client.indices.close(...)
createedit
Creates an index with optional settings and mappings.
client.indices.create(...)
create_data_streamedit
Creates a data stream
client.indices.createDataStream(...)
data_streams_statsedit
Provides statistics on operations happening in a data stream.
client.indices.dataStreamsStats(...)
deleteedit
Deletes an index.
client.indices.delete(...)
delete_aliasedit
Deletes an alias.
client.indices.deleteAlias(...)
delete_data_lifecycleedit
Deletes the data lifecycle of the selected data streams.
client.indices.deleteDataLifecycle(...)
delete_data_streamedit
Deletes a data stream.
client.indices.deleteDataStream(...)
delete_index_templateedit
Deletes an index template.
client.indices.deleteIndexTemplate(...)
delete_templateedit
Deletes an index template.
client.indices.deleteTemplate(...)
disk_usageedit
Analyzes the disk usage of each field of an index or data stream
client.indices.diskUsage(...)
downsampleedit
Downsample an index
client.indices.downsample(...)
existsedit
Returns information about whether a particular index exists.
client.indices.exists(...)
exists_aliasedit
Returns information about whether a particular alias exists.
client.indices.existsAlias(...)
exists_index_templateedit
Returns information about whether a particular index template exists.
client.indices.existsIndexTemplate(...)
exists_templateedit
Returns information about whether a particular index template exists.
client.indices.existsTemplate(...)
explain_data_lifecycleedit
Retrieves information about the index’s current DLM lifecycle, such as any potential encountered error, time since creation etc.
client.indices.explainDataLifecycle(...)
field_usage_statsedit
Returns the field usage stats for each field of an index
client.indices.fieldUsageStats(...)
flushedit
Performs the flush operation on one or more indices.
client.indices.flush(...)
forcemergeedit
Performs the force merge operation on one or more indices.
client.indices.forcemerge(...)
getedit
Returns information about one or more indices.
client.indices.get(...)
get_aliasedit
Returns an alias.
client.indices.getAlias(...)
get_data_lifecycleedit
Returns the data lifecycle of the selected data streams.
client.indices.getDataLifecycle(...)
get_data_streamedit
Returns data streams.
client.indices.getDataStream(...)
get_field_mappingedit
Returns mapping for one or more fields.
client.indices.getFieldMapping(...)
get_index_templateedit
Returns an index template.
client.indices.getIndexTemplate(...)
get_mappingedit
Returns mappings for one or more indices.
client.indices.getMapping(...)
get_settingsedit
Returns settings for one or more indices.
client.indices.getSettings(...)
get_templateedit
Returns an index template.
client.indices.getTemplate(...)
migrate_to_data_streamedit
Migrates an alias to a data stream
client.indices.migrateToDataStream(...)
modify_data_streamedit
Modifies a data stream
client.indices.modifyDataStream(...)
openedit
Opens an index.
client.indices.open(...)
promote_data_streamedit
Promotes a data stream from a replicated data stream managed by CCR to a regular data stream
client.indices.promoteDataStream(...)
put_aliasedit
Creates or updates an alias.
client.indices.putAlias(...)
put_data_lifecycleedit
Updates the data lifecycle of the selected data streams.
client.indices.putDataLifecycle(...)
put_index_templateedit
Creates or updates an index template.
client.indices.putIndexTemplate(...)
put_mappingedit
Updates the index mappings.
client.indices.putMapping(...)
put_settingsedit
Updates the index settings.
client.indices.putSettings(...)
put_templateedit
Creates or updates an index template.
client.indices.putTemplate(...)
recoveryedit
Returns information about ongoing index shard recoveries.
client.indices.recovery(...)
refreshedit
Performs the refresh operation in one or more indices.
client.indices.refresh(...)
reload_search_analyzersedit
Reloads an index’s search analyzers and their resources.
client.indices.reloadSearchAnalyzers(...)
resolve_indexedit
Returns information about any matching indices, aliases, and data streams
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.
client.indices.rollover(...)
segmentsedit
Provides low-level information about segments in a Lucene index.
client.indices.segments(...)
shard_storesedit
Provides store information for shard copies of indices.
client.indices.shardStores(...)
shrinkedit
Allow to shrink an existing index into a new index with fewer primary shards.
client.indices.shrink(...)
simulate_index_templateedit
Simulate matching the given index name against the index templates in the system
client.indices.simulateIndexTemplate(...)
simulate_templateedit
Simulate resolving the given template name or body
client.indices.simulateTemplate(...)
splitedit
Allows you to split an existing index into a new index with more primary shards.
client.indices.split(...)
statsedit
Provides statistics on operations happening in an index.
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.
client.indices.unfreeze(...)
update_aliasesedit
Updates index aliases.
client.indices.updateAliases(...)
validate_queryedit
Allows a user to validate a potentially expensive query without executing it.
client.indices.validateQuery(...)
ingestedit
delete_pipelineedit
Deletes a pipeline.
client.ingest.deletePipeline(...)
geo_ip_statsedit
Returns statistical information about geoip databases
client.ingest.geoIpStats(...)
get_pipelineedit
Returns a pipeline.
client.ingest.getPipeline(...)
processor_grokedit
Returns a list of the built-in patterns.
client.ingest.processorGrok(...)
put_pipelineedit
Creates or updates a pipeline.
client.ingest.putPipeline(...)
simulateedit
Allows to simulate a pipeline with example documents.
client.ingest.simulate(...)
licenseedit
deleteedit
Deletes licensing information for the cluster
client.license.delete(...)
getedit
Retrieves licensing information for the cluster
client.license.get(...)
get_basic_statusedit
Retrieves information about the status of the basic license.
client.license.getBasicStatus(...)
get_trial_statusedit
Retrieves information about the status of the trial license.
client.license.getTrialStatus(...)
postedit
Updates the license for the cluster.
client.license.post(...)
post_start_basicedit
Starts an indefinite basic license.
client.license.postStartBasic(...)
post_start_trialedit
starts a limited time trial license.
client.license.postStartTrial(...)
logstashedit
delete_pipelineedit
Deletes Logstash Pipelines used by Central Management
client.logstash.deletePipeline(...)
get_pipelineedit
Retrieves Logstash Pipelines used by Central Management
client.logstash.getPipeline(...)
put_pipelineedit
Adds and updates Logstash Pipelines used for Central Management
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.
client.migration.deprecations(...)
get_feature_upgrade_statusedit
Find out whether system features need to be upgraded or not
client.migration.getFeatureUpgradeStatus(...)
post_feature_upgradeedit
Begin upgrades for system features
client.migration.postFeatureUpgrade(...)
mledit
clear_trained_model_deployment_cacheedit
Clear the cached results from a trained model deployment
client.ml.clearTrainedModelDeploymentCache(...)
close_jobedit
Closes one or more anomaly detection jobs. A job can be opened and closed multiple times throughout its lifecycle.
client.ml.closeJob(...)
delete_calendaredit
Deletes a calendar.
client.ml.deleteCalendar(...)
delete_calendar_eventedit
Deletes scheduled events from a calendar.
client.ml.deleteCalendarEvent(...)
delete_calendar_jobedit
Deletes anomaly detection jobs from a calendar.
client.ml.deleteCalendarJob(...)
delete_data_frame_analyticsedit
Deletes an existing data frame analytics job.
client.ml.deleteDataFrameAnalytics(...)
delete_datafeededit
Deletes an existing datafeed.
client.ml.deleteDatafeed(...)
delete_expired_dataedit
Deletes expired and unused machine learning data.
client.ml.deleteExpiredData(...)
delete_filteredit
Deletes a filter.
client.ml.deleteFilter(...)
delete_forecastedit
Deletes forecasts from a machine learning job.
client.ml.deleteForecast(...)
delete_jobedit
Deletes an existing anomaly detection job.
client.ml.deleteJob(...)
delete_model_snapshotedit
Deletes an existing model snapshot.
client.ml.deleteModelSnapshot(...)
delete_trained_modeledit
Deletes an existing trained inference model that is currently not referenced by an ingest pipeline.
client.ml.deleteTrainedModel(...)
delete_trained_model_aliasedit
Deletes a model alias that refers to the trained model
client.ml.deleteTrainedModelAlias(...)
estimate_model_memoryedit
Estimates the model memory
client.ml.estimateModelMemory(...)
evaluate_data_frameedit
Evaluates the data frame analytics for an annotated index.
client.ml.evaluateDataFrame(...)
explain_data_frame_analyticsedit
Explains a data frame analytics config.
client.ml.explainDataFrameAnalytics(...)
flush_jobedit
Forces any buffered data to be processed by the job.
client.ml.flushJob(...)
forecastedit
Predicts the future behavior of a time series by using its historical behavior.
client.ml.forecast(...)
get_bucketsedit
Retrieves anomaly detection job results for one or more buckets.
client.ml.getBuckets(...)
get_calendar_eventsedit
Retrieves information about the scheduled events in calendars.
client.ml.getCalendarEvents(...)
get_calendarsedit
Retrieves configuration information for calendars.
client.ml.getCalendars(...)
get_categoriesedit
Retrieves anomaly detection job results for one or more categories.
client.ml.getCategories(...)
get_data_frame_analyticsedit
Retrieves configuration information for data frame analytics jobs.
client.ml.getDataFrameAnalytics(...)
get_data_frame_analytics_statsedit
Retrieves usage information for data frame analytics jobs.
client.ml.getDataFrameAnalyticsStats(...)
get_datafeed_statsedit
Retrieves usage information for datafeeds.
client.ml.getDatafeedStats(...)
get_datafeedsedit
Retrieves configuration information for datafeeds.
client.ml.getDatafeeds(...)
get_filtersedit
Retrieves filters.
client.ml.getFilters(...)
get_influencersedit
Retrieves anomaly detection job results for one or more influencers.
client.ml.getInfluencers(...)
get_job_statsedit
Retrieves usage information for anomaly detection jobs.
client.ml.getJobStats(...)
get_jobsedit
Retrieves configuration information for anomaly detection jobs.
client.ml.getJobs(...)
get_memory_statsedit
Returns information on how ML is using memory.
client.ml.getMemoryStats(...)
get_model_snapshot_upgrade_statsedit
Gets stats for anomaly detection job model snapshot upgrades that are in progress.
client.ml.getModelSnapshotUpgradeStats(...)
get_model_snapshotsedit
Retrieves information about model snapshots.
client.ml.getModelSnapshots(...)
get_overall_bucketsedit
Retrieves overall bucket results that summarize the bucket results of multiple anomaly detection jobs.
client.ml.getOverallBuckets(...)
get_recordsedit
Retrieves anomaly records for an anomaly detection job.
client.ml.getRecords(...)
get_trained_modelsedit
Retrieves configuration information for a trained inference model.
client.ml.getTrainedModels(...)
get_trained_models_statsedit
Retrieves usage information for trained inference models.
client.ml.getTrainedModelsStats(...)
infer_trained_modeledit
Evaluate a trained model.
client.ml.inferTrainedModel(...)
infoedit
Returns defaults and limits used by machine learning.
client.ml.info(...)
open_jobedit
Opens one or more anomaly detection jobs.
client.ml.openJob(...)
post_calendar_eventsedit
Posts scheduled events in a calendar.
client.ml.postCalendarEvents(...)
post_dataedit
Sends data to an anomaly detection job for analysis.
client.ml.postData(...)
preview_data_frame_analyticsedit
Previews that will be analyzed given a data frame analytics config.
client.ml.previewDataFrameAnalytics(...)
preview_datafeededit
Previews a datafeed.
client.ml.previewDatafeed(...)
put_calendaredit
Instantiates a calendar.
client.ml.putCalendar(...)
put_calendar_jobedit
Adds an anomaly detection job to a calendar.
client.ml.putCalendarJob(...)
put_data_frame_analyticsedit
Instantiates a data frame analytics job.
client.ml.putDataFrameAnalytics(...)
put_datafeededit
Instantiates a datafeed.
client.ml.putDatafeed(...)
put_filteredit
Instantiates a filter.
client.ml.putFilter(...)
put_jobedit
Instantiates an anomaly detection job.
client.ml.putJob(...)
put_trained_modeledit
Creates an inference trained model.
client.ml.putTrainedModel(...)
put_trained_model_aliasedit
Creates a new model alias (or reassigns an existing one) to refer to the trained model
client.ml.putTrainedModelAlias(...)
put_trained_model_definition_partedit
Creates part of a trained model definition
client.ml.putTrainedModelDefinitionPart(...)
put_trained_model_vocabularyedit
Creates a trained model vocabulary
client.ml.putTrainedModelVocabulary(...)
reset_jobedit
Resets an existing anomaly detection job.
client.ml.resetJob(...)
revert_model_snapshotedit
Reverts to a specific snapshot.
client.ml.revertModelSnapshot(...)
set_upgrade_modeedit
Sets a cluster wide upgrade_mode setting that prepares machine learning indices for an upgrade.
client.ml.setUpgradeMode(...)
start_data_frame_analyticsedit
Starts a data frame analytics job.
client.ml.startDataFrameAnalytics(...)
start_datafeededit
Starts one or more datafeeds.
client.ml.startDatafeed(...)
start_trained_model_deploymentedit
Start a trained model deployment.
client.ml.startTrainedModelDeployment(...)
stop_data_frame_analyticsedit
Stops one or more data frame analytics jobs.
client.ml.stopDataFrameAnalytics(...)
stop_datafeededit
Stops one or more datafeeds.
client.ml.stopDatafeed(...)
stop_trained_model_deploymentedit
Stop a trained model deployment.
client.ml.stopTrainedModelDeployment(...)
update_data_frame_analyticsedit
Updates certain properties of a data frame analytics job.
client.ml.updateDataFrameAnalytics(...)
update_datafeededit
Updates certain properties of a datafeed.
client.ml.updateDatafeed(...)
update_filteredit
Updates the description of a filter, adds items, or removes items.
client.ml.updateFilter(...)
update_jobedit
Updates certain properties of an anomaly detection job.
client.ml.updateJob(...)
update_model_snapshotedit
Updates certain properties of a snapshot.
client.ml.updateModelSnapshot(...)
update_trained_model_deploymentedit
Updates certain properties of trained model deployment.
client.ml.updateTrainedModelDeployment(...)
upgrade_job_snapshotedit
Upgrades a given job snapshot to the current major version.
client.ml.upgradeJobSnapshot(...)
nodesedit
clear_repositories_metering_archiveedit
Removes the archived repositories metering information present in the cluster.
client.nodes.clearRepositoriesMeteringArchive(...)
get_repositories_metering_infoedit
Returns cluster repositories metering information.
client.nodes.getRepositoriesMeteringInfo(...)
hot_threadsedit
Returns information about hot threads on each node in the cluster.
client.nodes.hotThreads(...)
infoedit
Returns information about nodes in the cluster.
client.nodes.info(...)
reload_secure_settingsedit
Reloads secure settings.
client.nodes.reloadSecureSettings(...)
statsedit
Returns statistical information about nodes in the cluster.
client.nodes.stats(...)
usageedit
Returns low-level information about REST actions usage on nodes.
client.nodes.usage(...)
rollupedit
delete_jobedit
Deletes an existing rollup job.
client.rollup.deleteJob(...)
get_jobsedit
Retrieves the configuration, stats, and status of rollup jobs.
client.rollup.getJobs(...)
get_rollup_capsedit
Returns the capabilities of any rollup jobs that have been configured for a specific index or index pattern.
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).
client.rollup.getRollupIndexCaps(...)
put_jobedit
Creates a rollup job.
client.rollup.putJob(...)
rollup_searchedit
Enables searching rolled-up data using the standard query DSL.
client.rollup.rollupSearch(...)
start_jobedit
Starts an existing, stopped rollup job.
client.rollup.startJob(...)
stop_jobedit
Stops an existing, started rollup job.
client.rollup.stopJob(...)
search_applicationedit
deleteedit
Deletes a search application.
client.searchApplication.delete(...)
delete_behavioral_analyticsedit
Delete a behavioral analytics collection.
client.searchApplication.deleteBehavioralAnalytics(...)
getedit
Returns the details about a search application.
client.searchApplication.get(...)
get_behavioral_analyticsedit
Returns the existing behavioral analytics collections.
client.searchApplication.getBehavioralAnalytics(...)
listedit
Returns the existing search applications.
client.searchApplication.list(...)
post_behavioral_analytics_eventedit
Creates a behavioral analytics event for existing collection.
client.searchApplication.postBehavioralAnalyticsEvent(...)
putedit
Creates or updates a search application.
client.searchApplication.put(...)
put_behavioral_analyticsedit
Creates a behavioral analytics collection.
client.searchApplication.putBehavioralAnalytics(...)
searchedit
Perform a search against a search application
client.searchApplication.search(...)
searchable_snapshotsedit
cache_statsedit
Retrieve node-level cache statistics about searchable snapshots.
client.searchableSnapshots.cacheStats(...)
clear_cacheedit
Clear the cache of searchable snapshots.
client.searchableSnapshots.clearCache(...)
mountedit
Mount a snapshot as a searchable index.
client.searchableSnapshots.mount(...)
statsedit
Retrieve shard-level statistics about searchable snapshots.
client.searchableSnapshots.stats(...)
securityedit
authenticateedit
Enables authentication as a user and retrieve information about the authenticated user.
client.security.authenticate(...)
bulk_update_api_keysedit
Updates the attributes of multiple existing API keys.
client.security.bulkUpdateApiKeys(...)
change_passwordedit
Changes the passwords of users in the native realm and built-in users.
client.security.changePassword(...)
clear_api_key_cacheedit
Clear a subset or all entries from the API key cache.
client.security.clearApiKeyCache(...)
clear_cached_privilegesedit
Evicts application privileges from the native application privileges cache.
client.security.clearCachedPrivileges(...)
clear_cached_realmsedit
Evicts users from the user cache. Can completely clear the cache or evict specific users.
client.security.clearCachedRealms(...)
clear_cached_rolesedit
Evicts roles from the native role cache.
client.security.clearCachedRoles(...)
clear_cached_service_tokensedit
Evicts tokens from the service account token caches.
client.security.clearCachedServiceTokens(...)
create_api_keyedit
Creates an API key for access without requiring basic authentication.
client.security.createApiKey(...)
create_service_tokenedit
Creates a service account token for access without requiring basic authentication.
client.security.createServiceToken(...)
delete_privilegesedit
Removes application privileges.
client.security.deletePrivileges(...)
delete_roleedit
Removes roles in the native realm.
client.security.deleteRole(...)
delete_role_mappingedit
Removes role mappings.
client.security.deleteRoleMapping(...)
delete_service_tokenedit
Deletes a service account token.
client.security.deleteServiceToken(...)
delete_useredit
Deletes users from the native realm.
client.security.deleteUser(...)
disable_useredit
Disables users in the native realm.
client.security.disableUser(...)
enable_useredit
Enables users in the native realm.
client.security.enableUser(...)
enroll_kibanaedit
Allows a kibana instance to configure itself to communicate with a secured elasticsearch cluster.
client.security.enrollKibana(...)
enroll_nodeedit
Allows a new node to enroll to an existing cluster with security enabled.
client.security.enrollNode(...)
get_api_keyedit
Retrieves information for one or more API keys.
client.security.getApiKey(...)
get_builtin_privilegesedit
Retrieves the list of cluster privileges and index privileges that are available in this version of Elasticsearch.
client.security.getBuiltinPrivileges(...)
get_privilegesedit
Retrieves application privileges.
client.security.getPrivileges(...)
get_roleedit
Retrieves roles in the native realm.
client.security.getRole(...)
get_role_mappingedit
Retrieves role mappings.
client.security.getRoleMapping(...)
get_service_accountsedit
Retrieves information about service accounts.
client.security.getServiceAccounts(...)
get_service_credentialsedit
Retrieves information of all service credentials for a service account.
client.security.getServiceCredentials(...)
get_tokenedit
Creates a bearer token for access without requiring basic authentication.
client.security.getToken(...)
get_useredit
Retrieves information about users in the native realm and built-in users.
client.security.getUser(...)
get_user_privilegesedit
Retrieves security privileges for the logged in user.
client.security.getUserPrivileges(...)
grant_api_keyedit
Creates an API key on behalf of another user.
client.security.grantApiKey(...)
has_privilegesedit
Determines whether the specified user has a specified list of privileges.
client.security.hasPrivileges(...)
invalidate_api_keyedit
Invalidates one or more API keys.
client.security.invalidateApiKey(...)
invalidate_tokenedit
Invalidates one or more access tokens or refresh tokens.
client.security.invalidateToken(...)
oidc_authenticateedit
Exchanges an OpenID Connection authentication response message for an Elasticsearch access token and refresh token pair
client.security.oidcAuthenticate(...)
oidc_logoutedit
Invalidates a refresh token and access token that was generated from the OpenID Connect Authenticate API
client.security.oidcLogout(...)
oidc_prepare_authenticationedit
Creates an OAuth 2.0 authentication request as a URL string
client.security.oidcPrepareAuthentication(...)
put_privilegesedit
Adds or updates application privileges.
client.security.putPrivileges(...)
put_roleedit
Adds and updates roles in the native realm.
client.security.putRole(...)
put_role_mappingedit
Creates and updates role mappings.
client.security.putRoleMapping(...)
put_useredit
Adds and updates users in the native realm. These users are commonly referred to as native users.
client.security.putUser(...)
query_api_keysedit
Retrieves information for API keys using a subset of query DSL
client.security.queryApiKeys(...)
saml_authenticateedit
Exchanges a SAML Response message for an Elasticsearch access token and refresh token pair
client.security.samlAuthenticate(...)
saml_complete_logoutedit
Verifies the logout response sent from the SAML IdP
client.security.samlCompleteLogout(...)
saml_invalidateedit
Consumes a SAML LogoutRequest
client.security.samlInvalidate(...)
saml_logoutedit
Invalidates an access token and a refresh token that were generated via the SAML Authenticate API
client.security.samlLogout(...)
saml_prepare_authenticationedit
Creates a SAML authentication request
client.security.samlPrepareAuthentication(...)
saml_service_provider_metadataedit
Generates SAML metadata for the Elastic stack SAML 2.0 Service Provider
client.security.samlServiceProviderMetadata(...)
update_api_keyedit
Updates attributes of an existing API key.
client.security.updateApiKey(...)
slmedit
delete_lifecycleedit
Deletes an existing snapshot lifecycle policy.
client.slm.deleteLifecycle(...)
execute_lifecycleedit
Immediately creates a snapshot according to the lifecycle policy, without waiting for the scheduled time.
client.slm.executeLifecycle(...)
execute_retentionedit
Deletes any snapshots that are expired according to the policy’s retention rules.
client.slm.executeRetention(...)
get_lifecycleedit
Retrieves one or more snapshot lifecycle policy definitions and information about the latest snapshot attempts.
client.slm.getLifecycle(...)
get_statsedit
Returns global and policy-level statistics about actions taken by snapshot lifecycle management.
client.slm.getStats(...)
get_statusedit
Retrieves the status of snapshot lifecycle management (SLM).
client.slm.getStatus(...)
put_lifecycleedit
Creates or updates a snapshot lifecycle policy.
client.slm.putLifecycle(...)
startedit
Turns on snapshot lifecycle management (SLM).
client.slm.start(...)
stopedit
Turns off snapshot lifecycle management (SLM).
client.slm.stop(...)
snapshotedit
cleanup_repositoryedit
Removes stale data from repository.
client.snapshot.cleanupRepository(...)
cloneedit
Clones indices from one snapshot into another snapshot in the same repository.
client.snapshot.clone(...)
createedit
Creates a snapshot in a repository.
client.snapshot.create(...)
create_repositoryedit
Creates a repository.
client.snapshot.createRepository(...)
deleteedit
Deletes one or more snapshots.
client.snapshot.delete(...)
delete_repositoryedit
Deletes a repository.
client.snapshot.deleteRepository(...)
getedit
Returns information about a snapshot.
client.snapshot.get(...)
get_repositoryedit
Returns information about a repository.
client.snapshot.getRepository(...)
repository_analyzeedit
Analyzes a repository for correctness and performance
client.snapshot.repositoryAnalyze(...)
restoreedit
Restores a snapshot.
client.snapshot.restore(...)
statusedit
Returns information about the status of a snapshot.
client.snapshot.status(...)
verify_repositoryedit
Verifies a repository.
client.snapshot.verifyRepository(...)
sqledit
clear_cursoredit
Clears the SQL cursor
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.
client.sql.deleteAsync(...)
get_asyncedit
Returns the current status and available results for an async SQL search or stored synchronous SQL search
client.sql.getAsync(...)
get_async_statusedit
Returns the current status of an async SQL search or a stored synchronous SQL search
client.sql.getAsyncStatus(...)
queryedit
Executes a SQL request
client.sql.query(...)
translateedit
Translates SQL into Elasticsearch queries
client.sql.translate(...)
ssledit
certificatesedit
Retrieves information about the X.509 certificates used to encrypt communications in the cluster.
client.ssl.certificates(...)
tasksedit
canceledit
Cancels a task, if it can be cancelled through an API.
client.tasks.cancel(...)
getedit
Returns information about a task.
client.tasks.get(...)
listedit
Returns a list of tasks.
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.
client.textStructure.findStructure(...)
transformedit
delete_transformedit
Deletes an existing transform.
client.transform.deleteTransform(...)
get_transformedit
Retrieves configuration information for transforms.
client.transform.getTransform(...)
get_transform_statsedit
Retrieves usage information for transforms.
client.transform.getTransformStats(...)
preview_transformedit
Previews a transform.
client.transform.previewTransform(...)
put_transformedit
Instantiates a transform.
client.transform.putTransform(...)
reset_transformedit
Resets an existing transform.
client.transform.resetTransform(...)
schedule_now_transformedit
Schedules now a transform.
client.transform.scheduleNowTransform(...)
start_transformedit
Starts one or more transforms.
client.transform.startTransform(...)
stop_transformedit
Stops one or more transforms.
client.transform.stopTransform(...)
update_transformedit
Updates certain properties of a transform.
client.transform.updateTransform(...)
upgrade_transformsedit
Upgrades all transforms.
client.transform.upgradeTransforms(...)
watcheredit
ack_watchedit
Acknowledges a watch, manually throttling the execution of the watch’s actions.
client.watcher.ackWatch(...)
activate_watchedit
Activates a currently inactive watch.
client.watcher.activateWatch(...)
deactivate_watchedit
Deactivates a currently active watch.
client.watcher.deactivateWatch(...)
delete_watchedit
Removes a watch from Watcher.
client.watcher.deleteWatch(...)
execute_watchedit
Forces the execution of a stored watch.
client.watcher.executeWatch(...)
get_settingsedit
Retrieve settings for the watcher system index
client.watcher.getSettings(...)
get_watchedit
Retrieves a watch by its ID.
client.watcher.getWatch(...)
put_watchedit
Creates a new watch, or updates an existing one.
client.watcher.putWatch(...)
query_watchesedit
Retrieves stored watches.
client.watcher.queryWatches(...)
startedit
Starts Watcher if it is not already running.
client.watcher.start(...)
statsedit
Retrieves the current Watcher metrics.
client.watcher.stats(...)
stopedit
Stops Watcher if it is running.
client.watcher.stop(...)
update_settingsedit
Update settings for the watcher system index
client.watcher.updateSettings(...)
xpackedit
infoedit
Retrieves information about the installed X-Pack features.
client.xpack.info(...)
usageedit
Retrieves usage information about the installed X-Pack features.
client.xpack.usage(...)